├── .asf.yaml ├── .gitattributes ├── .github ├── PULL_REQUEST_TEMPLATE ├── labeler.yml └── workflows │ ├── benchmark.yml │ ├── build_and_test.yml │ ├── build_branch35.yml │ ├── build_branch35_python.yml │ ├── build_branch40.yml │ ├── build_branch40_java21.yml │ ├── build_branch40_maven.yml │ ├── build_branch40_maven_java21.yml │ ├── build_branch40_non_ansi.yml │ ├── build_branch40_python.yml │ ├── build_branch40_python_pypy3.10.yml │ ├── build_branch41.yml │ ├── build_branch41_java21.yml │ ├── build_branch41_maven.yml │ ├── build_branch41_maven_java21.yml │ ├── build_branch41_non_ansi.yml │ ├── build_branch41_python.yml │ ├── build_branch41_python_3.14.yml │ ├── build_branch41_python_pypy3.10.yml │ ├── build_coverage.yml │ ├── build_infra_images_cache.yml │ ├── build_java21.yml │ ├── build_main.yml │ ├── build_maven.yml │ ├── build_maven_java21.yml │ ├── build_maven_java21_arm.yml │ ├── build_maven_java21_macos26.yml │ ├── build_non_ansi.yml │ ├── build_python_3.10.yml │ ├── build_python_3.11_arm.yml │ ├── build_python_3.11_classic_only.yml │ ├── build_python_3.11_macos26.yml │ ├── build_python_3.12.yml │ ├── build_python_3.13.yml │ ├── build_python_3.13_nogil.yml │ ├── build_python_3.14.yml │ ├── build_python_connect.yml │ ├── build_python_connect40.yml │ ├── build_python_minimum.yml │ ├── build_python_numpy_2.1.3.yml │ ├── build_python_ps_minimum.yml │ ├── build_python_pypy3.10.yml │ ├── build_python_pypy3.11.yml │ ├── build_rockdb_as_ui_backend.yml │ ├── build_sparkr_window.yml │ ├── build_uds.yml │ ├── images │ └── workflow-enable-button.png │ ├── labeler.yml │ ├── maven_test.yml │ ├── notify_test_workflow.yml │ ├── pages.yml │ ├── publish_snapshot.yml │ ├── python_hosted_runner_test.yml │ ├── release.yml │ ├── stale.yml │ ├── test_report.yml │ └── update_build_status.yml ├── .gitignore ├── .mvn ├── extensions.xml ├── jvm.config └── maven.config ├── .nojekyll ├── CONTRIBUTING.md ├── LICENSE ├── LICENSE-binary ├── NOTICE ├── NOTICE-binary ├── R ├── .gitignore ├── CRAN_RELEASE.md ├── DOCUMENTATION.md ├── WINDOWS.md ├── check-cran.sh ├── create-docs.sh ├── create-rd.sh ├── find-r.sh ├── install-dev.bat ├── install-dev.sh ├── install-source-package.sh ├── log4j2.properties ├── pkg │ ├── .Rbuildignore │ ├── .gitignore │ ├── .lintr │ ├── DESCRIPTION │ ├── NAMESPACE │ ├── R │ │ ├── DataFrame.R │ │ ├── RDD.R │ │ ├── SQLContext.R │ │ ├── WindowSpec.R │ │ ├── backend.R │ │ ├── broadcast.R │ │ ├── catalog.R │ │ ├── client.R │ │ ├── column.R │ │ ├── context.R │ │ ├── deserialize.R │ │ ├── functions.R │ │ ├── generics.R │ │ ├── group.R │ │ ├── install.R │ │ ├── jobj.R │ │ ├── jvm.R │ │ ├── mllib_classification.R │ │ ├── mllib_clustering.R │ │ ├── mllib_fpm.R │ │ ├── mllib_recommendation.R │ │ ├── mllib_regression.R │ │ ├── mllib_stat.R │ │ ├── mllib_tree.R │ │ ├── mllib_utils.R │ │ ├── pairRDD.R │ │ ├── schema.R │ │ ├── serialize.R │ │ ├── sparkR.R │ │ ├── stats.R │ │ ├── streaming.R │ │ ├── types.R │ │ ├── utils.R │ │ ├── window.R │ │ └── zzz.R │ ├── README.md │ ├── inst │ │ ├── profile │ │ │ ├── general.R │ │ │ └── shell.R │ │ ├── tests │ │ │ └── testthat │ │ │ │ └── test_basic.R │ │ └── worker │ │ │ ├── daemon.R │ │ │ └── worker.R │ ├── pkgdown │ │ ├── _pkgdown_template.yml │ │ └── extra.css │ ├── src-native │ │ ├── Makefile │ │ ├── Makefile.win │ │ └── string_hash_code.c │ ├── tests │ │ ├── fulltests │ │ │ ├── data │ │ │ │ └── test_utils_utf.json │ │ │ ├── jarTest.R │ │ │ ├── packageInAJarTest.R │ │ │ ├── test_Serde.R │ │ │ ├── test_Windows.R │ │ │ ├── test_binaryFile.R │ │ │ ├── test_binary_function.R │ │ │ ├── test_broadcast.R │ │ │ ├── test_client.R │ │ │ ├── test_context.R │ │ │ ├── test_includePackage.R │ │ │ ├── test_jvm_api.R │ │ │ ├── test_mllib_classification.R │ │ │ ├── test_mllib_clustering.R │ │ │ ├── test_mllib_fpm.R │ │ │ ├── test_mllib_recommendation.R │ │ │ ├── test_mllib_regression.R │ │ │ ├── test_mllib_stat.R │ │ │ ├── test_mllib_tree.R │ │ │ ├── test_parallelize_collect.R │ │ │ ├── test_rdd.R │ │ │ ├── test_shuffle.R │ │ │ ├── test_sparkR.R │ │ │ ├── test_sparkSQL.R │ │ │ ├── test_sparkSQL_arrow.R │ │ │ ├── test_sparkSQL_eager.R │ │ │ ├── test_streaming.R │ │ │ ├── test_take.R │ │ │ ├── test_textFile.R │ │ │ └── test_utils.R │ │ └── run-all.R │ └── vignettes │ │ └── sparkr-vignettes.Rmd └── run-tests.sh ├── README.md ├── assembly └── pom.xml ├── bin ├── beeline ├── beeline.cmd ├── docker-image-tool.sh ├── find-spark-home ├── find-spark-home.cmd ├── load-spark-env.cmd ├── load-spark-env.sh ├── pyspark ├── pyspark.cmd ├── pyspark2.cmd ├── run-example ├── run-example.cmd ├── spark-class ├── spark-class.cmd ├── spark-class2.cmd ├── spark-connect-shell ├── spark-pipelines ├── spark-shell ├── spark-shell.cmd ├── spark-shell2.cmd ├── spark-sql ├── spark-sql.cmd ├── spark-sql2.cmd ├── spark-submit ├── spark-submit.cmd ├── spark-submit2.cmd ├── sparkR ├── sparkR.cmd └── sparkR2.cmd ├── binder ├── Dockerfile └── postBuild ├── common ├── kvstore │ ├── pom.xml │ └── src │ │ ├── main │ │ └── java │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── util │ │ │ └── kvstore │ │ │ ├── ArrayWrappers.java │ │ │ ├── InMemoryStore.java │ │ │ ├── KVIndex.java │ │ │ ├── KVStore.java │ │ │ ├── KVStoreIterator.java │ │ │ ├── KVStoreSerializer.java │ │ │ ├── KVStoreView.java │ │ │ ├── KVTypeInfo.java │ │ │ ├── LevelDB.java │ │ │ ├── LevelDBIterator.java │ │ │ ├── LevelDBTypeInfo.java │ │ │ ├── RocksDB.java │ │ │ ├── RocksDBIterator.java │ │ │ ├── RocksDBTypeInfo.java │ │ │ └── UnsupportedStoreVersionException.java │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── util │ │ │ └── kvstore │ │ │ ├── ArrayKeyIndexType.java │ │ │ ├── ArrayWrappersSuite.java │ │ │ ├── CustomType1.java │ │ │ ├── CustomType2.java │ │ │ ├── DBIteratorSuite.java │ │ │ ├── InMemoryIteratorSuite.java │ │ │ ├── InMemoryStoreSuite.java │ │ │ ├── IntKeyType.java │ │ │ ├── LevelDBBenchmark.java │ │ │ ├── LevelDBIteratorSuite.java │ │ │ ├── LevelDBSuite.java │ │ │ ├── LevelDBTypeInfoSuite.java │ │ │ ├── RocksDBIteratorSuite.java │ │ │ ├── RocksDBSuite.java │ │ │ └── RocksDBTypeInfoSuite.java │ │ └── resources │ │ └── log4j2.properties ├── network-common │ ├── pom.xml │ └── src │ │ ├── main │ │ └── java │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── network │ │ │ ├── TransportContext.java │ │ │ ├── buffer │ │ │ ├── FileSegmentManagedBuffer.java │ │ │ ├── ManagedBuffer.java │ │ │ ├── NettyManagedBuffer.java │ │ │ └── NioManagedBuffer.java │ │ │ ├── client │ │ │ ├── BaseResponseCallback.java │ │ │ ├── ChunkFetchFailureException.java │ │ │ ├── ChunkReceivedCallback.java │ │ │ ├── MergedBlockMetaResponseCallback.java │ │ │ ├── RpcResponseCallback.java │ │ │ ├── StreamCallback.java │ │ │ ├── StreamCallbackWithID.java │ │ │ ├── StreamInterceptor.java │ │ │ ├── TransportClient.java │ │ │ ├── TransportClientBootstrap.java │ │ │ ├── TransportClientFactory.java │ │ │ └── TransportResponseHandler.java │ │ │ ├── crypto │ │ │ ├── AuthClientBootstrap.java │ │ │ ├── AuthEngine.java │ │ │ ├── AuthMessage.java │ │ │ ├── AuthRpcHandler.java │ │ │ ├── AuthServerBootstrap.java │ │ │ ├── CtrTransportCipher.java │ │ │ ├── GcmTransportCipher.java │ │ │ ├── README.md │ │ │ ├── TransportCipher.java │ │ │ └── TransportCipherUtil.java │ │ │ ├── protocol │ │ │ ├── AbstractMessage.java │ │ │ ├── AbstractResponseMessage.java │ │ │ ├── ChunkFetchFailure.java │ │ │ ├── ChunkFetchRequest.java │ │ │ ├── ChunkFetchSuccess.java │ │ │ ├── Encodable.java │ │ │ ├── Encoders.java │ │ │ ├── EncryptedMessageWithHeader.java │ │ │ ├── MergedBlockMetaRequest.java │ │ │ ├── MergedBlockMetaSuccess.java │ │ │ ├── Message.java │ │ │ ├── MessageDecoder.java │ │ │ ├── MessageEncoder.java │ │ │ ├── MessageWithHeader.java │ │ │ ├── OneWayMessage.java │ │ │ ├── RequestMessage.java │ │ │ ├── ResponseMessage.java │ │ │ ├── RpcFailure.java │ │ │ ├── RpcRequest.java │ │ │ ├── RpcResponse.java │ │ │ ├── SslMessageEncoder.java │ │ │ ├── StreamChunkId.java │ │ │ ├── StreamFailure.java │ │ │ ├── StreamRequest.java │ │ │ ├── StreamResponse.java │ │ │ └── UploadStream.java │ │ │ ├── sasl │ │ │ ├── SaslClientBootstrap.java │ │ │ ├── SaslEncryption.java │ │ │ ├── SaslEncryptionBackend.java │ │ │ ├── SaslMessage.java │ │ │ ├── SaslRpcHandler.java │ │ │ ├── SaslServerBootstrap.java │ │ │ ├── SaslTimeoutException.java │ │ │ ├── SecretKeyHolder.java │ │ │ ├── SparkSaslClient.java │ │ │ └── SparkSaslServer.java │ │ │ ├── server │ │ │ ├── AbstractAuthRpcHandler.java │ │ │ ├── BlockPushNonFatalFailure.java │ │ │ ├── ChunkFetchRequestHandler.java │ │ │ ├── MessageHandler.java │ │ │ ├── NoOpRpcHandler.java │ │ │ ├── OneForOneStreamManager.java │ │ │ ├── RpcHandler.java │ │ │ ├── StreamManager.java │ │ │ ├── TransportChannelHandler.java │ │ │ ├── TransportRequestHandler.java │ │ │ ├── TransportServer.java │ │ │ └── TransportServerBootstrap.java │ │ │ ├── shuffledb │ │ │ ├── DB.java │ │ │ ├── DBBackend.java │ │ │ ├── DBIterator.java │ │ │ ├── LevelDB.java │ │ │ ├── LevelDBIterator.java │ │ │ ├── RocksDB.java │ │ │ ├── RocksDBIterator.java │ │ │ └── StoreVersion.java │ │ │ ├── ssl │ │ │ ├── ReloadingX509TrustManager.java │ │ │ └── SSLFactory.java │ │ │ └── util │ │ │ ├── AbstractFileRegion.java │ │ │ ├── ByteArrayReadableChannel.java │ │ │ ├── ByteArrayWritableChannel.java │ │ │ ├── ByteBufferWriteableChannel.java │ │ │ ├── ConfigProvider.java │ │ │ ├── CryptoUtils.java │ │ │ ├── DBProvider.java │ │ │ ├── IOMode.java │ │ │ ├── LevelDBProvider.java │ │ │ ├── LimitedInputStream.java │ │ │ ├── MapConfigProvider.java │ │ │ ├── NettyLogger.java │ │ │ ├── NettyMemoryMetrics.java │ │ │ ├── NettyUtils.java │ │ │ ├── RocksDBProvider.java │ │ │ ├── TimerWithCustomTimeUnit.java │ │ │ ├── TransportConf.java │ │ │ └── TransportFrameDecoder.java │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── network │ │ │ ├── ChunkFetchIntegrationSuite.java │ │ │ ├── ChunkFetchRequestHandlerSuite.java │ │ │ ├── ExtendedChannelPromise.java │ │ │ ├── ProtocolSuite.java │ │ │ ├── RequestTimeoutIntegrationSuite.java │ │ │ ├── RpcIntegrationSuite.java │ │ │ ├── SslChunkFetchIntegrationSuite.java │ │ │ ├── StreamSuite.java │ │ │ ├── StreamTestHelper.java │ │ │ ├── TestManagedBuffer.java │ │ │ ├── TestUtils.java │ │ │ ├── TransportConfSuite.java │ │ │ ├── TransportRequestHandlerSuite.java │ │ │ ├── TransportResponseHandlerSuite.java │ │ │ ├── client │ │ │ ├── SslTransportClientFactorySuite.java │ │ │ └── TransportClientFactorySuite.java │ │ │ ├── crypto │ │ │ ├── AuthEngineSuite.java │ │ │ ├── AuthIntegrationSuite.java │ │ │ ├── AuthMessagesSuite.java │ │ │ ├── CtrAuthEngineSuite.java │ │ │ ├── GcmAuthEngineSuite.java │ │ │ └── TransportCipherSuite.java │ │ │ ├── protocol │ │ │ ├── EncodersSuite.java │ │ │ ├── EncryptedMessageWithHeaderSuite.java │ │ │ ├── MergedBlockMetaSuccessSuite.java │ │ │ └── MessageWithHeaderSuite.java │ │ │ ├── sasl │ │ │ └── SparkSaslSuite.java │ │ │ ├── server │ │ │ └── OneForOneStreamManagerSuite.java │ │ │ ├── ssl │ │ │ ├── ReloadingX509TrustManagerSuite.java │ │ │ ├── SSLFactorySuite.java │ │ │ └── SslSampleConfigs.java │ │ │ └── util │ │ │ ├── CryptoUtilsSuite.java │ │ │ ├── DBProviderSuite.java │ │ │ ├── JavaUtilsSuite.java │ │ │ ├── NettyMemoryMetricsSuite.java │ │ │ ├── TimerWithCustomUnitSuite.java │ │ │ └── TransportFrameDecoderSuite.java │ │ └── resources │ │ ├── certchain.pem │ │ ├── key.pem │ │ ├── keystore │ │ ├── log4j2.properties │ │ ├── truststore │ │ ├── unencrypted-certchain.pem │ │ ├── unencrypted-key.pem │ │ └── untrusted-keystore ├── network-shuffle │ ├── pom.xml │ └── src │ │ ├── main │ │ └── java │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── network │ │ │ ├── sasl │ │ │ └── ShuffleSecretManager.java │ │ │ └── shuffle │ │ │ ├── AppsWithRecoveryDisabled.java │ │ │ ├── BlockFetchingListener.java │ │ │ ├── BlockPushingListener.java │ │ │ ├── BlockStoreClient.java │ │ │ ├── BlockTransferListener.java │ │ │ ├── Constants.java │ │ │ ├── DownloadFile.java │ │ │ ├── DownloadFileManager.java │ │ │ ├── DownloadFileWritableChannel.java │ │ │ ├── ErrorHandler.java │ │ │ ├── ExecutorDiskUtils.java │ │ │ ├── ExternalBlockHandler.java │ │ │ ├── ExternalBlockStoreClient.java │ │ │ ├── ExternalShuffleBlockResolver.java │ │ │ ├── MergeFinalizerListener.java │ │ │ ├── MergedBlockMeta.java │ │ │ ├── MergedBlocksMetaListener.java │ │ │ ├── MergedShuffleFileManager.java │ │ │ ├── NoOpMergedShuffleFileManager.java │ │ │ ├── OneForOneBlockFetcher.java │ │ │ ├── OneForOneBlockPusher.java │ │ │ ├── RemoteBlockPushResolver.java │ │ │ ├── RetryingBlockTransferor.java │ │ │ ├── ShuffleIndexInformation.java │ │ │ ├── ShuffleIndexRecord.java │ │ │ ├── ShuffleTransportContext.java │ │ │ ├── SimpleDownloadFile.java │ │ │ ├── checksum │ │ │ ├── Cause.java │ │ │ └── ShuffleChecksumHelper.java │ │ │ └── protocol │ │ │ ├── AbstractFetchShuffleBlocks.java │ │ │ ├── BlockPushReturnCode.java │ │ │ ├── BlockTransferMessage.java │ │ │ ├── BlocksRemoved.java │ │ │ ├── CorruptionCause.java │ │ │ ├── DiagnoseCorruption.java │ │ │ ├── ExecutorShuffleInfo.java │ │ │ ├── FetchShuffleBlockChunks.java │ │ │ ├── FetchShuffleBlocks.java │ │ │ ├── FinalizeShuffleMerge.java │ │ │ ├── GetLocalDirsForExecutors.java │ │ │ ├── LocalDirsForExecutors.java │ │ │ ├── MergeStatuses.java │ │ │ ├── OpenBlocks.java │ │ │ ├── PushBlockStream.java │ │ │ ├── RegisterExecutor.java │ │ │ ├── RemoveBlocks.java │ │ │ ├── RemoveShuffleMerge.java │ │ │ ├── StreamHandle.java │ │ │ ├── UploadBlock.java │ │ │ └── UploadBlockStream.java │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── network │ │ │ ├── sasl │ │ │ ├── SaslIntegrationSuite.java │ │ │ └── ShuffleSecretManagerSuite.java │ │ │ └── shuffle │ │ │ ├── AppIsolationSuite.java │ │ │ ├── BlockTransferMessagesSuite.java │ │ │ ├── CleanupNonShuffleServiceServedFilesSuite.java │ │ │ ├── ErrorHandlerSuite.java │ │ │ ├── ExternalBlockHandlerSuite.java │ │ │ ├── ExternalShuffleBlockResolverSuite.java │ │ │ ├── ExternalShuffleCleanupSuite.java │ │ │ ├── ExternalShuffleIntegrationSuite.java │ │ │ ├── ExternalShuffleSecuritySuite.java │ │ │ ├── OneForOneBlockFetcherSuite.java │ │ │ ├── OneForOneBlockPusherSuite.java │ │ │ ├── RemoteBlockPushResolverSuite.java │ │ │ ├── RetryingBlockTransferorSuite.java │ │ │ ├── ShuffleIndexInformationSuite.java │ │ │ ├── ShuffleTransportContextSuite.java │ │ │ ├── SimpleDownloadFileSuite.java │ │ │ ├── SslExternalShuffleIntegrationSuite.java │ │ │ ├── SslExternalShuffleSecuritySuite.java │ │ │ ├── SslShuffleTransportContextSuite.java │ │ │ ├── TestShuffleDataContext.java │ │ │ └── protocol │ │ │ ├── FetchShuffleBlockChunksSuite.java │ │ │ └── FetchShuffleBlocksSuite.java │ │ └── resources │ │ ├── certchain.pem │ │ ├── key.pem │ │ ├── keystore │ │ ├── log4j2.properties │ │ ├── truststore │ │ ├── unencrypted-certchain.pem │ │ ├── unencrypted-key.pem │ │ └── untrusted-keystore ├── network-yarn │ ├── pom.xml │ └── src │ │ └── main │ │ └── java │ │ └── org │ │ └── apache │ │ └── spark │ │ └── network │ │ └── yarn │ │ ├── YarnShuffleService.java │ │ ├── YarnShuffleServiceMetrics.java │ │ └── util │ │ └── HadoopConfigProvider.java ├── sketch │ ├── pom.xml │ └── src │ │ ├── main │ │ └── java │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── util │ │ │ └── sketch │ │ │ ├── BitArray.java │ │ │ ├── BloomFilter.java │ │ │ ├── BloomFilterBase.java │ │ │ ├── BloomFilterImpl.java │ │ │ ├── BloomFilterImplV2.java │ │ │ ├── CountMinSketch.java │ │ │ ├── CountMinSketchImpl.java │ │ │ ├── IncompatibleMergeException.java │ │ │ ├── Murmur3_x86_32.java │ │ │ ├── Platform.java │ │ │ └── Utils.java │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── util │ │ │ └── sketch │ │ │ └── SparkBloomFilterSuite.java │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── util │ │ └── sketch │ │ ├── BitArraySuite.scala │ │ ├── BloomFilterSuite.scala │ │ └── CountMinSketchSuite.scala ├── tags │ ├── README.md │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── annotation │ │ │ │ ├── AlphaComponent.java │ │ │ │ ├── ClassicOnly.java │ │ │ │ ├── DeveloperApi.java │ │ │ │ ├── Evolving.java │ │ │ │ ├── Experimental.java │ │ │ │ ├── Private.java │ │ │ │ ├── Stable.java │ │ │ │ └── Unstable.java │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── annotation │ │ │ ├── Since.scala │ │ │ ├── package-info.java │ │ │ └── package.scala │ │ └── test │ │ └── java │ │ └── org │ │ └── apache │ │ └── spark │ │ └── tags │ │ ├── AmmoniteTest.java │ │ ├── ChromeUITest.java │ │ ├── DockerTest.java │ │ ├── ExtendedHiveTest.java │ │ ├── ExtendedLevelDBTest.java │ │ ├── ExtendedSQLTest.java │ │ ├── ExtendedYarnTest.java │ │ ├── SlowHiveTest.java │ │ ├── SlowSQLTest.java │ │ └── WebBrowserTest.java ├── unsafe │ ├── pom.xml │ └── src │ │ ├── main │ │ └── java │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── sql │ │ │ └── catalyst │ │ │ │ ├── expressions │ │ │ │ └── HiveHasher.java │ │ │ │ └── util │ │ │ │ ├── CollationAwareUTF8String.java │ │ │ │ ├── CollationFactory.java │ │ │ │ ├── CollationNames.java │ │ │ │ ├── CollationSupport.java │ │ │ │ ├── DateTimeConstants.java │ │ │ │ └── SpecialCodePointConstants.java │ │ │ └── unsafe │ │ │ ├── KVIterator.java │ │ │ ├── Platform.java │ │ │ ├── UTF8StringBuilder.java │ │ │ ├── UnsafeAlignedOffset.java │ │ │ ├── array │ │ │ ├── ByteArrayMethods.java │ │ │ └── LongArray.java │ │ │ ├── bitset │ │ │ └── BitSetMethods.java │ │ │ ├── hash │ │ │ └── Murmur3_x86_32.java │ │ │ ├── memory │ │ │ ├── HeapMemoryAllocator.java │ │ │ ├── MemoryAllocator.java │ │ │ ├── MemoryBlock.java │ │ │ ├── MemoryLocation.java │ │ │ └── UnsafeMemoryAllocator.java │ │ │ └── types │ │ │ ├── ByteArray.java │ │ │ ├── CalendarInterval.java │ │ │ ├── GeographyVal.java │ │ │ ├── GeometryVal.java │ │ │ ├── UTF8String.java │ │ │ └── VariantVal.java │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── unsafe │ │ │ ├── PlatformUtilSuite.java │ │ │ ├── array │ │ │ ├── ByteArraySuite.java │ │ │ └── LongArraySuite.java │ │ │ ├── hash │ │ │ └── Murmur3_x86_32Suite.java │ │ │ └── types │ │ │ ├── CalendarIntervalSuite.java │ │ │ ├── CollationSupportSuite.java │ │ │ ├── GeographyValSuite.java │ │ │ ├── GeometryValSuite.java │ │ │ └── UTF8StringSuite.java │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── unsafe │ │ └── types │ │ ├── CollationFactorySuite.scala │ │ └── UTF8StringPropertyCheckSuite.scala ├── utils-java │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ ├── QueryContext.java │ │ │ │ ├── QueryContextType.java │ │ │ │ ├── api │ │ │ │ └── java │ │ │ │ │ └── function │ │ │ │ │ ├── CoGroupFunction.java │ │ │ │ │ ├── DoubleFlatMapFunction.java │ │ │ │ │ ├── DoubleFunction.java │ │ │ │ │ ├── FilterFunction.java │ │ │ │ │ ├── FlatMapFunction.java │ │ │ │ │ ├── FlatMapFunction2.java │ │ │ │ │ ├── FlatMapGroupsFunction.java │ │ │ │ │ ├── ForeachFunction.java │ │ │ │ │ ├── ForeachPartitionFunction.java │ │ │ │ │ ├── Function.java │ │ │ │ │ ├── Function0.java │ │ │ │ │ ├── Function2.java │ │ │ │ │ ├── Function3.java │ │ │ │ │ ├── Function4.java │ │ │ │ │ ├── MapFunction.java │ │ │ │ │ ├── MapGroupsFunction.java │ │ │ │ │ ├── MapPartitionsFunction.java │ │ │ │ │ ├── PairFlatMapFunction.java │ │ │ │ │ ├── PairFunction.java │ │ │ │ │ ├── ReduceFunction.java │ │ │ │ │ ├── VoidFunction.java │ │ │ │ │ ├── VoidFunction2.java │ │ │ │ │ └── package-info.java │ │ │ │ ├── internal │ │ │ │ ├── LogKey.java │ │ │ │ ├── LogKeys.java │ │ │ │ ├── MDC.java │ │ │ │ ├── SparkLogger.java │ │ │ │ └── SparkLoggerFactory.java │ │ │ │ ├── memory │ │ │ │ └── MemoryMode.java │ │ │ │ ├── network │ │ │ │ └── util │ │ │ │ │ ├── ByteUnit.java │ │ │ │ │ └── JavaUtils.java │ │ │ │ ├── unsafe │ │ │ │ └── array │ │ │ │ │ └── ByteArrayUtils.java │ │ │ │ └── util │ │ │ │ └── Pair.java │ │ └── resources │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── SparkLayout.json │ │ │ ├── log4j2-defaults.properties │ │ │ └── log4j2-json-layout.properties │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── util │ │ │ ├── CustomLogKeys.java │ │ │ ├── PatternSparkLoggerSuite.java │ │ │ ├── SparkLoggerSuiteBase.java │ │ │ └── StructuredSparkLoggerSuite.java │ │ └── resources │ │ └── log4j2.properties ├── utils │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ ├── SparkThrowable.java │ │ │ │ └── storage │ │ │ │ └── StorageLevelMapper.java │ │ ├── resources │ │ │ └── error │ │ │ │ ├── README.md │ │ │ │ ├── error-classes.json │ │ │ │ ├── error-conditions.json │ │ │ │ └── error-states.json │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── ErrorClassesJSONReader.scala │ │ │ ├── SparkBuildInfo.scala │ │ │ ├── SparkException.scala │ │ │ ├── SparkThrowableHelper.scala │ │ │ ├── StringSubstitutor.scala │ │ │ ├── api │ │ │ └── java │ │ │ │ └── function │ │ │ │ └── package.scala │ │ │ ├── internal │ │ │ ├── Logging.scala │ │ │ └── config │ │ │ │ ├── ConfigBuilder.scala │ │ │ │ ├── ConfigEntry.scala │ │ │ │ ├── ConfigProvider.scala │ │ │ │ └── ConfigReader.scala │ │ │ ├── scheduler │ │ │ └── SparkListenerEvent.scala │ │ │ ├── sql │ │ │ └── streaming │ │ │ │ └── StreamingQueryException.scala │ │ │ ├── storage │ │ │ └── StorageLevel.scala │ │ │ └── util │ │ │ ├── ArrayImplicits.scala │ │ │ ├── ClosureCleaner.scala │ │ │ ├── CompletionIterator.scala │ │ │ ├── JsonUtils.scala │ │ │ ├── LexicalThreadLocal.scala │ │ │ ├── LogUtils.scala │ │ │ ├── MavenUtils.scala │ │ │ ├── SparkClassUtils.scala │ │ │ ├── SparkCollectionUtils.scala │ │ │ ├── SparkEnvUtils.scala │ │ │ ├── SparkErrorUtils.scala │ │ │ ├── SparkFatalException.scala │ │ │ ├── SparkFileUtils.scala │ │ │ ├── SparkSchemaUtils.scala │ │ │ ├── SparkSerDeUtils.scala │ │ │ ├── SparkStreamUtils.scala │ │ │ ├── SparkStringUtils.scala │ │ │ ├── SparkSystemUtils.scala │ │ │ ├── SparkTestUtils.scala │ │ │ ├── SparkThreadUtils.scala │ │ │ └── VersionUtils.scala │ │ └── test │ │ ├── resources │ │ └── log4j2.properties │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── util │ │ ├── IvyTestUtils.scala │ │ ├── LogKeysSuite.scala │ │ ├── LogThrottlingSuite.scala │ │ ├── MDCSuite.scala │ │ ├── MavenUtilsSuite.scala │ │ ├── MaybeNull.scala │ │ ├── PatternLoggingSuite.scala │ │ ├── SparkErrorUtilsSuite.scala │ │ ├── StructuredLoggingSuite.scala │ │ └── VersionUtilsSuite.scala └── variant │ ├── README.md │ ├── pom.xml │ └── src │ └── main │ └── java │ └── org │ └── apache │ └── spark │ └── types │ └── variant │ ├── ShreddingUtils.java │ ├── Variant.java │ ├── VariantBuilder.java │ ├── VariantSchema.java │ ├── VariantShreddingWriter.java │ ├── VariantSizeLimitException.java │ └── VariantUtil.java ├── conf ├── fairscheduler.xml.template ├── log4j2-json-layout.properties.template ├── log4j2.properties.template ├── metrics.properties.template ├── spark-defaults.conf.template ├── spark-env.sh.template └── workers.template ├── connector ├── avro │ ├── benchmarks │ │ ├── AvroReadBenchmark-jdk21-results.txt │ │ ├── AvroReadBenchmark-results.txt │ │ ├── AvroWriteBenchmark-jdk21-results.txt │ │ └── AvroWriteBenchmark-results.txt │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── resources │ │ │ └── META-INF │ │ │ │ └── services │ │ │ │ └── org.apache.spark.sql.sources.DataSourceRegister │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ ├── avro │ │ │ ├── AvroDataToCatalyst.scala │ │ │ ├── AvroExpressionEvalUtils.scala │ │ │ ├── CatalystDataToAvro.scala │ │ │ ├── SchemaOfAvro.scala │ │ │ └── package.scala │ │ │ └── v2 │ │ │ └── avro │ │ │ ├── AvroDataSourceV2.scala │ │ │ ├── AvroPartitionReaderFactory.scala │ │ │ ├── AvroScan.scala │ │ │ ├── AvroScanBuilder.scala │ │ │ ├── AvroTable.scala │ │ │ └── AvroWrite.scala │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── avro │ │ │ └── JavaAvroFunctionsSuite.java │ │ ├── resources │ │ ├── before_1582_date_v2_4_5.avro │ │ ├── before_1582_date_v2_4_6.avro │ │ ├── before_1582_date_v3_2_0.avro │ │ ├── before_1582_timestamp_micros_v2_4_5.avro │ │ ├── before_1582_timestamp_micros_v2_4_6.avro │ │ ├── before_1582_timestamp_micros_v3_2_0.avro │ │ ├── before_1582_timestamp_millis_v2_4_5.avro │ │ ├── before_1582_timestamp_millis_v2_4_6.avro │ │ ├── before_1582_timestamp_millis_v3_2_0.avro │ │ ├── empty_blocks.avro │ │ ├── empty_file.avro │ │ ├── episodes.avro │ │ ├── log4j2.properties │ │ ├── test-random-partitioned │ │ │ ├── part-r-00000.avro │ │ │ ├── part-r-00001.avro │ │ │ ├── part-r-00002.avro │ │ │ ├── part-r-00003.avro │ │ │ ├── part-r-00004.avro │ │ │ ├── part-r-00005.avro │ │ │ ├── part-r-00006.avro │ │ │ ├── part-r-00007.avro │ │ │ ├── part-r-00008.avro │ │ │ ├── part-r-00009.avro │ │ │ └── part-r-00010.avro │ │ ├── test.avro │ │ ├── test.avsc │ │ ├── test.json │ │ └── test_sub.avsc │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ ├── avro │ │ ├── AvroCatalystDataConversionSuite.scala │ │ ├── AvroCodecSuite.scala │ │ ├── AvroFunctionsSuite.scala │ │ ├── AvroLogicalTypeInitSuite.scala │ │ ├── AvroLogicalTypeSuite.scala │ │ ├── AvroRowReaderSuite.scala │ │ ├── AvroScanSuite.scala │ │ ├── AvroSchemaHelperSuite.scala │ │ ├── AvroSerdeSuite.scala │ │ ├── AvroSuite.scala │ │ └── DeprecatedAvroFunctionsSuite.scala │ │ └── execution │ │ ├── benchmark │ │ ├── AvroReadBenchmark.scala │ │ └── AvroWriteBenchmark.scala │ │ └── datasources │ │ └── AvroReadSchemaSuite.scala ├── docker-integration-tests │ ├── README.md │ ├── pom.xml │ └── src │ │ └── test │ │ ├── resources │ │ ├── db2-krb-setup.sh │ │ ├── log4j2.properties │ │ ├── mariadb-docker-entrypoint.sh │ │ ├── mariadb-krb-setup.sh │ │ └── postgres-krb-setup.sh │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── sql │ │ └── jdbc │ │ │ ├── DB2DatabaseOnDocker.scala │ │ │ ├── DB2IntegrationSuite.scala │ │ │ ├── DB2KrbIntegrationSuite.scala │ │ │ ├── DockerIntegrationFunSuite.scala │ │ │ ├── DockerJDBCIntegrationSuite.scala │ │ │ ├── DockerKrbJDBCIntegrationSuite.scala │ │ │ ├── MariaDBDatabaseOnDocker.scala │ │ │ ├── MariaDBKrbIntegrationSuite.scala │ │ │ ├── MsSQLServerDatabaseOnDocker.scala │ │ │ ├── MsSqlServerIntegrationSuite.scala │ │ │ ├── MySQLDatabaseOnDocker.scala │ │ │ ├── MySQLIntegrationSuite.scala │ │ │ ├── OracleDatabaseOnDocker.scala │ │ │ ├── OracleIntegrationSuite.scala │ │ │ ├── PostgresDatabaseOnDocker.scala │ │ │ ├── PostgresIntegrationSuite.scala │ │ │ ├── PostgresKrbIntegrationSuite.scala │ │ │ ├── SharedJDBCIntegrationSuite.scala │ │ │ ├── querytest │ │ │ ├── CrossDbmsQueryTestSuite.scala │ │ │ ├── GeneratedSubquerySuite.scala │ │ │ └── PostgresSQLQueryTestSuite.scala │ │ │ └── v2 │ │ │ ├── DB2IntegrationSuite.scala │ │ │ ├── DB2NamespaceSuite.scala │ │ │ ├── DockerJDBCIntegrationV2Suite.scala │ │ │ ├── MsSqlServerIntegrationSuite.scala │ │ │ ├── MsSqlServerNamespaceSuite.scala │ │ │ ├── MySQLIntegrationSuite.scala │ │ │ ├── MySQLNamespaceSuite.scala │ │ │ ├── OracleIntegrationSuite.scala │ │ │ ├── OracleNamespaceSuite.scala │ │ │ ├── PostgresIntegrationSuite.scala │ │ │ ├── PostgresNamespaceSuite.scala │ │ │ ├── V2JDBCNamespaceTest.scala │ │ │ ├── V2JDBCTest.scala │ │ │ └── join │ │ │ ├── MsSqlServerJoinPushdownIntegrationSuite.scala │ │ │ ├── MySQLJoinPushdownIntegrationSuite.scala │ │ │ ├── OracleJoinPushdownIntegrationSuite.scala │ │ │ └── PostgresJoinPushdownIntegrationSuite.scala │ │ └── util │ │ └── DockerUtils.scala ├── kafka-0-10-assembly │ └── pom.xml ├── kafka-0-10-sql │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── resources │ │ │ ├── META-INF │ │ │ │ └── services │ │ │ │ │ └── org.apache.spark.sql.sources.DataSourceRegister │ │ │ └── error │ │ │ │ └── kafka-error-conditions.json │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── kafka010 │ │ │ ├── ConsumerStrategy.scala │ │ │ ├── JsonUtils.scala │ │ │ ├── KafkaBatch.scala │ │ │ ├── KafkaBatchPartitionReader.scala │ │ │ ├── KafkaBatchWrite.scala │ │ │ ├── KafkaContinuousStream.scala │ │ │ ├── KafkaDataWriter.scala │ │ │ ├── KafkaExceptions.scala │ │ │ ├── KafkaMicroBatchStream.scala │ │ │ ├── KafkaOffsetRangeCalculator.scala │ │ │ ├── KafkaOffsetRangeLimit.scala │ │ │ ├── KafkaOffsetReader.scala │ │ │ ├── KafkaOffsetReaderAdmin.scala │ │ │ ├── KafkaOffsetReaderConsumer.scala │ │ │ ├── KafkaRecordToRowConverter.scala │ │ │ ├── KafkaRelation.scala │ │ │ ├── KafkaSink.scala │ │ │ ├── KafkaSource.scala │ │ │ ├── KafkaSourceInitialOffsetWriter.scala │ │ │ ├── KafkaSourceOffset.scala │ │ │ ├── KafkaSourceProvider.scala │ │ │ ├── KafkaSourceRDD.scala │ │ │ ├── KafkaStreamingWrite.scala │ │ │ ├── KafkaWrite.scala │ │ │ ├── KafkaWriteTask.scala │ │ │ ├── KafkaWriter.scala │ │ │ ├── consumer │ │ │ ├── FetchedDataPool.scala │ │ │ ├── InternalKafkaConsumerPool.scala │ │ │ └── KafkaDataConsumer.scala │ │ │ ├── package-info.java │ │ │ ├── package.scala │ │ │ └── producer │ │ │ ├── CachedKafkaProducer.scala │ │ │ └── InternalKafkaProducerPool.scala │ │ └── test │ │ ├── resources │ │ ├── kafka-source-initial-offset-future-version.bin │ │ ├── kafka-source-initial-offset-version-2.1.0.bin │ │ ├── kafka-source-offset-version-2.1.0.txt │ │ ├── log4j2.properties │ │ └── structured-streaming │ │ │ └── checkpoint-version-2.4.3-kafka-include-headers-default │ │ │ ├── commits │ │ │ └── 0 │ │ │ ├── metadata │ │ │ ├── offsets │ │ │ └── 0 │ │ │ ├── sources │ │ │ └── 0 │ │ │ │ └── 0 │ │ │ └── state │ │ │ └── 0 │ │ │ ├── 0 │ │ │ └── 1.delta │ │ │ ├── 1 │ │ │ └── 1.delta │ │ │ ├── 2 │ │ │ └── 1.delta │ │ │ ├── 3 │ │ │ └── 1.delta │ │ │ └── 4 │ │ │ └── 1.delta │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ └── kafka010 │ │ ├── ConsumerStrategySuite.scala │ │ ├── JsonUtilsSuite.scala │ │ ├── KafkaContinuousSourceSuite.scala │ │ ├── KafkaContinuousTest.scala │ │ ├── KafkaDelegationTokenSuite.scala │ │ ├── KafkaDontFailOnDataLossSuite.scala │ │ ├── KafkaMicroBatchSourceSuite.scala │ │ ├── KafkaOffsetRangeCalculatorSuite.scala │ │ ├── KafkaOffsetReaderSuite.scala │ │ ├── KafkaRealTimeIntegrationSuite.scala │ │ ├── KafkaRealTimeModeSuite.scala │ │ ├── KafkaRelationSuite.scala │ │ ├── KafkaSinkSuite.scala │ │ ├── KafkaSourceOffsetSuite.scala │ │ ├── KafkaSourceProviderSuite.scala │ │ ├── KafkaSparkConfSuite.scala │ │ ├── KafkaTest.scala │ │ ├── KafkaTestUtils.scala │ │ ├── RecordBuilder.scala │ │ ├── consumer │ │ ├── FetchedDataPoolSuite.scala │ │ ├── InternalKafkaConsumerPoolSuite.scala │ │ └── KafkaDataConsumerSuite.scala │ │ └── producer │ │ └── InternalKafkaProducerPoolSuite.scala ├── kafka-0-10-token-provider │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── resources │ │ │ ├── META-INF │ │ │ │ └── services │ │ │ │ │ └── org.apache.spark.security.HadoopDelegationTokenProvider │ │ │ └── error │ │ │ │ └── kafka-token-provider-error-conditions.json │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── kafka010 │ │ │ ├── KafkaConfigUpdater.scala │ │ │ ├── KafkaDelegationTokenProvider.scala │ │ │ ├── KafkaRedactionUtil.scala │ │ │ ├── KafkaTokenProviderException.scala │ │ │ ├── KafkaTokenSparkConf.scala │ │ │ └── KafkaTokenUtil.scala │ │ └── test │ │ ├── resources │ │ └── log4j2.properties │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── kafka010 │ │ ├── KafkaConfigUpdaterSuite.scala │ │ ├── KafkaDelegationTokenTest.scala │ │ ├── KafkaHadoopDelegationTokenManagerSuite.scala │ │ ├── KafkaRedactionUtilSuite.scala │ │ ├── KafkaTokenSparkConfSuite.scala │ │ └── KafkaTokenUtilSuite.scala ├── kafka-0-10 │ ├── pom.xml │ └── src │ │ ├── main │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── streaming │ │ │ └── kafka010 │ │ │ ├── ConsumerStrategy.scala │ │ │ ├── DirectKafkaInputDStream.scala │ │ │ ├── KafkaDataConsumer.scala │ │ │ ├── KafkaRDD.scala │ │ │ ├── KafkaRDDPartition.scala │ │ │ ├── KafkaUtils.scala │ │ │ ├── LocationStrategy.scala │ │ │ ├── OffsetRange.scala │ │ │ ├── PerPartitionConfig.scala │ │ │ ├── package-info.java │ │ │ └── package.scala │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── streaming │ │ │ └── kafka010 │ │ │ ├── JavaConsumerStrategySuite.java │ │ │ ├── JavaDirectKafkaStreamSuite.java │ │ │ ├── JavaKafkaRDDSuite.java │ │ │ └── JavaLocationStrategySuite.java │ │ ├── resources │ │ └── log4j2.properties │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── streaming │ │ └── kafka010 │ │ ├── DirectKafkaStreamSuite.scala │ │ ├── KafkaDataConsumerSuite.scala │ │ ├── KafkaRDDSuite.scala │ │ ├── KafkaTestUtils.scala │ │ └── mocks │ │ ├── MockScheduler.scala │ │ └── MockTime.scala ├── kinesis-asl-assembly │ └── pom.xml ├── kinesis-asl │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ ├── examples │ │ │ │ └── streaming │ │ │ │ │ └── JavaKinesisWordCountASL.java │ │ │ │ └── streaming │ │ │ │ └── kinesis │ │ │ │ └── KinesisInitialPositions.java │ │ ├── python │ │ │ └── examples │ │ │ │ └── streaming │ │ │ │ └── kinesis_wordcount_asl.py │ │ ├── resources │ │ │ └── log4j2.properties │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── examples │ │ │ └── streaming │ │ │ │ ├── KinesisExampleUtils.scala │ │ │ │ └── KinesisWordCountASL.scala │ │ │ └── streaming │ │ │ └── kinesis │ │ │ ├── KinesisBackedBlockRDD.scala │ │ │ ├── KinesisCheckpointer.scala │ │ │ ├── KinesisInputDStream.scala │ │ │ ├── KinesisReadConfigurations.scala │ │ │ ├── KinesisReceiver.scala │ │ │ ├── KinesisRecordProcessor.scala │ │ │ ├── KinesisUtilsPythonHelper.scala │ │ │ └── SparkAWSCredentials.scala │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── streaming │ │ │ └── kinesis │ │ │ └── JavaKinesisInputDStreamBuilderSuite.java │ │ ├── resources │ │ └── log4j2.properties │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── streaming │ │ └── kinesis │ │ ├── KPLBasedKinesisTestUtils.scala │ │ ├── KinesisBackedBlockRDDSuite.scala │ │ ├── KinesisCheckpointerSuite.scala │ │ ├── KinesisFunSuite.scala │ │ ├── KinesisInputDStreamBuilderSuite.scala │ │ ├── KinesisReceiverSuite.scala │ │ ├── KinesisStreamSuite.scala │ │ ├── KinesisTestUtils.scala │ │ └── SparkAWSCredentialsBuilderSuite.scala ├── profiler │ ├── README.md │ ├── pom.xml │ └── src │ │ └── main │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── profiler │ │ ├── ProfilerPlugin.scala │ │ ├── SparkAsyncProfiler.scala │ │ └── package.scala ├── protobuf │ ├── README.md │ ├── pom.xml │ └── src │ │ ├── main │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── protobuf │ │ │ ├── CatalystDataToProtobuf.scala │ │ │ ├── ProtobufDataToCatalyst.scala │ │ │ ├── ProtobufDeserializer.scala │ │ │ ├── ProtobufSerializer.scala │ │ │ ├── package.scala │ │ │ └── utils │ │ │ ├── ProtobufOptions.scala │ │ │ ├── ProtobufUtils.scala │ │ │ └── SchemaConverters.scala │ │ └── test │ │ ├── resources │ │ ├── log4j2.properties │ │ └── protobuf │ │ │ ├── basicmessage.proto │ │ │ ├── catalyst_types.proto │ │ │ ├── duration.proto │ │ │ ├── functions_suite.proto │ │ │ ├── nestedenum.proto │ │ │ ├── proto2_messages.proto │ │ │ ├── pyspark_test.proto │ │ │ ├── serde_suite.proto │ │ │ └── timestamp.proto │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ └── protobuf │ │ ├── ProtobufCatalystDataConversionSuite.scala │ │ ├── ProtobufFunctionsSuite.scala │ │ ├── ProtobufSerdeSuite.scala │ │ └── ProtobufTestBase.scala └── spark-ganglia-lgpl │ ├── pom.xml │ └── src │ └── main │ ├── java │ └── com │ │ └── codahale │ │ └── metrics │ │ └── ganglia │ │ └── GangliaReporter.java │ └── scala │ └── org │ └── apache │ └── spark │ └── metrics │ └── sink │ └── GangliaSink.scala ├── core ├── benchmarks │ ├── ChecksumBenchmark-jdk21-results.txt │ ├── ChecksumBenchmark-results.txt │ ├── CoalescedRDDBenchmark-jdk21-results.txt │ ├── CoalescedRDDBenchmark-results.txt │ ├── KryoBenchmark-jdk21-results.txt │ ├── KryoBenchmark-results.txt │ ├── KryoIteratorBenchmark-jdk21-results.txt │ ├── KryoIteratorBenchmark-results.txt │ ├── KryoSerializerBenchmark-jdk21-results.txt │ ├── KryoSerializerBenchmark-results.txt │ ├── LZFBenchmark-jdk21-results.txt │ ├── LZFBenchmark-results.txt │ ├── MapStatusesConvertBenchmark-jdk21-results.txt │ ├── MapStatusesConvertBenchmark-results.txt │ ├── MapStatusesSerDeserBenchmark-jdk21-results.txt │ ├── MapStatusesSerDeserBenchmark-results.txt │ ├── PercentileHeapBenchmark-jdk21-results.txt │ ├── PercentileHeapBenchmark-results.txt │ ├── PersistenceEngineBenchmark-jdk21-results.txt │ ├── PersistenceEngineBenchmark-results.txt │ ├── PropertiesCloneBenchmark-jdk21-results.txt │ ├── PropertiesCloneBenchmark-results.txt │ ├── RocksDBBenchmark-jdk21-results.txt │ ├── RocksDBBenchmark-results.txt │ ├── SorterBenchmark-jdk21-results.txt │ ├── SorterBenchmark-results.txt │ ├── XORShiftRandomBenchmark-jdk21-results.txt │ ├── XORShiftRandomBenchmark-results.txt │ ├── ZStandardBenchmark-jdk21-results.txt │ ├── ZStandardBenchmark-results.txt │ ├── ZStandardTPCDSDataBenchmark-jdk21-results.txt │ └── ZStandardTPCDSDataBenchmark-results.txt ├── pom.xml └── src │ ├── main │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── JobExecutionStatus.java │ │ │ ├── SparkExecutorInfo.java │ │ │ ├── SparkFirehoseListener.java │ │ │ ├── SparkJobInfo.java │ │ │ ├── SparkStageInfo.java │ │ │ ├── api │ │ │ ├── java │ │ │ │ ├── JavaFutureAction.java │ │ │ │ ├── Optional.java │ │ │ │ └── StorageLevels.java │ │ │ ├── plugin │ │ │ │ ├── DriverPlugin.java │ │ │ │ ├── ExecutorPlugin.java │ │ │ │ ├── PluginContext.java │ │ │ │ └── SparkPlugin.java │ │ │ └── resource │ │ │ │ └── ResourceDiscoveryPlugin.java │ │ │ ├── io │ │ │ ├── NioBufferedFileInputStream.java │ │ │ └── ReadAheadInputStream.java │ │ │ ├── memory │ │ │ ├── MemoryConsumer.java │ │ │ ├── SparkOutOfMemoryError.java │ │ │ ├── TaskMemoryManager.java │ │ │ └── TooLargePageException.java │ │ │ ├── package-info.java │ │ │ ├── serializer │ │ │ └── DummySerializerInstance.java │ │ │ ├── shuffle │ │ │ ├── api │ │ │ │ ├── ShuffleDataIO.java │ │ │ │ ├── ShuffleDriverComponents.java │ │ │ │ ├── ShuffleExecutorComponents.java │ │ │ │ ├── ShuffleMapOutputWriter.java │ │ │ │ ├── ShufflePartitionWriter.java │ │ │ │ ├── SingleSpillShuffleMapOutputWriter.java │ │ │ │ ├── WritableByteChannelWrapper.java │ │ │ │ └── metadata │ │ │ │ │ ├── MapOutputCommitMessage.java │ │ │ │ │ └── MapOutputMetadata.java │ │ │ ├── checksum │ │ │ │ ├── RowBasedChecksum.scala │ │ │ │ └── ShuffleChecksumSupport.java │ │ │ └── sort │ │ │ │ ├── BypassMergeSortShuffleWriter.java │ │ │ │ ├── PackedRecordPointer.java │ │ │ │ ├── ShuffleExternalSorter.java │ │ │ │ ├── ShuffleInMemorySorter.java │ │ │ │ ├── ShuffleSortDataFormat.java │ │ │ │ ├── SpillInfo.java │ │ │ │ ├── UnsafeShuffleWriter.java │ │ │ │ └── io │ │ │ │ ├── LocalDiskShuffleDataIO.java │ │ │ │ ├── LocalDiskShuffleDriverComponents.java │ │ │ │ ├── LocalDiskShuffleExecutorComponents.java │ │ │ │ ├── LocalDiskShuffleMapOutputWriter.java │ │ │ │ └── LocalDiskSingleSpillMapOutputWriter.java │ │ │ ├── status │ │ │ └── api │ │ │ │ └── v1 │ │ │ │ ├── ApplicationStatus.java │ │ │ │ ├── StageStatus.java │ │ │ │ ├── TaskSorting.java │ │ │ │ └── TaskStatus.java │ │ │ ├── storage │ │ │ └── TimeTrackingOutputStream.java │ │ │ ├── unsafe │ │ │ └── map │ │ │ │ ├── BytesToBytesMap.java │ │ │ │ └── HashMapGrowthStrategy.java │ │ │ └── util │ │ │ ├── ChildFirstURLClassLoader.java │ │ │ ├── EnumUtil.java │ │ │ ├── ExposedBufferByteArrayOutputStream.java │ │ │ ├── MutableURLClassLoader.java │ │ │ ├── ParentClassLoader.java │ │ │ └── collection │ │ │ ├── TimSort.java │ │ │ └── unsafe │ │ │ └── sort │ │ │ ├── PrefixComparator.java │ │ │ ├── PrefixComparators.java │ │ │ ├── RadixSort.java │ │ │ ├── RecordComparator.java │ │ │ ├── RecordPointerAndKeyPrefix.java │ │ │ ├── UnsafeExternalSorter.java │ │ │ ├── UnsafeInMemorySorter.java │ │ │ ├── UnsafeSortDataFormat.java │ │ │ ├── UnsafeSorterIterator.java │ │ │ ├── UnsafeSorterSpillMerger.java │ │ │ ├── UnsafeSorterSpillReader.java │ │ │ └── UnsafeSorterSpillWriter.java │ ├── protobuf │ │ ├── buf.yaml │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── status │ │ │ └── protobuf │ │ │ └── store_types.proto │ ├── resources │ │ ├── META-INF │ │ │ ├── LICENSE │ │ │ ├── NOTICE │ │ │ └── services │ │ │ │ ├── org.apache.spark.deploy.history.EventFilterBuilder │ │ │ │ ├── org.apache.spark.security.HadoopDelegationTokenProvider │ │ │ │ └── org.apache.spark.status.protobuf.ProtobufSerDe │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── ui │ │ │ └── static │ │ │ ├── bootstrap.bundle.min.js │ │ │ ├── bootstrap.min.css │ │ │ ├── d3-flamegraph.css │ │ │ ├── d3-flamegraph.min.js │ │ │ ├── d3.min.js │ │ │ ├── dagre-d3.min.js │ │ │ ├── dataTables.bootstrap4.min.css │ │ │ ├── dataTables.bootstrap4.min.js │ │ │ ├── dataTables.rowsGroup.js │ │ │ ├── environmentpage.js │ │ │ ├── executorspage-template.html │ │ │ ├── executorspage.js │ │ │ ├── flamegraph.js │ │ │ ├── graphlib-dot.min.js │ │ │ ├── historypage-common.js │ │ │ ├── historypage-template.html │ │ │ ├── historypage.js │ │ │ ├── initialize-tooltips.js │ │ │ ├── jquery.blockUI.min.js │ │ │ ├── jquery.cookies.2.2.0.min.js │ │ │ ├── jquery.dataTables.min.css │ │ │ ├── jquery.dataTables.min.js │ │ │ ├── jquery.min.js │ │ │ ├── jquery.mustache.js │ │ │ ├── log-view.js │ │ │ ├── package.json │ │ │ ├── scroll-button.js │ │ │ ├── sorttable.js │ │ │ ├── spark-dag-viz.css │ │ │ ├── spark-dag-viz.js │ │ │ ├── spark-logo-77x50px-hd.png │ │ │ ├── stagepage.js │ │ │ ├── stagespage-template.html │ │ │ ├── streaming-page.css │ │ │ ├── streaming-page.js │ │ │ ├── structured-streaming-page.js │ │ │ ├── table.js │ │ │ ├── timeline-view.css │ │ │ ├── timeline-view.js │ │ │ ├── utils.js │ │ │ ├── vis-timeline-graph2d.min.css │ │ │ ├── vis-timeline-graph2d.min.js │ │ │ ├── webui-dataTables.css │ │ │ ├── webui.css │ │ │ └── webui.js │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── Aggregator.scala │ │ ├── BarrierCoordinator.scala │ │ ├── BarrierTaskContext.scala │ │ ├── BarrierTaskInfo.scala │ │ ├── ContextAwareIterator.scala │ │ ├── ContextCleaner.scala │ │ ├── Dependency.scala │ │ ├── ExecutorAllocationClient.scala │ │ ├── ExecutorAllocationManager.scala │ │ ├── FutureAction.scala │ │ ├── HeartbeatReceiver.scala │ │ ├── Heartbeater.scala │ │ ├── InternalAccumulator.scala │ │ ├── InterruptibleIterator.scala │ │ ├── JobArtifactSet.scala │ │ ├── MapOutputStatistics.scala │ │ ├── MapOutputTracker.scala │ │ ├── Partition.scala │ │ ├── PartitionEvaluator.scala │ │ ├── PartitionEvaluatorFactory.scala │ │ ├── Partitioner.scala │ │ ├── SSLOptions.scala │ │ ├── SecurityManager.scala │ │ ├── SerializableWritable.scala │ │ ├── SparkConf.scala │ │ ├── SparkContext.scala │ │ ├── SparkEnv.scala │ │ ├── SparkFileAlreadyExistsException.scala │ │ ├── SparkFiles.scala │ │ ├── SparkStatusTracker.scala │ │ ├── StatusAPIImpl.scala │ │ ├── TaskContext.scala │ │ ├── TaskContextImpl.scala │ │ ├── TaskEndReason.scala │ │ ├── TaskKilledException.scala │ │ ├── TaskNotSerializableException.scala │ │ ├── TaskOutputFileAlreadyExistException.scala │ │ ├── TaskState.scala │ │ ├── TestUtils.scala │ │ ├── api │ │ ├── java │ │ │ ├── JavaDoubleRDD.scala │ │ │ ├── JavaHadoopRDD.scala │ │ │ ├── JavaNewHadoopRDD.scala │ │ │ ├── JavaPairRDD.scala │ │ │ ├── JavaRDD.scala │ │ │ ├── JavaRDDLike.scala │ │ │ ├── JavaSparkContext.scala │ │ │ ├── JavaSparkStatusTracker.scala │ │ │ ├── JavaUtils.scala │ │ │ ├── package-info.java │ │ │ └── package.scala │ │ ├── python │ │ │ ├── Py4JServer.scala │ │ │ ├── PythonErrorUtils.scala │ │ │ ├── PythonGatewayServer.scala │ │ │ ├── PythonHadoopUtil.scala │ │ │ ├── PythonPartitioner.scala │ │ │ ├── PythonRDD.scala │ │ │ ├── PythonRunner.scala │ │ │ ├── PythonUtils.scala │ │ │ ├── PythonWorkerFactory.scala │ │ │ ├── PythonWorkerLogCapture.scala │ │ │ ├── PythonWorkerUtils.scala │ │ │ ├── SerDeUtil.scala │ │ │ └── StreamingPythonRunner.scala │ │ └── r │ │ │ ├── BaseRRunner.scala │ │ │ ├── JVMObjectTracker.scala │ │ │ ├── RAuthHelper.scala │ │ │ ├── RBackend.scala │ │ │ ├── RBackendAuthHandler.scala │ │ │ ├── RBackendHandler.scala │ │ │ ├── RRDD.scala │ │ │ ├── RRunner.scala │ │ │ ├── RUtils.scala │ │ │ └── SerDe.scala │ │ ├── broadcast │ │ ├── Broadcast.scala │ │ ├── BroadcastFactory.scala │ │ ├── BroadcastManager.scala │ │ ├── TorrentBroadcast.scala │ │ ├── TorrentBroadcastFactory.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── deploy │ │ ├── ApplicationDescription.scala │ │ ├── Client.scala │ │ ├── ClientArguments.scala │ │ ├── Command.scala │ │ ├── DeployMessage.scala │ │ ├── DriverDescription.scala │ │ ├── DriverTimeoutPlugin.scala │ │ ├── ExecutorDescription.scala │ │ ├── ExecutorFailureTracker.scala │ │ ├── ExecutorState.scala │ │ ├── ExternalShuffleService.scala │ │ ├── ExternalShuffleServiceSource.scala │ │ ├── FaultToleranceTest.scala │ │ ├── JsonProtocol.scala │ │ ├── LocalSparkCluster.scala │ │ ├── PythonRunner.scala │ │ ├── RPackageUtils.scala │ │ ├── RRunner.scala │ │ ├── RedirectConsolePlugin.scala │ │ ├── SparkApplication.scala │ │ ├── SparkCuratorUtil.scala │ │ ├── SparkHadoopUtil.scala │ │ ├── SparkPipelines.scala │ │ ├── SparkSubmit.scala │ │ ├── SparkSubmitArguments.scala │ │ ├── StandaloneResourceUtils.scala │ │ ├── Utils.scala │ │ ├── client │ │ │ ├── StandaloneAppClient.scala │ │ │ └── StandaloneAppClientListener.scala │ │ ├── history │ │ │ ├── ApplicationCache.scala │ │ │ ├── ApplicationHistoryProvider.scala │ │ │ ├── BasicEventFilterBuilder.scala │ │ │ ├── EventFilter.scala │ │ │ ├── EventLogFileCompactor.scala │ │ │ ├── EventLogFileReaders.scala │ │ │ ├── EventLogFileWriters.scala │ │ │ ├── FsHistoryProvider.scala │ │ │ ├── HistoryAppStatusStore.scala │ │ │ ├── HistoryPage.scala │ │ │ ├── HistoryServer.scala │ │ │ ├── HistoryServerArguments.scala │ │ │ ├── HistoryServerDiskManager.scala │ │ │ ├── HistoryServerMemoryManager.scala │ │ │ ├── HybridStore.scala │ │ │ └── LogPage.scala │ │ ├── master │ │ │ ├── ApplicationInfo.scala │ │ │ ├── ApplicationSource.scala │ │ │ ├── ApplicationState.scala │ │ │ ├── DriverInfo.scala │ │ │ ├── DriverState.scala │ │ │ ├── ExecutorDesc.scala │ │ │ ├── ExecutorResourceDescription.scala │ │ │ ├── FileSystemPersistenceEngine.scala │ │ │ ├── LeaderElectionAgent.scala │ │ │ ├── Master.scala │ │ │ ├── MasterArguments.scala │ │ │ ├── MasterMessages.scala │ │ │ ├── MasterSource.scala │ │ │ ├── PersistenceEngine.scala │ │ │ ├── RecoveryModeFactory.scala │ │ │ ├── RecoveryState.scala │ │ │ ├── RocksDBPersistenceEngine.scala │ │ │ ├── WorkerInfo.scala │ │ │ ├── WorkerState.scala │ │ │ ├── ZooKeeperLeaderElectionAgent.scala │ │ │ ├── ZooKeeperPersistenceEngine.scala │ │ │ └── ui │ │ │ │ ├── ApplicationPage.scala │ │ │ │ ├── EnvironmentPage.scala │ │ │ │ ├── LogPage.scala │ │ │ │ ├── MasterPage.scala │ │ │ │ └── MasterWebUI.scala │ │ ├── rest │ │ │ ├── RestSubmissionClient.scala │ │ │ ├── RestSubmissionServer.scala │ │ │ ├── StandaloneRestServer.scala │ │ │ ├── SubmitRestProtocolException.scala │ │ │ ├── SubmitRestProtocolMessage.scala │ │ │ ├── SubmitRestProtocolRequest.scala │ │ │ └── SubmitRestProtocolResponse.scala │ │ ├── security │ │ │ ├── HBaseDelegationTokenProvider.scala │ │ │ ├── HadoopDelegationTokenManager.scala │ │ │ ├── HadoopFSDelegationTokenProvider.scala │ │ │ └── README.md │ │ └── worker │ │ │ ├── CommandUtils.scala │ │ │ ├── DriverRunner.scala │ │ │ ├── DriverWrapper.scala │ │ │ ├── ExecutorRunner.scala │ │ │ ├── Worker.scala │ │ │ ├── WorkerArguments.scala │ │ │ ├── WorkerSource.scala │ │ │ ├── WorkerWatcher.scala │ │ │ └── ui │ │ │ ├── LogPage.scala │ │ │ ├── WorkerPage.scala │ │ │ └── WorkerWebUI.scala │ │ ├── errors │ │ └── SparkCoreErrors.scala │ │ ├── executor │ │ ├── CoarseGrainedExecutorBackend.scala │ │ ├── CommitDeniedException.scala │ │ ├── Executor.scala │ │ ├── ExecutorBackend.scala │ │ ├── ExecutorClassLoader.scala │ │ ├── ExecutorExitCode.scala │ │ ├── ExecutorLogUrlHandler.scala │ │ ├── ExecutorMetrics.scala │ │ ├── ExecutorMetricsPoller.scala │ │ ├── ExecutorMetricsSource.scala │ │ ├── ExecutorSource.scala │ │ ├── InputMetrics.scala │ │ ├── OutputMetrics.scala │ │ ├── ProcfsMetricsGetter.scala │ │ ├── ShuffleReadMetrics.scala │ │ ├── ShuffleWriteMetrics.scala │ │ ├── TaskMetrics.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── input │ │ ├── FixedLengthBinaryInputFormat.scala │ │ ├── FixedLengthBinaryRecordReader.scala │ │ ├── PortableDataStream.scala │ │ ├── WholeTextFileInputFormat.scala │ │ └── WholeTextFileRecordReader.scala │ │ ├── internal │ │ ├── config │ │ │ ├── Deploy.scala │ │ │ ├── History.scala │ │ │ ├── Kryo.scala │ │ │ ├── Network.scala │ │ │ ├── Python.scala │ │ │ ├── R.scala │ │ │ ├── SparkConfigProvider.scala │ │ │ ├── Status.scala │ │ │ ├── Streaming.scala │ │ │ ├── Tests.scala │ │ │ ├── UI.scala │ │ │ ├── Worker.scala │ │ │ └── package.scala │ │ ├── io │ │ │ ├── FileCommitProtocol.scala │ │ │ ├── HadoopMapRedCommitProtocol.scala │ │ │ ├── HadoopMapReduceCommitProtocol.scala │ │ │ ├── HadoopWriteConfigUtil.scala │ │ │ ├── SparkHadoopWriter.scala │ │ │ └── SparkHadoopWriterUtils.scala │ │ └── plugin │ │ │ ├── PluginContainer.scala │ │ │ ├── PluginContextImpl.scala │ │ │ └── PluginEndpoint.scala │ │ ├── io │ │ ├── CompressionCodec.scala │ │ ├── HadoopCodecStreams.scala │ │ ├── MutableCheckedOutputStream.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── launcher │ │ ├── LauncherBackend.scala │ │ ├── SparkSubmitArgumentsParser.scala │ │ └── WorkerCommandBuilder.scala │ │ ├── mapred │ │ └── SparkHadoopMapRedUtil.scala │ │ ├── memory │ │ ├── ExecutionMemoryPool.scala │ │ ├── MemoryManager.scala │ │ ├── MemoryPool.scala │ │ ├── StorageMemoryPool.scala │ │ ├── UnifiedMemoryManager.scala │ │ ├── UnmanagedMemoryConsumer.scala │ │ └── package.scala │ │ ├── metrics │ │ ├── ExecutorMetricType.scala │ │ ├── MetricsConfig.scala │ │ ├── MetricsSystem.scala │ │ ├── sink │ │ │ ├── ConsoleSink.scala │ │ │ ├── CsvSink.scala │ │ │ ├── GraphiteSink.scala │ │ │ ├── JmxSink.scala │ │ │ ├── MetricsServlet.scala │ │ │ ├── PrometheusServlet.scala │ │ │ ├── Sink.scala │ │ │ ├── Slf4jSink.scala │ │ │ ├── StatsdReporter.scala │ │ │ ├── StatsdSink.scala │ │ │ └── package.scala │ │ └── source │ │ │ ├── AccumulatorSource.scala │ │ │ ├── JVMCPUSource.scala │ │ │ ├── JvmSource.scala │ │ │ ├── Source.scala │ │ │ ├── StaticSources.scala │ │ │ └── package.scala │ │ ├── network │ │ ├── BlockDataManager.scala │ │ ├── BlockTransferService.scala │ │ └── netty │ │ │ ├── NettyBlockRpcServer.scala │ │ │ ├── NettyBlockTransferService.scala │ │ │ └── SparkTransportConf.scala │ │ ├── package.scala │ │ ├── partial │ │ ├── ApproximateActionListener.scala │ │ ├── ApproximateEvaluator.scala │ │ ├── BoundedDouble.scala │ │ ├── CountEvaluator.scala │ │ ├── GroupedCountEvaluator.scala │ │ ├── MeanEvaluator.scala │ │ ├── PartialResult.scala │ │ ├── SumEvaluator.scala │ │ └── package.scala │ │ ├── paths │ │ └── SparkPath.scala │ │ ├── rdd │ │ ├── AsyncRDDActions.scala │ │ ├── BinaryFileRDD.scala │ │ ├── BlockRDD.scala │ │ ├── CartesianRDD.scala │ │ ├── CheckpointRDD.scala │ │ ├── CoGroupedRDD.scala │ │ ├── CoalescedRDD.scala │ │ ├── DoubleRDDFunctions.scala │ │ ├── EmptyRDD.scala │ │ ├── HadoopRDD.scala │ │ ├── InputFileBlockHolder.scala │ │ ├── JdbcRDD.scala │ │ ├── LocalCheckpointRDD.scala │ │ ├── LocalRDDCheckpointData.scala │ │ ├── MapPartitionsRDD.scala │ │ ├── MapPartitionsWithEvaluatorRDD.scala │ │ ├── NewHadoopRDD.scala │ │ ├── OrderedRDDFunctions.scala │ │ ├── PairRDDFunctions.scala │ │ ├── ParallelCollectionRDD.scala │ │ ├── PartitionPruningRDD.scala │ │ ├── PartitionerAwareUnionRDD.scala │ │ ├── PartitionwiseSampledRDD.scala │ │ ├── PipedRDD.scala │ │ ├── RDD.scala │ │ ├── RDDBarrier.scala │ │ ├── RDDCheckpointData.scala │ │ ├── RDDOperationScope.scala │ │ ├── ReliableCheckpointRDD.scala │ │ ├── ReliableRDDCheckpointData.scala │ │ ├── SequenceFileRDDFunctions.scala │ │ ├── ShuffledRDD.scala │ │ ├── SubtractedRDD.scala │ │ ├── UnionRDD.scala │ │ ├── WholeTextFileRDD.scala │ │ ├── ZippedPartitionsRDD.scala │ │ ├── ZippedPartitionsWithEvaluatorRDD.scala │ │ ├── ZippedWithIndexRDD.scala │ │ ├── coalesce-public.scala │ │ ├── package-info.java │ │ ├── package.scala │ │ └── util │ │ │ └── PeriodicRDDCheckpointer.scala │ │ ├── resource │ │ ├── ExecutorResourceRequest.scala │ │ ├── ExecutorResourceRequests.scala │ │ ├── ResourceAllocator.scala │ │ ├── ResourceDiscoveryScriptPlugin.scala │ │ ├── ResourceInformation.scala │ │ ├── ResourceProfile.scala │ │ ├── ResourceProfileBuilder.scala │ │ ├── ResourceProfileManager.scala │ │ ├── ResourceUtils.scala │ │ ├── TaskResourceRequest.scala │ │ └── TaskResourceRequests.scala │ │ ├── rpc │ │ ├── RpcAddress.scala │ │ ├── RpcCallContext.scala │ │ ├── RpcEndpoint.scala │ │ ├── RpcEndpointAddress.scala │ │ ├── RpcEndpointNotFoundException.scala │ │ ├── RpcEndpointRef.scala │ │ ├── RpcEnv.scala │ │ ├── RpcEnvStoppedException.scala │ │ ├── RpcTimeout.scala │ │ └── netty │ │ │ ├── Dispatcher.scala │ │ │ ├── Inbox.scala │ │ │ ├── MessageLoop.scala │ │ │ ├── NettyRpcCallContext.scala │ │ │ ├── NettyRpcEnv.scala │ │ │ ├── NettyStreamManager.scala │ │ │ ├── Outbox.scala │ │ │ └── RpcEndpointVerifier.scala │ │ ├── scheduler │ │ ├── AccumulableInfo.scala │ │ ├── ActiveJob.scala │ │ ├── AsyncEventQueue.scala │ │ ├── BarrierJobAllocationFailed.scala │ │ ├── DAGScheduler.scala │ │ ├── DAGSchedulerEvent.scala │ │ ├── DAGSchedulerSource.scala │ │ ├── EventLoggingListener.scala │ │ ├── ExecutorDecommissionInfo.scala │ │ ├── ExecutorFailuresInTaskSet.scala │ │ ├── ExecutorLossReason.scala │ │ ├── ExecutorResourceInfo.scala │ │ ├── ExecutorResourcesAmounts.scala │ │ ├── ExternalClusterManager.scala │ │ ├── HealthTracker.scala │ │ ├── InputFormatInfo.scala │ │ ├── JobListener.scala │ │ ├── JobResult.scala │ │ ├── JobWaiter.scala │ │ ├── LiveListenerBus.scala │ │ ├── MapStatus.scala │ │ ├── MergeStatus.scala │ │ ├── MiscellaneousProcessDetails.scala │ │ ├── OutputCommitCoordinator.scala │ │ ├── Pool.scala │ │ ├── ReplayListenerBus.scala │ │ ├── ResultStage.scala │ │ ├── ResultTask.scala │ │ ├── Schedulable.scala │ │ ├── SchedulableBuilder.scala │ │ ├── SchedulerBackend.scala │ │ ├── SchedulingAlgorithm.scala │ │ ├── SchedulingMode.scala │ │ ├── ShuffleMapStage.scala │ │ ├── ShuffleMapTask.scala │ │ ├── SparkListener.scala │ │ ├── SparkListenerBus.scala │ │ ├── SplitInfo.scala │ │ ├── Stage.scala │ │ ├── StageInfo.scala │ │ ├── StatsReportListener.scala │ │ ├── Task.scala │ │ ├── TaskDescription.scala │ │ ├── TaskInfo.scala │ │ ├── TaskLocality.scala │ │ ├── TaskLocation.scala │ │ ├── TaskResult.scala │ │ ├── TaskResultGetter.scala │ │ ├── TaskScheduler.scala │ │ ├── TaskSchedulerImpl.scala │ │ ├── TaskSet.scala │ │ ├── TaskSetExcludeList.scala │ │ ├── TaskSetManager.scala │ │ ├── WorkerOffer.scala │ │ ├── cluster │ │ │ ├── CoarseGrainedClusterMessage.scala │ │ │ ├── CoarseGrainedSchedulerBackend.scala │ │ │ ├── ExecutorData.scala │ │ │ ├── ExecutorInfo.scala │ │ │ ├── SchedulerBackendUtils.scala │ │ │ └── StandaloneSchedulerBackend.scala │ │ ├── dynalloc │ │ │ └── ExecutorMonitor.scala │ │ ├── local │ │ │ └── LocalSchedulerBackend.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── security │ │ ├── CryptoStreamUtils.scala │ │ ├── GroupMappingServiceProvider.scala │ │ ├── HadoopDelegationTokenProvider.scala │ │ ├── SecurityConfigurationLock.scala │ │ ├── ShellBasedGroupsMappingProvider.scala │ │ ├── SocketAuthHelper.scala │ │ └── SocketAuthServer.scala │ │ ├── serializer │ │ ├── GenericAvroSerializer.scala │ │ ├── JavaSerializer.scala │ │ ├── KryoSerializer.scala │ │ ├── SerializationDebugger.scala │ │ ├── Serializer.scala │ │ ├── SerializerHelper.scala │ │ ├── SerializerManager.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── shuffle │ │ ├── BaseShuffleHandle.scala │ │ ├── BlockStoreShuffleReader.scala │ │ ├── FetchFailedException.scala │ │ ├── IndexShuffleBlockResolver.scala │ │ ├── MigratableResolver.scala │ │ ├── ShuffleBlockInfo.scala │ │ ├── ShuffleBlockPusher.scala │ │ ├── ShuffleBlockResolver.scala │ │ ├── ShuffleChecksumUtils.scala │ │ ├── ShuffleDataIOUtils.scala │ │ ├── ShuffleHandle.scala │ │ ├── ShuffleManager.scala │ │ ├── ShufflePartitionPairsWriter.scala │ │ ├── ShuffleReader.scala │ │ ├── ShuffleWriteProcessor.scala │ │ ├── ShuffleWriter.scala │ │ ├── metrics.scala │ │ └── sort │ │ │ ├── SortShuffleManager.scala │ │ │ └── SortShuffleWriter.scala │ │ ├── status │ │ ├── AppHistoryServerPlugin.scala │ │ ├── AppStatusListener.scala │ │ ├── AppStatusSource.scala │ │ ├── AppStatusStore.scala │ │ ├── AppStatusUtils.scala │ │ ├── ElementTrackingStore.scala │ │ ├── KVUtils.scala │ │ ├── LiveEntity.scala │ │ ├── api │ │ │ └── v1 │ │ │ │ ├── ApiRootResource.scala │ │ │ │ ├── ApplicationListResource.scala │ │ │ │ ├── JacksonMessageWriter.scala │ │ │ │ ├── OneApplicationResource.scala │ │ │ │ ├── PrometheusResource.scala │ │ │ │ ├── SimpleDateParam.scala │ │ │ │ ├── StagesResource.scala │ │ │ │ └── api.scala │ │ ├── protobuf │ │ │ ├── AccumulableInfoSerializer.scala │ │ │ ├── AppSummarySerializer.scala │ │ │ ├── ApplicationEnvironmentInfoWrapperSerializer.scala │ │ │ ├── ApplicationInfoWrapperSerializer.scala │ │ │ ├── CachedQuantileSerializer.scala │ │ │ ├── ExecutorMetricsSerializer.scala │ │ │ ├── ExecutorStageSummarySerializer.scala │ │ │ ├── ExecutorStageSummaryWrapperSerializer.scala │ │ │ ├── ExecutorSummaryWrapperSerializer.scala │ │ │ ├── JobDataWrapperSerializer.scala │ │ │ ├── JobExecutionStatusSerializer.scala │ │ │ ├── KVStoreProtobufSerializer.scala │ │ │ ├── PoolDataSerializer.scala │ │ │ ├── ProcessSummaryWrapperSerializer.scala │ │ │ ├── ProtobufSerDe.scala │ │ │ ├── RDDOperationGraphWrapperSerializer.scala │ │ │ ├── RDDStorageInfoWrapperSerializer.scala │ │ │ ├── ResourceProfileWrapperSerializer.scala │ │ │ ├── SpeculationStageSummaryWrapperSerializer.scala │ │ │ ├── StageDataWrapperSerializer.scala │ │ │ ├── StageStatusSerializer.scala │ │ │ ├── StreamBlockDataSerializer.scala │ │ │ ├── TaskDataWrapperSerializer.scala │ │ │ └── Utils.scala │ │ └── storeTypes.scala │ │ ├── storage │ │ ├── BlockException.scala │ │ ├── BlockId.scala │ │ ├── BlockInfoManager.scala │ │ ├── BlockManager.scala │ │ ├── BlockManagerDecommissioner.scala │ │ ├── BlockManagerId.scala │ │ ├── BlockManagerManagedBuffer.scala │ │ ├── BlockManagerMaster.scala │ │ ├── BlockManagerMasterEndpoint.scala │ │ ├── BlockManagerMasterHeartbeatEndpoint.scala │ │ ├── BlockManagerMessages.scala │ │ ├── BlockManagerSource.scala │ │ ├── BlockManagerStorageEndpoint.scala │ │ ├── BlockNotFoundException.scala │ │ ├── BlockReplicationPolicy.scala │ │ ├── BlockSavedOnDecommissionedBlockManagerException.scala │ │ ├── BlockUpdatedInfo.scala │ │ ├── DiskBlockManager.scala │ │ ├── DiskBlockObjectWriter.scala │ │ ├── DiskStore.scala │ │ ├── FallbackStorage.scala │ │ ├── FileSegment.scala │ │ ├── LogBlockIdGenerator.scala │ │ ├── LogBlockWriter.scala │ │ ├── LogLine.scala │ │ ├── PushBasedFetchHelper.scala │ │ ├── RDDInfo.scala │ │ ├── RollingLogWriter.scala │ │ ├── ShuffleBlockFetcherIterator.scala │ │ ├── StorageUtils.scala │ │ ├── TopologyMapper.scala │ │ └── memory │ │ │ └── MemoryStore.scala │ │ ├── ui │ │ ├── ConsoleProgressBar.scala │ │ ├── DriverLogPage.scala │ │ ├── GraphUIData.scala │ │ ├── HttpSecurityFilter.scala │ │ ├── JWSFilter.scala │ │ ├── JettyUtils.scala │ │ ├── PagedTable.scala │ │ ├── SparkUI.scala │ │ ├── ToolTips.scala │ │ ├── UIUtils.scala │ │ ├── UIWorkloadGenerator.scala │ │ ├── WebUI.scala │ │ ├── env │ │ │ └── EnvironmentPage.scala │ │ ├── exec │ │ │ ├── ExecutorHeapHistogramPage.scala │ │ │ ├── ExecutorThreadDumpPage.scala │ │ │ └── ExecutorsTab.scala │ │ ├── flamegraph │ │ │ └── FlamegraphNode.scala │ │ ├── jobs │ │ │ ├── AllJobsPage.scala │ │ │ ├── AllStagesPage.scala │ │ │ ├── JobDataUtil.scala │ │ │ ├── JobPage.scala │ │ │ ├── JobsTab.scala │ │ │ ├── PoolPage.scala │ │ │ ├── PoolTable.scala │ │ │ ├── StageDataUtil.scala │ │ │ ├── StagePage.scala │ │ │ ├── StageTable.scala │ │ │ ├── StagesTab.scala │ │ │ └── TaskThreadDumpPage.scala │ │ ├── scope │ │ │ └── RDDOperationGraph.scala │ │ └── storage │ │ │ ├── RDDPage.scala │ │ │ ├── StoragePage.scala │ │ │ ├── StorageTab.scala │ │ │ └── ToolTips.scala │ │ └── util │ │ ├── AccumulatorV2.scala │ │ ├── BestEffortLazyVal.scala │ │ ├── BlockingThreadPoolExecutorService.scala │ │ ├── BoundedPriorityQueue.scala │ │ ├── ByteBufferInputStream.scala │ │ ├── ByteBufferOutputStream.scala │ │ ├── CausedBy.scala │ │ ├── Clock.scala │ │ ├── CollectionsUtils.scala │ │ ├── CommandLineUtils.scala │ │ ├── DependencyUtils.scala │ │ ├── DirectByteBufferOutputStream.scala │ │ ├── Distribution.scala │ │ ├── EventLoop.scala │ │ ├── HadoopFSUtils.scala │ │ ├── IdGenerator.scala │ │ ├── IntParam.scala │ │ ├── JsonProtocol.scala │ │ ├── KeyLock.scala │ │ ├── LazyTry.scala │ │ ├── ListenerBus.scala │ │ ├── ManualClock.scala │ │ ├── MemoryParam.scala │ │ ├── MetricUtils.scala │ │ ├── MutablePair.scala │ │ ├── NextIterator.scala │ │ ├── NonFateSharingCache.scala │ │ ├── PeriodicCheckpointer.scala │ │ ├── RpcUtils.scala │ │ ├── SecurityUtils.scala │ │ ├── SerializableBuffer.scala │ │ ├── SerializableConfiguration.scala │ │ ├── SerializableJobConf.scala │ │ ├── ShutdownHookManager.scala │ │ ├── SignalUtils.scala │ │ ├── SizeEstimator.scala │ │ ├── SparkClosureCleaner.scala │ │ ├── SparkExitCode.scala │ │ ├── SparkUncaughtExceptionHandler.scala │ │ ├── StatCounter.scala │ │ ├── StubClassLoader.scala │ │ ├── ThreadUtils.scala │ │ ├── TransientBestEffortLazyVal.scala │ │ ├── UninterruptibleThread.scala │ │ ├── UninterruptibleThreadRunner.scala │ │ ├── Utils.scala │ │ ├── collection │ │ ├── AppendOnlyMap.scala │ │ ├── BitSet.scala │ │ ├── CompactBuffer.scala │ │ ├── ExternalAppendOnlyMap.scala │ │ ├── ExternalSorter.scala │ │ ├── ImmutableBitSet.scala │ │ ├── OpenHashMap.scala │ │ ├── OpenHashSet.scala │ │ ├── PairsWriter.scala │ │ ├── PartitionedAppendOnlyMap.scala │ │ ├── PartitionedPairBuffer.scala │ │ ├── PercentileHeap.scala │ │ ├── PrimitiveVector.scala │ │ ├── SizeTracker.scala │ │ ├── SizeTrackingAppendOnlyMap.scala │ │ ├── SizeTrackingVector.scala │ │ ├── SortDataFormat.scala │ │ ├── Sorter.scala │ │ ├── Spillable.scala │ │ ├── Utils.scala │ │ └── WritablePartitionedPairCollection.scala │ │ ├── io │ │ ├── ChunkedByteBuffer.scala │ │ ├── ChunkedByteBufferFileRegion.scala │ │ └── ChunkedByteBufferOutputStream.scala │ │ ├── logging │ │ ├── DriverLogger.scala │ │ ├── FileAppender.scala │ │ ├── RollingFileAppender.scala │ │ └── RollingPolicy.scala │ │ ├── package-info.java │ │ ├── package.scala │ │ ├── random │ │ ├── Pseudorandom.scala │ │ ├── RandomSampler.scala │ │ ├── SamplingUtils.scala │ │ ├── StratifiedSamplingUtils.scala │ │ ├── XORShiftRandom.scala │ │ ├── package-info.java │ │ └── package.scala │ │ └── taskListeners.scala │ └── test │ ├── java │ ├── org │ │ └── apache │ │ │ └── spark │ │ │ ├── JavaJdbcRDDSuite.java │ │ │ ├── api │ │ │ └── java │ │ │ │ └── OptionalSuite.java │ │ │ ├── io │ │ │ ├── GenericFileInputStreamSuite.java │ │ │ ├── NioBufferedInputStreamSuite.java │ │ │ └── ReadAheadInputStreamSuite.java │ │ │ ├── launcher │ │ │ └── SparkLauncherSuite.java │ │ │ ├── memory │ │ │ ├── TaskMemoryManagerSuite.java │ │ │ ├── TestMemoryConsumer.java │ │ │ └── TestPartialSpillingMemoryConsumer.java │ │ │ ├── resource │ │ │ └── JavaResourceProfileSuite.java │ │ │ ├── serializer │ │ │ ├── ContainsProxyClass.java │ │ │ └── TestJavaSerializerImpl.java │ │ │ ├── shuffle │ │ │ └── sort │ │ │ │ ├── PackedRecordPointerSuite.java │ │ │ │ ├── ShuffleInMemoryRadixSorterSuite.java │ │ │ │ ├── ShuffleInMemorySorterSuite.java │ │ │ │ └── UnsafeShuffleWriterSuite.java │ │ │ ├── unsafe │ │ │ └── map │ │ │ │ ├── AbstractBytesToBytesMapSuite.java │ │ │ │ ├── BytesToBytesMapOffHeapSuite.java │ │ │ │ └── BytesToBytesMapOnHeapSuite.java │ │ │ └── util │ │ │ ├── SerializableConfigurationSuite.java │ │ │ └── collection │ │ │ ├── TestTimSort.java │ │ │ └── unsafe │ │ │ └── sort │ │ │ ├── UnsafeExternalSorterRadixSortSuite.java │ │ │ ├── UnsafeExternalSorterSuite.java │ │ │ ├── UnsafeInMemorySorterRadixSortSuite.java │ │ │ └── UnsafeInMemorySorterSuite.java │ └── test │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── Java8RDDAPISuite.java │ │ ├── JavaAPISuite.java │ │ ├── JavaSparkContextSuite.java │ │ └── JavaTaskContextCompileCheck.java │ ├── resources │ ├── HistoryServerExpectations │ │ ├── app_environment_expectation.json │ │ ├── application_list_json_expectation.json │ │ ├── complete_stage_list_json_expectation.json │ │ ├── completed_app_list_json_expectation.json │ │ ├── excludeOnFailure_for_stage_expectation.json │ │ ├── excludeOnFailure_node_for_stage_expectation.json │ │ ├── executor_list_json_expectation.json │ │ ├── executor_list_with_executor_metrics_json_expectation.json │ │ ├── executor_memory_usage_expectation.json │ │ ├── executor_node_excludeOnFailure_expectation.json │ │ ├── executor_node_excludeOnFailure_unexcluding_expectation.json │ │ ├── executor_resource_information_expectation.json │ │ ├── failed_stage_list_json_expectation.json │ │ ├── job_list_from_multi_attempt_app_json_1__expectation.json │ │ ├── job_list_from_multi_attempt_app_json_2__expectation.json │ │ ├── job_list_json_expectation.json │ │ ├── limit_app_list_json_expectation.json │ │ ├── maxDate2_app_list_json_expectation.json │ │ ├── maxDate_app_list_json_expectation.json │ │ ├── maxEndDate_app_list_json_expectation.json │ │ ├── minDate_and_maxEndDate_app_list_json_expectation.json │ │ ├── minDate_app_list_json_expectation.json │ │ ├── minEndDate_and_maxEndDate_app_list_json_expectation.json │ │ ├── minEndDate_app_list_json_expectation.json │ │ ├── miscellaneous_process_expectation.json │ │ ├── multiple_resource_profiles_expectation.json │ │ ├── one_app_json_expectation.json │ │ ├── one_app_multi_attempt_json_expectation.json │ │ ├── one_job_json_expectation.json │ │ ├── one_rdd_storage_json_expectation.json │ │ ├── one_stage_attempt_json_details_with_failed_task_expectation.json │ │ ├── one_stage_attempt_json_expectation.json │ │ ├── one_stage_json_expectation.json │ │ ├── one_stage_json_with_details_expectation.json │ │ ├── one_stage_json_with_partitionId_expectation.json │ │ ├── rdd_list_storage_json_expectation.json │ │ ├── running_app_list_json_expectation.json │ │ ├── stage_list_json_expectation.json │ │ ├── stage_list_with_accumulable_json_expectation.json │ │ ├── stage_list_with_peak_metrics_expectation.json │ │ ├── stage_task_list_expectation.json │ │ ├── stage_task_list_from_multi_attempt_app_json_1__expectation.json │ │ ├── stage_task_list_from_multi_attempt_app_json_2__expectation.json │ │ ├── stage_task_list_w__offset___length_expectation.json │ │ ├── stage_task_list_w__sortBy_expectation.json │ │ ├── stage_task_list_w__sortBy_short_names___runtime_expectation.json │ │ ├── stage_task_list_w__sortBy_short_names__runtime_expectation.json │ │ ├── stage_task_list_w__status___offset___length_expectation.json │ │ ├── stage_task_list_w__status___sortBy_short_names__runtime_expectation.json │ │ ├── stage_task_list_w__status_expectation.json │ │ ├── stage_task_list_with_partitionId_expectation.json │ │ ├── stage_task_summary_w__custom_quantiles_expectation.json │ │ ├── stage_task_summary_w_shuffle_read_expectation.json │ │ ├── stage_task_summary_w_shuffle_write_expectation.json │ │ ├── stage_with_accumulable_json_expectation.json │ │ ├── stage_with_peak_metrics_expectation.json │ │ ├── stage_with_speculation_summary_expectation.json │ │ ├── stage_with_summaries_expectation.json │ │ ├── succeeded_failed_job_list_json_expectation.json │ │ └── succeeded_job_list_json_expectation.json │ ├── META-INF │ │ └── services │ │ │ ├── org.apache.spark.scheduler.ExternalClusterManager │ │ │ └── org.apache.spark.security.HadoopDelegationTokenProvider │ ├── ProcfsMetrics │ │ ├── 22763 │ │ │ └── stat │ │ ├── 26109 │ │ │ └── stat │ │ └── 487713 │ │ │ └── stat │ ├── TestHelloV2_2.13.jar │ ├── TestHelloV3_2.13.jar │ ├── TestUDTF.jar │ ├── certchain.pem │ ├── fairscheduler-with-invalid-data.xml │ ├── fairscheduler-with-valid-data.xml │ ├── fairscheduler.xml │ ├── hive-site.xml │ ├── key.pem │ ├── keystore │ ├── log4j2.properties │ ├── spark-events-broken │ │ ├── last-attempt-incomplete │ │ │ ├── application_1656321732247_0006_1 │ │ │ └── application_1656321732247_0006_2 │ │ └── previous-attempt-incomplete │ │ │ ├── application_1656321732247_0006_1 │ │ │ └── application_1656321732247_0006_2 │ ├── spark-events │ │ ├── app-20161115172038-0000 │ │ ├── app-20161116163331-0000 │ │ ├── app-20180109111548-0000 │ │ ├── app-20200706201101-0003 │ │ ├── application_1516285256255_0012 │ │ ├── application_1553914137147_0018 │ │ ├── application_1555004656427_0144 │ │ ├── application_1578436911597_0052 │ │ ├── application_1628109047826_1317105 │ │ ├── local-1422981759269 │ │ ├── local-1422981780767 │ │ ├── local-1425081759269 │ │ ├── local-1426533911241 │ │ ├── local-1426633911242 │ │ ├── local-1430917381534 │ │ ├── local-1430917381535_1 │ │ ├── local-1430917381535_2 │ │ └── local-1642039451826 │ ├── spark.keystore │ ├── test_metrics_config.properties │ ├── test_metrics_system.properties │ ├── truststore │ ├── unencrypted-certchain.pem │ ├── unencrypted-key.pem │ └── untrusted-keystore │ └── scala │ └── org │ └── apache │ ├── spark │ ├── AccumulatorSuite.scala │ ├── BarrierStageOnSubmittedSuite.scala │ ├── CheckpointSuite.scala │ ├── ContextCleanerSuite.scala │ ├── DebugFilesystem.scala │ ├── DistributedSuite.scala │ ├── DriverSuite.scala │ ├── ExecutorAllocationManagerSuite.scala │ ├── ExternalShuffleServiceSuite.scala │ ├── FailureSuite.scala │ ├── FileSuite.scala │ ├── FutureActionSuite.scala │ ├── HeartbeatReceiverSuite.scala │ ├── ImplicitOrderingSuite.scala │ ├── InternalAccumulatorSuite.scala │ ├── JobArtifactSetSuite.scala │ ├── JobCancellationSuite.scala │ ├── JsonTestUtils.scala │ ├── LocalRootDirsTest.scala │ ├── LocalSparkContext.scala │ ├── MapOutputTrackerSuite.scala │ ├── MapStatusesConvertBenchmark.scala │ ├── MapStatusesSerDeserBenchmark.scala │ ├── PartitioningSuite.scala │ ├── ProcessTestUtils.scala │ ├── SSLOptionsSuite.scala │ ├── SecurityManagerSuite.scala │ ├── SerializerTestUtils.scala │ ├── SharedSparkContext.scala │ ├── ShuffleNettySuite.scala │ ├── ShuffleOldFetchProtocolSuite.scala │ ├── ShuffleSuite.scala │ ├── Smuggle.scala │ ├── SortShuffleSuite.scala │ ├── SparkConfSuite.scala │ ├── SparkContextInfoSuite.scala │ ├── SparkContextSchedulerCreationSuite.scala │ ├── SparkContextSuite.scala │ ├── SparkFunSuite.scala │ ├── SparkThrowableSuite.scala │ ├── SslExternalShuffleServiceSuite.scala │ ├── SslShuffleNettySuite.scala │ ├── StatusTrackerSuite.scala │ ├── TempLocalSparkContext.scala │ ├── TestShuffleDataIOWithMockedComponents.scala │ ├── ThreadAudit.scala │ ├── ThreadingSuite.scala │ ├── UnpersistSuite.scala │ ├── api │ │ ├── java │ │ │ └── JavaUtilsSuite.scala │ │ ├── python │ │ │ ├── PythonBroadcastSuite.scala │ │ │ ├── PythonHadoopUtilSuite.scala │ │ │ ├── PythonRDDSuite.scala │ │ │ ├── PythonWorkerFactorySuite.scala │ │ │ ├── SerDeUtilSuite.scala │ │ │ └── WriteInputFormatTestDataGenerator.scala │ │ └── r │ │ │ ├── BaseRRunnerSuite.scala │ │ │ ├── JVMObjectTrackerSuite.scala │ │ │ └── RBackendSuite.scala │ ├── benchmark │ │ ├── Benchmark.scala │ │ ├── BenchmarkBase.scala │ │ └── Benchmarks.scala │ ├── broadcast │ │ └── BroadcastSuite.scala │ ├── deploy │ │ ├── ClientSuite.scala │ │ ├── DecommissionWorkerSuite.scala │ │ ├── DeployTestUtils.scala │ │ ├── ExecutorFailureTrackerSuite.scala │ │ ├── ExternalShuffleServiceDbSuite.scala │ │ ├── ExternalShuffleServiceMetricsSuite.scala │ │ ├── JsonProtocolSuite.scala │ │ ├── LogUrlsStandaloneSuite.scala │ │ ├── PythonRunnerSuite.scala │ │ ├── RPackageUtilsSuite.scala │ │ ├── SparkHadoopUtilSuite.scala │ │ ├── SparkPipelinesSuite.scala │ │ ├── SparkSubmitSuite.scala │ │ ├── SparkSubmitTestUtils.scala │ │ ├── StandaloneDynamicAllocationSuite.scala │ │ ├── client │ │ │ ├── AppClientSuite.scala │ │ │ └── TestExecutor.scala │ │ ├── history │ │ │ ├── ApplicationCacheSuite.scala │ │ │ ├── BasicEventFilterBuilderSuite.scala │ │ │ ├── BasicEventFilterSuite.scala │ │ │ ├── ChromeUIHistoryServerSuite.scala │ │ │ ├── EventLogFileCompactorSuite.scala │ │ │ ├── EventLogFileReadersSuite.scala │ │ │ ├── EventLogFileWritersSuite.scala │ │ │ ├── EventLogTestHelper.scala │ │ │ ├── FsHistoryProviderSuite.scala │ │ │ ├── HistoryServerArgumentsSuite.scala │ │ │ ├── HistoryServerDiskManagerSuite.scala │ │ │ ├── HistoryServerMemoryManagerSuite.scala │ │ │ ├── HistoryServerPageSuite.scala │ │ │ ├── HistoryServerSuite.scala │ │ │ ├── HybridStoreSuite.scala │ │ │ └── RealBrowserUIHistoryServerSuite.scala │ │ ├── master │ │ │ ├── CustomRecoveryModeFactory.scala │ │ │ ├── MasterDecommissionSuite.scala │ │ │ ├── MasterSuite.scala │ │ │ ├── MasterSuiteBase.scala │ │ │ ├── MasterWorkerUISuite.scala │ │ │ ├── PersistenceEngineBenchmark.scala │ │ │ ├── PersistenceEngineSuite.scala │ │ │ ├── RecoverySuite.scala │ │ │ ├── ResourceProfilesSuite.scala │ │ │ ├── WorkerSelectionSuite.scala │ │ │ └── ui │ │ │ │ ├── ApplicationPageSuite.scala │ │ │ │ ├── MasterWebUISuite.scala │ │ │ │ └── ReadOnlyMasterWebUISuite.scala │ │ ├── rest │ │ │ ├── StandaloneRestSubmitSuite.scala │ │ │ └── SubmitRestProtocolSuite.scala │ │ ├── security │ │ │ ├── HadoopDelegationTokenManagerSuite.scala │ │ │ └── HadoopFSDelegationTokenProviderSuite.scala │ │ └── worker │ │ │ ├── CommandUtilsSuite.scala │ │ │ ├── DriverRunnerTest.scala │ │ │ ├── ExecutorRunnerTest.scala │ │ │ ├── WorkerArgumentsTest.scala │ │ │ ├── WorkerSuite.scala │ │ │ ├── WorkerWatcherSuite.scala │ │ │ └── ui │ │ │ └── LogPageSuite.scala │ ├── executor │ │ ├── ClassLoaderIsolationSuite.scala │ │ ├── CoarseGrainedExecutorBackendSuite.scala │ │ ├── ExecutorClassLoaderSuite.scala │ │ ├── ExecutorMetricsPollerSuite.scala │ │ ├── ExecutorSuite.scala │ │ ├── ProcfsMetricsGetterSuite.scala │ │ └── TaskMetricsSuite.scala │ ├── input │ │ ├── WholeTextFileInputFormatSuite.scala │ │ └── WholeTextFileRecordReaderSuite.scala │ ├── internal │ │ ├── LoggingSuite.scala │ │ ├── config │ │ │ ├── ConfigEntrySuite.scala │ │ │ └── ConfigReaderSuite.scala │ │ ├── io │ │ │ ├── FileCommitProtocolInstantiationSuite.scala │ │ │ └── SparkHadoopWriterUtilsSuite.scala │ │ └── plugin │ │ │ └── PluginContainerSuite.scala │ ├── io │ │ ├── ChunkedByteBufferFileRegionSuite.scala │ │ ├── ChunkedByteBufferSuite.scala │ │ ├── CompressionCodecSuite.scala │ │ ├── LZFBenchmark.scala │ │ ├── ZStandardBenchmark.scala │ │ └── ZStandardTPCDSDataBenchmark.scala │ ├── launcher │ │ └── LauncherBackendSuite.scala │ ├── memory │ │ ├── MemoryManagerSuite.scala │ │ ├── MemoryTestingUtils.scala │ │ ├── TestMemoryManager.scala │ │ ├── TestMemoryManagerSuite.scala │ │ └── UnifiedMemoryManagerSuite.scala │ ├── metrics │ │ ├── InputOutputMetricsSuite.scala │ │ ├── MetricsConfigSuite.scala │ │ ├── MetricsSystemSuite.scala │ │ ├── sink │ │ │ ├── GraphiteSinkSuite.scala │ │ │ ├── PrometheusServletSuite.scala │ │ │ └── StatsdSinkSuite.scala │ │ └── source │ │ │ ├── AccumulatorSourceSuite.scala │ │ │ └── SourceConfigSuite.scala │ ├── network │ │ ├── BlockTransferServiceSuite.scala │ │ └── netty │ │ │ ├── NettyBlockRpcServerSuite.scala │ │ │ ├── NettyBlockTransferSecuritySuite.scala │ │ │ ├── NettyBlockTransferServiceSuite.scala │ │ │ └── SparkTransportConfSuite.scala │ ├── partial │ │ ├── CountEvaluatorSuite.scala │ │ ├── MeanEvaluatorSuite.scala │ │ └── SumEvaluatorSuite.scala │ ├── rdd │ │ ├── AsyncRDDActionsSuite.scala │ │ ├── CoalescedRDDBenchmark.scala │ │ ├── DoubleRDDSuite.scala │ │ ├── HadoopRDDSuite.scala │ │ ├── JdbcRDDSuite.scala │ │ ├── LocalCheckpointSuite.scala │ │ ├── PairRDDFunctionsSuite.scala │ │ ├── ParallelCollectionSplitSuite.scala │ │ ├── PartitionPruningRDDSuite.scala │ │ ├── PartitionwiseSampledRDDSuite.scala │ │ ├── PipedRDDSuite.scala │ │ ├── RDDBarrierSuite.scala │ │ ├── RDDCleanerSuite.scala │ │ ├── RDDOperationScopeSuite.scala │ │ ├── RDDSuite.scala │ │ ├── RDDSuiteUtils.scala │ │ ├── SortingSuite.scala │ │ └── ZippedPartitionsSuite.scala │ ├── resource │ │ ├── ResourceDiscoveryPluginSuite.scala │ │ ├── ResourceInformationSuite.scala │ │ ├── ResourceProfileManagerSuite.scala │ │ ├── ResourceProfileSuite.scala │ │ ├── ResourceUtilsSuite.scala │ │ └── TestResourceIDs.scala │ ├── rpc │ │ ├── RpcAddressSuite.scala │ │ ├── RpcEnvSuite.scala │ │ ├── TestRpcEndpoint.scala │ │ └── netty │ │ │ ├── InboxSuite.scala │ │ │ ├── NettyRpcAddressSuite.scala │ │ │ ├── NettyRpcEnvSuite.scala │ │ │ └── NettyRpcHandlerSuite.scala │ ├── scheduler │ │ ├── AQEShuffledRDD.scala │ │ ├── AdaptiveSchedulingSuite.scala │ │ ├── BarrierTaskContextSuite.scala │ │ ├── CoarseGrainedSchedulerBackendSuite.scala │ │ ├── DAGSchedulerSuite.scala │ │ ├── EventLoggingListenerSuite.scala │ │ ├── ExecutorResourceInfoSuite.scala │ │ ├── ExecutorResourceUtils.scala │ │ ├── ExecutorResourcesAmountsSuite.scala │ │ ├── ExternalClusterManagerSuite.scala │ │ ├── FakeTask.scala │ │ ├── HealthTrackerIntegrationSuite.scala │ │ ├── HealthTrackerSuite.scala │ │ ├── JobWaiterSuite.scala │ │ ├── MapStatusSuite.scala │ │ ├── NotSerializableFakeTask.scala │ │ ├── OutputCommitCoordinatorIntegrationSuite.scala │ │ ├── OutputCommitCoordinatorSuite.scala │ │ ├── PoolSuite.scala │ │ ├── ReplayListenerSuite.scala │ │ ├── SchedulerIntegrationSuite.scala │ │ ├── SparkListenerSuite.scala │ │ ├── SparkListenerWithClusterSuite.scala │ │ ├── TaskContextSuite.scala │ │ ├── TaskDescriptionSuite.scala │ │ ├── TaskResultGetterSuite.scala │ │ ├── TaskSchedulerImplSuite.scala │ │ ├── TaskSetExcludelistSuite.scala │ │ ├── TaskSetManagerSuite.scala │ │ ├── WorkerDecommissionExtendedSuite.scala │ │ ├── WorkerDecommissionSuite.scala │ │ └── dynalloc │ │ │ └── ExecutorMonitorSuite.scala │ ├── security │ │ ├── CryptoStreamUtilsSuite.scala │ │ ├── EncryptionFunSuite.scala │ │ └── SocketAuthHelperSuite.scala │ ├── serializer │ │ ├── GenericAvroSerializerSuite.scala │ │ ├── JavaSerializerSuite.scala │ │ ├── KryoBenchmark.scala │ │ ├── KryoIteratorBenchmark.scala │ │ ├── KryoSerializerBenchmark.scala │ │ ├── KryoSerializerDistributedSuite.scala │ │ ├── KryoSerializerResizableOutputSuite.scala │ │ ├── KryoSerializerSuite.scala │ │ ├── ProactiveClosureSerializationSuite.scala │ │ ├── SerializationDebuggerSuite.scala │ │ ├── SerializerPropertiesSuite.scala │ │ ├── TestSerializer.scala │ │ └── UnsafeKryoSerializerSuite.scala │ ├── shuffle │ │ ├── BlockStoreShuffleReaderSuite.scala │ │ ├── ChecksumBenchmark.scala │ │ ├── HostLocalShuffleReadingSuite.scala │ │ ├── ShuffleBlockPusherSuite.scala │ │ ├── ShuffleChecksumTestHelper.scala │ │ ├── ShuffleDependencySuite.scala │ │ ├── ShuffleDriverComponentsSuite.scala │ │ ├── checksum │ │ │ └── OutputStreamRowBasedChecksum.scala │ │ └── sort │ │ │ ├── BypassMergeSortShuffleWriterSuite.scala │ │ │ ├── IndexShuffleBlockResolverSuite.scala │ │ │ ├── ShuffleExternalSorterSuite.scala │ │ │ ├── SortShuffleManagerSuite.scala │ │ │ ├── SortShuffleWriterSuite.scala │ │ │ └── io │ │ │ └── LocalDiskShuffleMapOutputWriterSuite.scala │ ├── status │ │ ├── AppStatusListenerSuite.scala │ │ ├── AppStatusStoreSuite.scala │ │ ├── AppStatusUtilsSuite.scala │ │ ├── AutoCleanupLiveUIDirSuite.scala │ │ ├── ElementTrackingStoreSuite.scala │ │ ├── ListenerEventsTestHelper.scala │ │ ├── LiveEntitySuite.scala │ │ ├── api │ │ │ └── v1 │ │ │ │ ├── ExecutorSummarySuite.scala │ │ │ │ └── SimpleDateParamSuite.scala │ │ └── protobuf │ │ │ └── KVStoreProtobufSerializerSuite.scala │ ├── storage │ │ ├── BlockIdSuite.scala │ │ ├── BlockInfoManagerSuite.scala │ │ ├── BlockManagerDecommissionIntegrationSuite.scala │ │ ├── BlockManagerDecommissionUnitSuite.scala │ │ ├── BlockManagerInfoSuite.scala │ │ ├── BlockManagerMasterSuite.scala │ │ ├── BlockManagerReplicationSuite.scala │ │ ├── BlockManagerSuite.scala │ │ ├── BlockReplicationPolicySuite.scala │ │ ├── DiskBlockManagerSuite.scala │ │ ├── DiskBlockObjectWriterSuite.scala │ │ ├── DiskStoreSuite.scala │ │ ├── FallbackStorageSuite.scala │ │ ├── FlatmapIteratorSuite.scala │ │ ├── LocalDirsSuite.scala │ │ ├── LogBlockWriterSuite.scala │ │ ├── MemoryStoreSuite.scala │ │ ├── PartiallySerializedBlockSuite.scala │ │ ├── PartiallyUnrolledIteratorSuite.scala │ │ ├── ShuffleBlockFetcherIteratorSuite.scala │ │ ├── SslBlockManagerReplicationSuite.scala │ │ ├── StorageSuite.scala │ │ └── TopologyMapperSuite.scala │ ├── ui │ │ ├── ChromeUISeleniumSuite.scala │ │ ├── DriverLogPageSuite.scala │ │ ├── HttpSecurityFilterSuite.scala │ │ ├── JWSFilterSuite.scala │ │ ├── PagedTableSuite.scala │ │ ├── RealBrowserUISeleniumSuite.scala │ │ ├── UISeleniumSuite.scala │ │ ├── UISuite.scala │ │ ├── UIUtilsSuite.scala │ │ ├── env │ │ │ └── EnvironmentPageSuite.scala │ │ ├── scope │ │ │ └── RDDOperationGraphSuite.scala │ │ └── storage │ │ │ └── StoragePageSuite.scala │ └── util │ │ ├── AccumulatorV2Suite.scala │ │ ├── ArrayImplicitsSuite.scala │ │ ├── BestEffortLazyValSuite.scala │ │ ├── BoundedPriorityQueueSuite.scala │ │ ├── CausedBySuite.scala │ │ ├── ClosureCleanerSuite.scala │ │ ├── ClosureCleanerSuite2.scala │ │ ├── CompletionIteratorSuite.scala │ │ ├── DependencyUtilsSuite.scala │ │ ├── DirectByteBufferOutputStreamSuite.scala │ │ ├── DistributionSuite.scala │ │ ├── EventLoopSuite.scala │ │ ├── FileAppenderSuite.scala │ │ ├── HadoopFSUtilsSuite.scala │ │ ├── JsonProtocolSuite.scala │ │ ├── KeyLockSuite.scala │ │ ├── LazyTrySuite.scala │ │ ├── MutableURLClassLoaderSuite.scala │ │ ├── NextIteratorSuite.scala │ │ ├── NonFateSharingCacheSuite.scala │ │ ├── PeriodicRDDCheckpointerSuite.scala │ │ ├── PropertiesCloneBenchmark.scala │ │ ├── ResetSystemProperties.scala │ │ ├── SizeEstimatorSuite.scala │ │ ├── SparkConfWithEnv.scala │ │ ├── SparkUncaughtExceptionHandlerSuite.scala │ │ ├── SslTestUtils.scala │ │ ├── ThreadUtilsSuite.scala │ │ ├── TransientBestEffortLazyValSuite.scala │ │ ├── UninterruptibleThreadRunnerSuite.scala │ │ ├── UninterruptibleThreadSuite.scala │ │ ├── UtilsSuite.scala │ │ ├── collection │ │ ├── AppendOnlyMapSuite.scala │ │ ├── BitSetSuite.scala │ │ ├── CompactBufferSuite.scala │ │ ├── ExternalAppendOnlyMapSuite.scala │ │ ├── ExternalSorterSpillSuite.scala │ │ ├── ExternalSorterSuite.scala │ │ ├── FixedHashObject.scala │ │ ├── ImmutableBitSetSuite.scala │ │ ├── OpenHashMapSuite.scala │ │ ├── OpenHashSetSuite.scala │ │ ├── PercentileHeapBenchmark.scala │ │ ├── PercentileHeapSuite.scala │ │ ├── PrimitiveVectorSuite.scala │ │ ├── SizeTrackerSuite.scala │ │ ├── SorterBenchmark.scala │ │ ├── SorterSuite.scala │ │ └── unsafe │ │ │ └── sort │ │ │ ├── PrefixComparatorsSuite.scala │ │ │ └── RadixSortSuite.scala │ │ ├── io │ │ └── ChunkedByteBufferOutputStreamSuite.scala │ │ ├── kvstore │ │ └── RocksDBBenchmark.scala │ │ ├── logging │ │ └── DriverLoggerSuite.scala │ │ └── random │ │ ├── RandomSamplerSuite.scala │ │ ├── SamplingUtilsSuite.scala │ │ ├── XORShiftRandomBenchmark.scala │ │ └── XORShiftRandomSuite.scala │ └── sparktest │ └── ImplicitSuite.scala ├── data ├── artifact-tests │ ├── crc │ │ ├── README.md │ │ ├── junitLargeJar.txt │ │ └── smallJar.txt │ ├── junitLargeJar.jar │ └── smallJar.jar ├── graphx │ ├── followers.txt │ └── users.txt ├── mllib │ ├── als │ │ ├── sample_movielens_ratings.txt │ │ └── test.data │ ├── gmm_data.txt │ ├── images │ │ ├── license.txt │ │ └── origin │ │ │ ├── kittens │ │ │ ├── 29.5.a_b_EGDP022204.jpg │ │ │ ├── 54893.jpg │ │ │ ├── DP153539.jpg │ │ │ ├── DP802813.jpg │ │ │ └── not-image.txt │ │ │ ├── license.txt │ │ │ └── multi-channel │ │ │ ├── BGRA.png │ │ │ ├── BGRA_alpha_60.png │ │ │ ├── chr30.4.184.jpg │ │ │ └── grayscale.jpg │ ├── kmeans_data.txt │ ├── pagerank_data.txt │ ├── pic_data.txt │ ├── ridge-data │ │ └── lpsa.data │ ├── sample_binary_classification_data.txt │ ├── sample_fpgrowth.txt │ ├── sample_isotonic_regression_libsvm_data.txt │ ├── sample_kmeans_data.txt │ ├── sample_lda_data.txt │ ├── sample_lda_libsvm_data.txt │ ├── sample_libsvm_data.txt │ ├── sample_linear_regression_data.txt │ ├── sample_movielens_data.txt │ ├── sample_multiclass_classification_data.txt │ ├── sample_svm_data.txt │ └── streaming_kmeans_data_test.txt └── streaming │ └── AFINN-111.txt ├── dev ├── .rat-excludes ├── .scalafmt.conf ├── README.md ├── change-scala-version.sh ├── check-license ├── check-protos.py ├── check_pyspark_custom_errors.py ├── checkstyle-suppressions.xml ├── checkstyle.xml ├── connect-gen-protos.sh ├── connect-jvm-client-mima-check ├── create-release │ ├── announce.tmpl │ ├── do-release-docker.sh │ ├── do-release.sh │ ├── generate-contributors.py │ ├── generate-llms-txt.py │ ├── known_translations │ ├── release-build.sh │ ├── release-tag.sh │ ├── release-util.sh │ ├── releaseutils.py │ ├── spark-rm │ │ └── Dockerfile │ ├── translate-contributors.py │ └── vote.tmpl ├── deps │ └── spark-deps-hadoop-3-hive-2.3 ├── eslint.js ├── free_disk_space ├── free_disk_space_container ├── gen-protos.sh ├── infra │ └── Dockerfile ├── is-changed.py ├── java-file-header ├── lint-java ├── lint-js ├── lint-python ├── lint-r ├── lint-r.R ├── lint-scala ├── make-distribution.sh ├── merge_spark_pr.py ├── mima ├── package-lock.json ├── package.json ├── pip-sanity-check.py ├── protobuf-breaking-changes-check.sh ├── py-cleanup ├── pyproject.toml ├── reformat-python ├── requirements.txt ├── run-pip-tests ├── run-tests ├── run-tests.py ├── sbt-checkstyle ├── scalafmt ├── scalastyle ├── spark-test-image-util │ └── docs │ │ ├── build-docs │ │ └── run-in-container ├── spark-test-image │ ├── docs │ │ └── Dockerfile │ ├── lint │ │ └── Dockerfile │ ├── numpy-213 │ │ └── Dockerfile │ ├── pypy-310 │ │ └── Dockerfile │ ├── pypy-311 │ │ └── Dockerfile │ ├── python-310 │ │ └── Dockerfile │ ├── python-311-classic-only │ │ └── Dockerfile │ ├── python-311 │ │ └── Dockerfile │ ├── python-312 │ │ └── Dockerfile │ ├── python-313-nogil │ │ └── Dockerfile │ ├── python-313 │ │ └── Dockerfile │ ├── python-314 │ │ └── Dockerfile │ ├── python-minimum │ │ └── Dockerfile │ ├── python-ps-minimum │ │ └── Dockerfile │ └── sparkr │ │ └── Dockerfile ├── sparktestsupport │ ├── __init__.py │ ├── modules.py │ ├── shellutils.py │ ├── toposort.py │ └── utils.py ├── streaming-gen-protos.sh ├── structured_logging_style.py ├── test-classes.txt ├── test-dependencies.sh ├── test-jars.txt └── tox.ini ├── docs ├── .bundle │ └── config ├── .gitignore ├── 404.md ├── Gemfile ├── Gemfile.lock ├── README.md ├── _config.yml ├── _data │ ├── menu-migration.yaml │ ├── menu-ml.yaml │ ├── menu-mllib.yaml │ ├── menu-sql.yaml │ └── menu-streaming.yaml ├── _includes │ ├── nav-left-wrapper-migration.html │ ├── nav-left-wrapper-ml.html │ ├── nav-left-wrapper-sql.html │ ├── nav-left-wrapper-streaming.html │ └── nav-left.html ├── _layouts │ ├── global.html │ └── redirect.html ├── _plugins │ ├── build-error-docs.py │ ├── build_api_docs.rb │ ├── conditonal_includes.rb │ ├── include_example.rb │ └── production_tag.rb ├── app-dev-spark-connect.md ├── building-spark.md ├── cloud-integration.md ├── cluster-overview.md ├── configuration.md ├── control-flow │ ├── case-stmt.md │ ├── compound-stmt.md │ ├── for-stmt.md │ ├── if-stmt.md │ ├── iterate-stmt.md │ ├── leave-stmt.md │ ├── loop-stmt.md │ ├── repeat-stmt.md │ └── while-stmt.md ├── core-migration-guide.md ├── css │ ├── api-docs.css │ ├── api-javadocs.css │ ├── bootstrap.min.css │ ├── bootstrap.min.css.map │ ├── custom.css │ ├── docsearch.css │ ├── docsearch.min.css │ ├── docsearch.min.css.map │ └── pygments-default.css ├── declarative-pipelines-programming-guide.md ├── graphx-programming-guide.md ├── hadoop-provided.md ├── hardware-provisioning.md ├── img │ ├── AllJobsPageDetail1.png │ ├── AllJobsPageDetail2.png │ ├── AllJobsPageDetail3.png │ ├── AllStagesPageDetail1.png │ ├── AllStagesPageDetail2.png │ ├── AllStagesPageDetail3.png │ ├── AllStagesPageDetail4.png │ ├── AllStagesPageDetail5.png │ ├── AllStagesPageDetail6.png │ ├── AllStagesPageDetail7.png │ ├── AllStagesPageDetail8.png │ ├── AllStagesPageDetail9.png │ ├── JDBCServer1.png │ ├── JDBCServer2.png │ ├── JDBCServer3.png │ ├── JobPageDetail1.png │ ├── JobPageDetail2.png │ ├── JobPageDetail3.png │ ├── async-progress.png │ ├── cluster-overview.png │ ├── cluster-overview.pptx │ ├── declarative-pipelines-dataflow-graph.png │ ├── edge_cut_vs_vertex_cut.png │ ├── extending-spark-connect-labelled.png │ ├── extending-spark-connect.png │ ├── glyphicons-halflings-white.png │ ├── glyphicons-halflings.png │ ├── graphx_figures.pptx │ ├── graphx_logo.png │ ├── java-sm.png │ ├── k8s-cluster-mode.png │ ├── ml-Pipeline.png │ ├── ml-PipelineModel.png │ ├── ml-Pipelines.pptx │ ├── property_graph.png │ ├── pycharm-with-pyspark1.png │ ├── pycharm-with-pyspark2.png │ ├── pycharm-with-pyspark3.png │ ├── pyspark-components.pptx │ ├── pyspark-machine_learning.png │ ├── pyspark-pandas_api_on_spark.png │ ├── pyspark-pandas_on_spark-transform_apply.pptx │ ├── pyspark-pandas_on_spark-transform_apply1.png │ ├── pyspark-pandas_on_spark-transform_apply2.png │ ├── pyspark-pandas_on_spark-transform_apply3.png │ ├── pyspark-pandas_on_spark-transform_apply4.png │ ├── pyspark-python_spark_connect_client.png │ ├── pyspark-remote-debug1.png │ ├── pyspark-remote-debug2.png │ ├── pyspark-spark_core_and_rdds.png │ ├── pyspark-spark_sql_and_dataframes.png │ ├── pyspark-structured_streaming.png │ ├── pyspark-udf-profile.png │ ├── python-sm.png │ ├── scala-sm.png │ ├── spark-connect-api.png │ ├── spark-connect-communication.png │ ├── spark-webui-accumulators.png │ ├── streaming-arch.png │ ├── streaming-dstream-ops.png │ ├── streaming-dstream-window.png │ ├── streaming-dstream.png │ ├── streaming-figures.pptx │ ├── streaming-flow.png │ ├── streaming-kinesis-arch.png │ ├── structured-streaming-example-model.png │ ├── structured-streaming-late-data.png │ ├── structured-streaming-model.png │ ├── structured-streaming-stream-as-a-table.png │ ├── structured-streaming-time-window-types.jpg │ ├── structured-streaming-watermark-append-mode.png │ ├── structured-streaming-watermark-update-mode.png │ ├── structured-streaming-window.png │ ├── structured-streaming.pptx │ ├── triplet.png │ ├── type-precedence-list.png │ ├── vertex_routing_edge_tables.png │ ├── webui-env-class.png │ ├── webui-env-hadoop.png │ ├── webui-env-sys.png │ ├── webui-env-tab.png │ ├── webui-exe-err.png │ ├── webui-exe-tab.png │ ├── webui-exe-thread.png │ ├── webui-sql-dag.png │ ├── webui-sql-plan.png │ ├── webui-sql-tab.png │ ├── webui-storage-detail.png │ ├── webui-storage-tab.png │ ├── webui-structured-streaming-detail.png │ └── webui-structured-streaming-detail2.png ├── index.md ├── job-scheduling.md ├── js │ ├── api-docs.js │ ├── api-javadocs.js │ ├── main.js │ └── vendor │ │ ├── anchor.min.js │ │ ├── bootstrap.bundle.min.js │ │ ├── bootstrap.bundle.min.js.map │ │ ├── docsearch.min.js │ │ ├── jquery.min.js │ │ └── modernizr-2.6.1-respond-1.1.0.min.js ├── migration-guide.md ├── ml-advanced.md ├── ml-ann.md ├── ml-classification-regression.md ├── ml-clustering.md ├── ml-collaborative-filtering.md ├── ml-datasource.md ├── ml-decision-tree.md ├── ml-ensembles.md ├── ml-features.md ├── ml-frequent-pattern-mining.md ├── ml-guide.md ├── ml-linalg-guide.md ├── ml-linear-methods.md ├── ml-migration-guide.md ├── ml-pipeline.md ├── ml-statistics.md ├── ml-survival-regression.md ├── ml-tuning.md ├── mllib-classification-regression.md ├── mllib-clustering.md ├── mllib-collaborative-filtering.md ├── mllib-data-types.md ├── mllib-decision-tree.md ├── mllib-dimensionality-reduction.md ├── mllib-ensembles.md ├── mllib-evaluation-metrics.md ├── mllib-feature-extraction.md ├── mllib-frequent-pattern-mining.md ├── mllib-guide.md ├── mllib-isotonic-regression.md ├── mllib-linear-methods.md ├── mllib-naive-bayes.md ├── mllib-optimization.md ├── mllib-pmml-model-export.md ├── mllib-statistics.md ├── monitoring.md ├── programming-guide.md ├── pyspark-migration-guide.md ├── quick-start.md ├── rdd-programming-guide.md ├── running-on-kubernetes.md ├── running-on-yarn.md ├── security.md ├── spark-connect-overview.md ├── spark-standalone.md ├── sparkr-migration-guide.md ├── sparkr.md ├── sql-data-sources-avro.md ├── sql-data-sources-binaryFile.md ├── sql-data-sources-csv.md ├── sql-data-sources-generic-options.md ├── sql-data-sources-hive-tables.md ├── sql-data-sources-jdbc.md ├── sql-data-sources-json.md ├── sql-data-sources-load-save-functions.md ├── sql-data-sources-orc.md ├── sql-data-sources-parquet.md ├── sql-data-sources-protobuf.md ├── sql-data-sources-text.md ├── sql-data-sources-troubleshooting.md ├── sql-data-sources-xml.md ├── sql-data-sources.md ├── sql-distributed-sql-engine-spark-sql-cli.md ├── sql-distributed-sql-engine.md ├── sql-error-conditions.md ├── sql-getting-started.md ├── sql-migration-guide.md ├── sql-performance-tuning.md ├── sql-pipe-syntax.md ├── sql-programming-guide.md ├── sql-pyspark-pandas-with-arrow.md ├── sql-ref-ansi-compliance.md ├── sql-ref-datatypes.md ├── sql-ref-datetime-pattern.md ├── sql-ref-function-invocation.md ├── sql-ref-functions-builtin.md ├── sql-ref-functions-udf-aggregate.md ├── sql-ref-functions-udf-hive.md ├── sql-ref-functions-udf-scalar.md ├── sql-ref-functions.md ├── sql-ref-identifier-clause.md ├── sql-ref-identifier.md ├── sql-ref-literals.md ├── sql-ref-name-resolution.md ├── sql-ref-null-semantics.md ├── sql-ref-number-pattern.md ├── sql-ref-operators.md ├── sql-ref-parameter-markers.md ├── sql-ref-scripting.md ├── sql-ref-sketch-aggregates.md ├── sql-ref-syntax-aux-analyze-table.md ├── sql-ref-syntax-aux-cache-cache-table.md ├── sql-ref-syntax-aux-cache-clear-cache.md ├── sql-ref-syntax-aux-cache-refresh-function.md ├── sql-ref-syntax-aux-cache-refresh-table.md ├── sql-ref-syntax-aux-cache-refresh.md ├── sql-ref-syntax-aux-cache-uncache-table.md ├── sql-ref-syntax-aux-cache.md ├── sql-ref-syntax-aux-conf-mgmt-reset.md ├── sql-ref-syntax-aux-conf-mgmt-set-timezone.md ├── sql-ref-syntax-aux-conf-mgmt-set.md ├── sql-ref-syntax-aux-conf-mgmt.md ├── sql-ref-syntax-aux-describe-database.md ├── sql-ref-syntax-aux-describe-function.md ├── sql-ref-syntax-aux-describe-query.md ├── sql-ref-syntax-aux-describe-table.md ├── sql-ref-syntax-aux-describe.md ├── sql-ref-syntax-aux-exec-imm.md ├── sql-ref-syntax-aux-resource-mgmt-add-archive.md ├── sql-ref-syntax-aux-resource-mgmt-add-file.md ├── sql-ref-syntax-aux-resource-mgmt-add-jar.md ├── sql-ref-syntax-aux-resource-mgmt-list-archive.md ├── sql-ref-syntax-aux-resource-mgmt-list-file.md ├── sql-ref-syntax-aux-resource-mgmt-list-jar.md ├── sql-ref-syntax-aux-resource-mgmt.md ├── sql-ref-syntax-aux-set-var.md ├── sql-ref-syntax-aux-show-columns.md ├── sql-ref-syntax-aux-show-create-table.md ├── sql-ref-syntax-aux-show-databases.md ├── sql-ref-syntax-aux-show-functions.md ├── sql-ref-syntax-aux-show-partitions.md ├── sql-ref-syntax-aux-show-table.md ├── sql-ref-syntax-aux-show-tables.md ├── sql-ref-syntax-aux-show-tblproperties.md ├── sql-ref-syntax-aux-show-views.md ├── sql-ref-syntax-aux-show.md ├── sql-ref-syntax-ddl-alter-database.md ├── sql-ref-syntax-ddl-alter-table.md ├── sql-ref-syntax-ddl-alter-view.md ├── sql-ref-syntax-ddl-create-database.md ├── sql-ref-syntax-ddl-create-function.md ├── sql-ref-syntax-ddl-create-sql-function.md ├── sql-ref-syntax-ddl-create-table-datasource.md ├── sql-ref-syntax-ddl-create-table-hiveformat.md ├── sql-ref-syntax-ddl-create-table-like.md ├── sql-ref-syntax-ddl-create-table.md ├── sql-ref-syntax-ddl-create-view.md ├── sql-ref-syntax-ddl-declare-variable.md ├── sql-ref-syntax-ddl-drop-database.md ├── sql-ref-syntax-ddl-drop-function.md ├── sql-ref-syntax-ddl-drop-table.md ├── sql-ref-syntax-ddl-drop-variable.md ├── sql-ref-syntax-ddl-drop-view.md ├── sql-ref-syntax-ddl-repair-table.md ├── sql-ref-syntax-ddl-truncate-table.md ├── sql-ref-syntax-ddl-usedb.md ├── sql-ref-syntax-dml-insert-overwrite-directory.md ├── sql-ref-syntax-dml-insert-table.md ├── sql-ref-syntax-dml-load.md ├── sql-ref-syntax-hive-format.md ├── sql-ref-syntax-qry-explain.md ├── sql-ref-syntax-qry-select-aggregate.md ├── sql-ref-syntax-qry-select-case.md ├── sql-ref-syntax-qry-select-clusterby.md ├── sql-ref-syntax-qry-select-cte.md ├── sql-ref-syntax-qry-select-distribute-by.md ├── sql-ref-syntax-qry-select-file.md ├── sql-ref-syntax-qry-select-groupby.md ├── sql-ref-syntax-qry-select-having.md ├── sql-ref-syntax-qry-select-hints.md ├── sql-ref-syntax-qry-select-inline-table.md ├── sql-ref-syntax-qry-select-join.md ├── sql-ref-syntax-qry-select-lateral-subquery.md ├── sql-ref-syntax-qry-select-lateral-view.md ├── sql-ref-syntax-qry-select-like.md ├── sql-ref-syntax-qry-select-limit.md ├── sql-ref-syntax-qry-select-offset.md ├── sql-ref-syntax-qry-select-orderby.md ├── sql-ref-syntax-qry-select-pivot.md ├── sql-ref-syntax-qry-select-sampling.md ├── sql-ref-syntax-qry-select-setops.md ├── sql-ref-syntax-qry-select-sortby.md ├── sql-ref-syntax-qry-select-subqueries.md ├── sql-ref-syntax-qry-select-transform.md ├── sql-ref-syntax-qry-select-tvf.md ├── sql-ref-syntax-qry-select-unpivot.md ├── sql-ref-syntax-qry-select-where.md ├── sql-ref-syntax-qry-select-window.md ├── sql-ref-syntax-qry-select.md ├── sql-ref-syntax-qry-star.md ├── sql-ref-syntax.md ├── sql-ref.md ├── ss-migration-guide.md ├── storage-openstack-swift.md ├── streaming-custom-receivers.md ├── streaming-kafka-0-10-integration.md ├── streaming-kafka-integration.md ├── streaming-kinesis-integration.md ├── streaming-programming-guide.md ├── streaming │ ├── additional-information.md │ ├── apis-on-dataframes-and-datasets.md │ ├── getting-started.md │ ├── index.md │ ├── performance-tips.md │ ├── ss-migration-guide.md │ ├── structured-streaming-kafka-integration.md │ ├── structured-streaming-state-data-source.md │ └── structured-streaming-transform-with-state.md ├── structured-streaming-kafka-integration.md ├── structured-streaming-programming-guide.md ├── submitting-applications.md ├── tuning.md └── web-ui.md ├── examples ├── pom.xml └── src │ └── main │ ├── java │ └── org │ │ └── apache │ │ └── spark │ │ └── examples │ │ ├── JavaHdfsLR.java │ │ ├── JavaLogQuery.java │ │ ├── JavaPageRank.java │ │ ├── JavaSparkPi.java │ │ ├── JavaStatusTrackerDemo.java │ │ ├── JavaTC.java │ │ ├── JavaWordCount.java │ │ ├── ml │ │ ├── JavaAFTSurvivalRegressionExample.java │ │ ├── JavaALSExample.java │ │ ├── JavaBinarizerExample.java │ │ ├── JavaBisectingKMeansExample.java │ │ ├── JavaBucketedRandomProjectionLSHExample.java │ │ ├── JavaBucketizerExample.java │ │ ├── JavaChiSqSelectorExample.java │ │ ├── JavaChiSquareTestExample.java │ │ ├── JavaCorrelationExample.java │ │ ├── JavaCountVectorizerExample.java │ │ ├── JavaDCTExample.java │ │ ├── JavaDecisionTreeClassificationExample.java │ │ ├── JavaDecisionTreeRegressionExample.java │ │ ├── JavaDocument.java │ │ ├── JavaElementwiseProductExample.java │ │ ├── JavaEstimatorTransformerParamExample.java │ │ ├── JavaFMClassifierExample.java │ │ ├── JavaFMRegressorExample.java │ │ ├── JavaFPGrowthExample.java │ │ ├── JavaFeatureHasherExample.java │ │ ├── JavaGaussianMixtureExample.java │ │ ├── JavaGeneralizedLinearRegressionExample.java │ │ ├── JavaGradientBoostedTreeClassifierExample.java │ │ ├── JavaGradientBoostedTreeRegressorExample.java │ │ ├── JavaImputerExample.java │ │ ├── JavaIndexToStringExample.java │ │ ├── JavaInteractionExample.java │ │ ├── JavaIsotonicRegressionExample.java │ │ ├── JavaKMeansExample.java │ │ ├── JavaLDAExample.java │ │ ├── JavaLabeledDocument.java │ │ ├── JavaLinearRegressionWithElasticNetExample.java │ │ ├── JavaLinearSVCExample.java │ │ ├── JavaLogisticRegressionSummaryExample.java │ │ ├── JavaLogisticRegressionWithElasticNetExample.java │ │ ├── JavaMaxAbsScalerExample.java │ │ ├── JavaMinHashLSHExample.java │ │ ├── JavaMinMaxScalerExample.java │ │ ├── JavaModelSelectionViaCrossValidationExample.java │ │ ├── JavaModelSelectionViaTrainValidationSplitExample.java │ │ ├── JavaMulticlassLogisticRegressionWithElasticNetExample.java │ │ ├── JavaMultilayerPerceptronClassifierExample.java │ │ ├── JavaNGramExample.java │ │ ├── JavaNaiveBayesExample.java │ │ ├── JavaNormalizerExample.java │ │ ├── JavaOneHotEncoderExample.java │ │ ├── JavaOneVsRestExample.java │ │ ├── JavaPCAExample.java │ │ ├── JavaPipelineExample.java │ │ ├── JavaPolynomialExpansionExample.java │ │ ├── JavaPowerIterationClusteringExample.java │ │ ├── JavaPrefixSpanExample.java │ │ ├── JavaQuantileDiscretizerExample.java │ │ ├── JavaRFormulaExample.java │ │ ├── JavaRandomForestClassifierExample.java │ │ ├── JavaRandomForestRegressorExample.java │ │ ├── JavaRobustScalerExample.java │ │ ├── JavaSQLTransformerExample.java │ │ ├── JavaStandardScalerExample.java │ │ ├── JavaStopWordsRemoverExample.java │ │ ├── JavaStringIndexerExample.java │ │ ├── JavaSummarizerExample.java │ │ ├── JavaTargetEncoderExample.java │ │ ├── JavaTfIdfExample.java │ │ ├── JavaTokenizerExample.java │ │ ├── JavaUnivariateFeatureSelectorExample.java │ │ ├── JavaVarianceThresholdSelectorExample.java │ │ ├── JavaVectorAssemblerExample.java │ │ ├── JavaVectorIndexerExample.java │ │ ├── JavaVectorSizeHintExample.java │ │ ├── JavaVectorSlicerExample.java │ │ └── JavaWord2VecExample.java │ │ ├── mllib │ │ ├── JavaALS.java │ │ ├── JavaAssociationRulesExample.java │ │ ├── JavaBinaryClassificationMetricsExample.java │ │ ├── JavaBisectingKMeansExample.java │ │ ├── JavaChiSqSelectorExample.java │ │ ├── JavaCorrelationsExample.java │ │ ├── JavaDecisionTreeClassificationExample.java │ │ ├── JavaDecisionTreeRegressionExample.java │ │ ├── JavaElementwiseProductExample.java │ │ ├── JavaGaussianMixtureExample.java │ │ ├── JavaGradientBoostingClassificationExample.java │ │ ├── JavaGradientBoostingRegressionExample.java │ │ ├── JavaHypothesisTestingExample.java │ │ ├── JavaHypothesisTestingKolmogorovSmirnovTestExample.java │ │ ├── JavaIsotonicRegressionExample.java │ │ ├── JavaKMeansExample.java │ │ ├── JavaKernelDensityEstimationExample.java │ │ ├── JavaLBFGSExample.java │ │ ├── JavaLatentDirichletAllocationExample.java │ │ ├── JavaLogisticRegressionWithLBFGSExample.java │ │ ├── JavaMultiLabelClassificationMetricsExample.java │ │ ├── JavaMulticlassClassificationMetricsExample.java │ │ ├── JavaNaiveBayesExample.java │ │ ├── JavaPCAExample.java │ │ ├── JavaPowerIterationClusteringExample.java │ │ ├── JavaPrefixSpanExample.java │ │ ├── JavaRandomForestClassificationExample.java │ │ ├── JavaRandomForestRegressionExample.java │ │ ├── JavaRankingMetricsExample.java │ │ ├── JavaRecommendationExample.java │ │ ├── JavaSVDExample.java │ │ ├── JavaSVMWithSGDExample.java │ │ ├── JavaSimpleFPGrowth.java │ │ ├── JavaStratifiedSamplingExample.java │ │ ├── JavaStreamingTestExample.java │ │ └── JavaSummaryStatisticsExample.java │ │ ├── sql │ │ ├── JavaSQLDataSourceExample.java │ │ ├── JavaSparkSQLCli.java │ │ ├── JavaSparkSQLExample.java │ │ ├── JavaUserDefinedScalar.java │ │ ├── JavaUserDefinedTypedAggregation.java │ │ ├── JavaUserDefinedUntypedAggregation.java │ │ ├── hive │ │ │ └── JavaSparkHiveExample.java │ │ └── streaming │ │ │ ├── JavaStructuredComplexSessionization.java │ │ │ ├── JavaStructuredKafkaWordCount.java │ │ │ ├── JavaStructuredKerberizedKafkaWordCount.java │ │ │ ├── JavaStructuredNetworkWordCount.java │ │ │ ├── JavaStructuredNetworkWordCountWindowed.java │ │ │ └── JavaStructuredSessionization.java │ │ └── streaming │ │ ├── JavaCustomReceiver.java │ │ ├── JavaDirectKafkaWordCount.java │ │ ├── JavaDirectKerberizedKafkaWordCount.java │ │ ├── JavaNetworkWordCount.java │ │ ├── JavaQueueStream.java │ │ ├── JavaRecord.java │ │ ├── JavaRecoverableNetworkWordCount.java │ │ ├── JavaSqlNetworkWordCount.java │ │ └── JavaStatefulNetworkWordCount.java │ ├── python │ ├── __init__.py │ ├── als.py │ ├── avro_inputformat.py │ ├── kmeans.py │ ├── logistic_regression.py │ ├── ml │ │ ├── __init__,py │ │ ├── aft_survival_regression.py │ │ ├── als_example.py │ │ ├── binarizer_example.py │ │ ├── bisecting_k_means_example.py │ │ ├── bucketed_random_projection_lsh_example.py │ │ ├── bucketizer_example.py │ │ ├── chi_square_test_example.py │ │ ├── chisq_selector_example.py │ │ ├── correlation_example.py │ │ ├── count_vectorizer_example.py │ │ ├── cross_validator.py │ │ ├── dataframe_example.py │ │ ├── dct_example.py │ │ ├── decision_tree_classification_example.py │ │ ├── decision_tree_regression_example.py │ │ ├── elementwise_product_example.py │ │ ├── estimator_transformer_param_example.py │ │ ├── feature_hasher_example.py │ │ ├── fm_classifier_example.py │ │ ├── fm_regressor_example.py │ │ ├── fpgrowth_example.py │ │ ├── gaussian_mixture_example.py │ │ ├── generalized_linear_regression_example.py │ │ ├── gradient_boosted_tree_classifier_example.py │ │ ├── gradient_boosted_tree_regressor_example.py │ │ ├── imputer_example.py │ │ ├── index_to_string_example.py │ │ ├── interaction_example.py │ │ ├── isotonic_regression_example.py │ │ ├── kmeans_example.py │ │ ├── lda_example.py │ │ ├── linear_regression_with_elastic_net.py │ │ ├── linearsvc.py │ │ ├── logistic_regression_summary_example.py │ │ ├── logistic_regression_with_elastic_net.py │ │ ├── max_abs_scaler_example.py │ │ ├── min_hash_lsh_example.py │ │ ├── min_max_scaler_example.py │ │ ├── multiclass_logistic_regression_with_elastic_net.py │ │ ├── multilayer_perceptron_classification.py │ │ ├── n_gram_example.py │ │ ├── naive_bayes_example.py │ │ ├── normalizer_example.py │ │ ├── one_vs_rest_example.py │ │ ├── onehot_encoder_example.py │ │ ├── pca_example.py │ │ ├── pipeline_example.py │ │ ├── polynomial_expansion_example.py │ │ ├── power_iteration_clustering_example.py │ │ ├── prefixspan_example.py │ │ ├── quantile_discretizer_example.py │ │ ├── random_forest_classifier_example.py │ │ ├── random_forest_regressor_example.py │ │ ├── rformula_example.py │ │ ├── robust_scaler_example.py │ │ ├── sql_transformer.py │ │ ├── standard_scaler_example.py │ │ ├── stopwords_remover_example.py │ │ ├── string_indexer_example.py │ │ ├── summarizer_example.py │ │ ├── target_encoder_example.py │ │ ├── tf_idf_example.py │ │ ├── tokenizer_example.py │ │ ├── train_validation_split.py │ │ ├── univariate_feature_selector_example.py │ │ ├── variance_threshold_selector_example.py │ │ ├── vector_assembler_example.py │ │ ├── vector_indexer_example.py │ │ ├── vector_size_hint_example.py │ │ ├── vector_slicer_example.py │ │ └── word2vec_example.py │ ├── mllib │ │ ├── __init__.py │ │ ├── binary_classification_metrics_example.py │ │ ├── bisecting_k_means_example.py │ │ ├── correlations.py │ │ ├── correlations_example.py │ │ ├── decision_tree_classification_example.py │ │ ├── decision_tree_regression_example.py │ │ ├── elementwise_product_example.py │ │ ├── fpgrowth_example.py │ │ ├── gaussian_mixture_example.py │ │ ├── gaussian_mixture_model.py │ │ ├── gradient_boosting_classification_example.py │ │ ├── gradient_boosting_regression_example.py │ │ ├── hypothesis_testing_example.py │ │ ├── hypothesis_testing_kolmogorov_smirnov_test_example.py │ │ ├── isotonic_regression_example.py │ │ ├── k_means_example.py │ │ ├── kernel_density_estimation_example.py │ │ ├── kmeans.py │ │ ├── latent_dirichlet_allocation_example.py │ │ ├── linear_regression_with_sgd_example.py │ │ ├── logistic_regression.py │ │ ├── logistic_regression_with_lbfgs_example.py │ │ ├── multi_class_metrics_example.py │ │ ├── multi_label_metrics_example.py │ │ ├── naive_bayes_example.py │ │ ├── normalizer_example.py │ │ ├── pca_rowmatrix_example.py │ │ ├── power_iteration_clustering_example.py │ │ ├── random_forest_classification_example.py │ │ ├── random_forest_regression_example.py │ │ ├── random_rdd_generation.py │ │ ├── ranking_metrics_example.py │ │ ├── recommendation_example.py │ │ ├── regression_metrics_example.py │ │ ├── sampled_rdds.py │ │ ├── standard_scaler_example.py │ │ ├── stratified_sampling_example.py │ │ ├── streaming_k_means_example.py │ │ ├── streaming_linear_regression_example.py │ │ ├── summary_statistics_example.py │ │ ├── svd_example.py │ │ ├── svm_with_sgd_example.py │ │ ├── tf_idf_example.py │ │ ├── word2vec.py │ │ └── word2vec_example.py │ ├── pagerank.py │ ├── parquet_inputformat.py │ ├── pi.py │ ├── sort.py │ ├── sql │ │ ├── __init__.py │ │ ├── arrow.py │ │ ├── basic.py │ │ ├── datasource.py │ │ ├── hive.py │ │ ├── streaming │ │ │ ├── __init__,py │ │ │ ├── structured_kafka_wordcount.py │ │ │ ├── structured_network_wordcount.py │ │ │ ├── structured_network_wordcount_session_window.py │ │ │ ├── structured_network_wordcount_windowed.py │ │ │ └── structured_sessionization.py │ │ └── udtf.py │ ├── status_api_demo.py │ ├── streaming │ │ ├── __init__.py │ │ ├── hdfs_wordcount.py │ │ ├── network_wordcount.py │ │ ├── network_wordjoinsentiments.py │ │ ├── queue_stream.py │ │ ├── recoverable_network_wordcount.py │ │ ├── sql_network_wordcount.py │ │ └── stateful_network_wordcount.py │ ├── transitive_closure.py │ └── wordcount.py │ ├── r │ ├── RSparkSQLExample.R │ ├── data-manipulation.R │ ├── dataframe.R │ ├── ml │ │ ├── als.R │ │ ├── bisectingKmeans.R │ │ ├── decisionTree.R │ │ ├── fmClassifier.R │ │ ├── fmRegressor.R │ │ ├── fpm.R │ │ ├── gaussianMixture.R │ │ ├── gbt.R │ │ ├── glm.R │ │ ├── isoreg.R │ │ ├── kmeans.R │ │ ├── kstest.R │ │ ├── lda.R │ │ ├── lm_with_elastic_net.R │ │ ├── logit.R │ │ ├── ml.R │ │ ├── mlp.R │ │ ├── naiveBayes.R │ │ ├── powerIterationClustering.R │ │ ├── prefixSpan.R │ │ ├── randomForest.R │ │ ├── survreg.R │ │ └── svmLinear.R │ └── streaming │ │ └── structured_network_wordcount.R │ ├── resources │ ├── META-INF │ │ └── services │ │ │ ├── org.apache.spark.sql.SparkSessionExtensionsProvider │ │ │ └── org.apache.spark.sql.jdbc.JdbcConnectionProvider │ ├── dir1 │ │ ├── dir2 │ │ │ └── file2.parquet │ │ ├── file1.parquet │ │ └── file3.json │ ├── employees.json │ ├── full_user.avsc │ ├── kv1.txt │ ├── people.csv │ ├── people.json │ ├── people.txt │ ├── people.xml │ ├── user.avsc │ ├── users.avro │ ├── users.orc │ └── users.parquet │ ├── scala │ └── org │ │ └── apache │ │ └── spark │ │ └── examples │ │ ├── AccumulatorMetricsTest.scala │ │ ├── BroadcastTest.scala │ │ ├── DFSReadWriteTest.scala │ │ ├── DriverSubmissionTest.scala │ │ ├── ExceptionHandlingTest.scala │ │ ├── GroupByTest.scala │ │ ├── HdfsTest.scala │ │ ├── LocalALS.scala │ │ ├── LocalFileLR.scala │ │ ├── LocalKMeans.scala │ │ ├── LocalLR.scala │ │ ├── LocalPi.scala │ │ ├── LogQuery.scala │ │ ├── MiniReadWriteTest.scala │ │ ├── MultiBroadcastTest.scala │ │ ├── SimpleSkewedGroupByTest.scala │ │ ├── SkewedGroupByTest.scala │ │ ├── SparkALS.scala │ │ ├── SparkHdfsLR.scala │ │ ├── SparkKMeans.scala │ │ ├── SparkLR.scala │ │ ├── SparkPageRank.scala │ │ ├── SparkPi.scala │ │ ├── SparkRemoteFileTest.scala │ │ ├── SparkTC.scala │ │ ├── extensions │ │ ├── AgeExample.scala │ │ ├── SessionExtensionsWithLoader.scala │ │ ├── SessionExtensionsWithoutLoader.scala │ │ └── SparkSessionExtensionsTest.scala │ │ ├── graphx │ │ ├── AggregateMessagesExample.scala │ │ ├── Analytics.scala │ │ ├── ComprehensiveExample.scala │ │ ├── ConnectedComponentsExample.scala │ │ ├── LiveJournalPageRank.scala │ │ ├── PageRankExample.scala │ │ ├── SSSPExample.scala │ │ ├── SynthBenchmark.scala │ │ └── TriangleCountingExample.scala │ │ ├── ml │ │ ├── AFTSurvivalRegressionExample.scala │ │ ├── ALSExample.scala │ │ ├── BinarizerExample.scala │ │ ├── BisectingKMeansExample.scala │ │ ├── BucketedRandomProjectionLSHExample.scala │ │ ├── BucketizerExample.scala │ │ ├── ChiSqSelectorExample.scala │ │ ├── ChiSquareTestExample.scala │ │ ├── CorrelationExample.scala │ │ ├── CountVectorizerExample.scala │ │ ├── DCTExample.scala │ │ ├── DataFrameExample.scala │ │ ├── DecisionTreeClassificationExample.scala │ │ ├── DecisionTreeExample.scala │ │ ├── DecisionTreeRegressionExample.scala │ │ ├── DeveloperApiExample.scala │ │ ├── ElementwiseProductExample.scala │ │ ├── EstimatorTransformerParamExample.scala │ │ ├── FMClassifierExample.scala │ │ ├── FMRegressorExample.scala │ │ ├── FPGrowthExample.scala │ │ ├── FeatureHasherExample.scala │ │ ├── GBTExample.scala │ │ ├── GaussianMixtureExample.scala │ │ ├── GeneralizedLinearRegressionExample.scala │ │ ├── GradientBoostedTreeClassifierExample.scala │ │ ├── GradientBoostedTreeRegressorExample.scala │ │ ├── ImputerExample.scala │ │ ├── IndexToStringExample.scala │ │ ├── InteractionExample.scala │ │ ├── IsotonicRegressionExample.scala │ │ ├── KMeansExample.scala │ │ ├── LDAExample.scala │ │ ├── LinearRegressionExample.scala │ │ ├── LinearRegressionWithElasticNetExample.scala │ │ ├── LinearSVCExample.scala │ │ ├── LogisticRegressionExample.scala │ │ ├── LogisticRegressionSummaryExample.scala │ │ ├── LogisticRegressionWithElasticNetExample.scala │ │ ├── MaxAbsScalerExample.scala │ │ ├── MinHashLSHExample.scala │ │ ├── MinMaxScalerExample.scala │ │ ├── ModelSelectionViaCrossValidationExample.scala │ │ ├── ModelSelectionViaTrainValidationSplitExample.scala │ │ ├── MulticlassLogisticRegressionWithElasticNetExample.scala │ │ ├── MultilayerPerceptronClassifierExample.scala │ │ ├── NGramExample.scala │ │ ├── NaiveBayesExample.scala │ │ ├── NormalizerExample.scala │ │ ├── OneHotEncoderExample.scala │ │ ├── OneVsRestExample.scala │ │ ├── PCAExample.scala │ │ ├── PipelineExample.scala │ │ ├── PolynomialExpansionExample.scala │ │ ├── PowerIterationClusteringExample.scala │ │ ├── PrefixSpanExample.scala │ │ ├── QuantileDiscretizerExample.scala │ │ ├── RFormulaExample.scala │ │ ├── RandomForestClassifierExample.scala │ │ ├── RandomForestExample.scala │ │ ├── RandomForestRegressorExample.scala │ │ ├── RobustScalerExample.scala │ │ ├── SQLTransformerExample.scala │ │ ├── StandardScalerExample.scala │ │ ├── StopWordsRemoverExample.scala │ │ ├── StringIndexerExample.scala │ │ ├── SummarizerExample.scala │ │ ├── TargetEncoderExample.scala │ │ ├── TfIdfExample.scala │ │ ├── TokenizerExample.scala │ │ ├── UnaryTransformerExample.scala │ │ ├── UnivariateFeatureSelectorExample.scala │ │ ├── VarianceThresholdSelectorExample.scala │ │ ├── VectorAssemblerExample.scala │ │ ├── VectorIndexerExample.scala │ │ ├── VectorSizeHintExample.scala │ │ ├── VectorSlicerExample.scala │ │ └── Word2VecExample.scala │ │ ├── mllib │ │ ├── AbstractParams.scala │ │ ├── AssociationRulesExample.scala │ │ ├── BinaryClassification.scala │ │ ├── BinaryClassificationMetricsExample.scala │ │ ├── BisectingKMeansExample.scala │ │ ├── ChiSqSelectorExample.scala │ │ ├── Correlations.scala │ │ ├── CorrelationsExample.scala │ │ ├── CosineSimilarity.scala │ │ ├── DecisionTreeClassificationExample.scala │ │ ├── DecisionTreeRegressionExample.scala │ │ ├── DecisionTreeRunner.scala │ │ ├── DenseKMeans.scala │ │ ├── ElementwiseProductExample.scala │ │ ├── FPGrowthExample.scala │ │ ├── GaussianMixtureExample.scala │ │ ├── GradientBoostedTreesRunner.scala │ │ ├── GradientBoostingClassificationExample.scala │ │ ├── GradientBoostingRegressionExample.scala │ │ ├── HypothesisTestingExample.scala │ │ ├── HypothesisTestingKolmogorovSmirnovTestExample.scala │ │ ├── IsotonicRegressionExample.scala │ │ ├── KMeansExample.scala │ │ ├── KernelDensityEstimationExample.scala │ │ ├── LBFGSExample.scala │ │ ├── LDAExample.scala │ │ ├── LatentDirichletAllocationExample.scala │ │ ├── LogisticRegressionWithLBFGSExample.scala │ │ ├── MovieLensALS.scala │ │ ├── MultiLabelMetricsExample.scala │ │ ├── MulticlassMetricsExample.scala │ │ ├── MultivariateSummarizer.scala │ │ ├── NaiveBayesExample.scala │ │ ├── NormalizerExample.scala │ │ ├── PCAOnRowMatrixExample.scala │ │ ├── PCAOnSourceVectorExample.scala │ │ ├── PMMLModelExportExample.scala │ │ ├── PowerIterationClusteringExample.scala │ │ ├── PrefixSpanExample.scala │ │ ├── RandomForestClassificationExample.scala │ │ ├── RandomForestRegressionExample.scala │ │ ├── RandomRDDGeneration.scala │ │ ├── RankingMetricsExample.scala │ │ ├── RecommendationExample.scala │ │ ├── SVDExample.scala │ │ ├── SVMWithSGDExample.scala │ │ ├── SampledRDDs.scala │ │ ├── SimpleFPGrowth.scala │ │ ├── SparseNaiveBayes.scala │ │ ├── StandardScalerExample.scala │ │ ├── StratifiedSamplingExample.scala │ │ ├── StreamingKMeansExample.scala │ │ ├── StreamingLinearRegressionExample.scala │ │ ├── StreamingLogisticRegression.scala │ │ ├── StreamingTestExample.scala │ │ ├── SummaryStatisticsExample.scala │ │ ├── TFIDFExample.scala │ │ ├── TallSkinnyPCA.scala │ │ ├── TallSkinnySVD.scala │ │ └── Word2VecExample.scala │ │ ├── pythonconverters │ │ └── AvroConverters.scala │ │ ├── sql │ │ ├── RDDRelation.scala │ │ ├── SQLDataSourceExample.scala │ │ ├── SimpleTypedAggregator.scala │ │ ├── SparkDataFramePi.scala │ │ ├── SparkSQLExample.scala │ │ ├── UserDefinedScalar.scala │ │ ├── UserDefinedTypedAggregation.scala │ │ ├── UserDefinedUntypedAggregation.scala │ │ ├── hive │ │ │ └── SparkHiveExample.scala │ │ ├── jdbc │ │ │ └── ExampleJdbcConnectionProvider.scala │ │ └── streaming │ │ │ ├── StructuredComplexSessionization.scala │ │ │ ├── StructuredKafkaWordCount.scala │ │ │ ├── StructuredKerberizedKafkaWordCount.scala │ │ │ ├── StructuredNetworkWordCount.scala │ │ │ ├── StructuredNetworkWordCountWindowed.scala │ │ │ └── StructuredSessionization.scala │ │ └── streaming │ │ ├── CustomReceiver.scala │ │ ├── DirectKafkaWordCount.scala │ │ ├── DirectKerberizedKafkaWordCount.scala │ │ ├── HdfsWordCount.scala │ │ ├── NetworkWordCount.scala │ │ ├── QueueStream.scala │ │ ├── RawNetworkGrep.scala │ │ ├── RecoverableNetworkWordCount.scala │ │ ├── SqlNetworkWordCount.scala │ │ ├── StatefulNetworkWordCount.scala │ │ ├── StreamingExamples.scala │ │ └── clickstream │ │ ├── PageViewGenerator.scala │ │ └── PageViewStream.scala │ └── scripts │ ├── getGpusResources.sh │ ├── submit-pi.sh │ └── submit-sql.sh ├── graphx ├── pom.xml └── src │ ├── main │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── graphx │ │ │ ├── TripletFields.java │ │ │ └── impl │ │ │ └── EdgeActiveness.java │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── graphx │ │ ├── Edge.scala │ │ ├── EdgeContext.scala │ │ ├── EdgeDirection.scala │ │ ├── EdgeRDD.scala │ │ ├── EdgeTriplet.scala │ │ ├── Graph.scala │ │ ├── GraphLoader.scala │ │ ├── GraphOps.scala │ │ ├── GraphXUtils.scala │ │ ├── PartitionStrategy.scala │ │ ├── Pregel.scala │ │ ├── VertexRDD.scala │ │ ├── impl │ │ ├── EdgePartition.scala │ │ ├── EdgePartitionBuilder.scala │ │ ├── EdgeRDDImpl.scala │ │ ├── GraphImpl.scala │ │ ├── ReplicatedVertexView.scala │ │ ├── RoutingTablePartition.scala │ │ ├── ShippableVertexPartition.scala │ │ ├── VertexPartition.scala │ │ ├── VertexPartitionBase.scala │ │ ├── VertexPartitionBaseOps.scala │ │ ├── VertexRDDImpl.scala │ │ └── package.scala │ │ ├── lib │ │ ├── ConnectedComponents.scala │ │ ├── LabelPropagation.scala │ │ ├── PageRank.scala │ │ ├── SVDPlusPlus.scala │ │ ├── ShortestPaths.scala │ │ ├── StronglyConnectedComponents.scala │ │ ├── TriangleCount.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── package-info.java │ │ ├── package.scala │ │ └── util │ │ ├── GraphGenerators.scala │ │ ├── PeriodicGraphCheckpointer.scala │ │ ├── collection │ │ └── GraphXPrimitiveKeyOpenHashMap.scala │ │ ├── package-info.java │ │ └── package.scala │ └── test │ ├── resources │ ├── als-test.data │ └── log4j2.properties │ └── scala │ └── org │ └── apache │ └── spark │ └── graphx │ ├── EdgeRDDSuite.scala │ ├── EdgeSuite.scala │ ├── GraphLoaderSuite.scala │ ├── GraphOpsSuite.scala │ ├── GraphSuite.scala │ ├── LocalSparkContext.scala │ ├── PregelSuite.scala │ ├── VertexRDDSuite.scala │ ├── impl │ ├── EdgePartitionSuite.scala │ └── VertexPartitionSuite.scala │ ├── lib │ ├── ConnectedComponentsSuite.scala │ ├── LabelPropagationSuite.scala │ ├── PageRankSuite.scala │ ├── SVDPlusPlusSuite.scala │ ├── ShortestPathsSuite.scala │ ├── StronglyConnectedComponentsSuite.scala │ └── TriangleCountSuite.scala │ └── util │ ├── GraphGeneratorsSuite.scala │ └── PeriodicGraphCheckpointerSuite.scala ├── hadoop-cloud ├── README.md ├── pom.xml └── src │ ├── main │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── internal │ │ └── io │ │ └── cloud │ │ ├── AbortableStreamBasedCheckpointFileManager.scala │ │ ├── BindingParquetOutputCommitter.scala │ │ └── PathOutputCommitProtocol.scala │ └── test │ ├── java │ └── org │ │ └── apache │ │ └── spark │ │ └── internal │ │ └── io │ │ └── cloud │ │ ├── IntegrationTestSuite.java │ │ └── abortable │ │ ├── AbortableFileSystem.java │ │ └── AbstractAbortableFileSystem.java │ ├── resources │ └── log4j2.properties │ └── scala │ └── org │ └── apache │ └── spark │ ├── SparkContextSuite.scala │ └── internal │ └── io │ └── cloud │ ├── AbortableStreamBasedCheckpointFileManagerSuite.scala │ ├── CommitterBindingSuite.scala │ └── StubPathOutputCommitter.scala ├── launcher ├── pom.xml └── src │ ├── main │ └── java │ │ └── org │ │ └── apache │ │ └── spark │ │ └── launcher │ │ ├── AbstractAppHandle.java │ │ ├── AbstractCommandBuilder.java │ │ ├── AbstractLauncher.java │ │ ├── ChildProcAppHandle.java │ │ ├── CommandBuilderUtils.java │ │ ├── FilteredObjectInputStream.java │ │ ├── InProcessAppHandle.java │ │ ├── InProcessLauncher.java │ │ ├── JavaModuleOptions.java │ │ ├── LauncherConnection.java │ │ ├── LauncherProtocol.java │ │ ├── LauncherServer.java │ │ ├── Main.java │ │ ├── NamedThreadFactory.java │ │ ├── OutputRedirector.java │ │ ├── SparkAppHandle.java │ │ ├── SparkClassCommandBuilder.java │ │ ├── SparkLauncher.java │ │ ├── SparkSubmitCommandBuilder.java │ │ ├── SparkSubmitOptionParser.java │ │ └── package-info.java │ └── test │ ├── java │ └── org │ │ └── apache │ │ └── spark │ │ └── launcher │ │ ├── BaseSuite.java │ │ ├── ChildProcAppHandleSuite.java │ │ ├── CommandBuilderUtilsSuite.java │ │ ├── InProcessLauncherSuite.java │ │ ├── LauncherServerSuite.java │ │ ├── SparkClassCommandBuilderSuite.java │ │ ├── SparkSubmitCommandBuilderSuite.java │ │ └── SparkSubmitOptionParserSuite.java │ └── resources │ ├── log4j2.properties │ └── spark-defaults.conf ├── licenses-binary ├── LICENSE-AnchorJS.txt ├── LICENSE-CC0.txt ├── LICENSE-JLargeArrays.txt ├── LICENSE-JTransforms.txt ├── LICENSE-antlr.txt ├── LICENSE-arpack.txt ├── LICENSE-automaton.txt ├── LICENSE-blas.txt ├── LICENSE-bootstrap.txt ├── LICENSE-cloudpickle.txt ├── LICENSE-d3.min.js.txt ├── LICENSE-dagre-d3.txt ├── LICENSE-datatables.txt ├── LICENSE-dnsjava.txt ├── LICENSE-f2j.txt ├── LICENSE-graphlib-dot.txt ├── LICENSE-icu4j.txt ├── LICENSE-istack-commons-runtime.txt ├── LICENSE-jakarta-annotation-api ├── LICENSE-jakarta-servlet-api.txt ├── LICENSE-jakarta-ws-rs-api ├── LICENSE-jakarta.activation-api.txt ├── LICENSE-jakarta.xml.bind-api.txt ├── LICENSE-janino.txt ├── LICENSE-javassist.html ├── LICENSE-javax-transaction-transaction-api.txt ├── LICENSE-javolution.txt ├── LICENSE-jaxb-runtime.txt ├── LICENSE-jline.txt ├── LICENSE-jline3.txt ├── LICENSE-join.txt ├── LICENSE-jquery.txt ├── LICENSE-json-formatter.txt ├── LICENSE-jsp-api.txt ├── LICENSE-kryo.txt ├── LICENSE-leveldbjni.txt ├── LICENSE-loose-version.txt ├── LICENSE-machinist.txt ├── LICENSE-matchMedia-polyfill.txt ├── LICENSE-minlog.txt ├── LICENSE-modernizr.txt ├── LICENSE-mustache.txt ├── LICENSE-paranamer.txt ├── LICENSE-pmml-model.txt ├── LICENSE-protobuf.txt ├── LICENSE-py4j.txt ├── LICENSE-pyrolite.txt ├── LICENSE-re2j.txt ├── LICENSE-reflectasm.txt ├── LICENSE-respond.txt ├── LICENSE-sbt-launch-lib.txt ├── LICENSE-scopt.txt ├── LICENSE-slf4j.txt ├── LICENSE-sorttable.js.txt ├── LICENSE-spire.txt ├── LICENSE-vis-timeline.txt ├── LICENSE-xmlenc.txt ├── LICENSE-xz.txt ├── LICENSE-zstd-jni.txt └── LICENSE-zstd.txt ├── licenses ├── LICENSE-AnchorJS.txt ├── LICENSE-CC0.txt ├── LICENSE-bootstrap.txt ├── LICENSE-cloudpickle.txt ├── LICENSE-d3.min.js.txt ├── LICENSE-dagre-d3.txt ├── LICENSE-datatables.txt ├── LICENSE-graphlib-dot.txt ├── LICENSE-jdom.txt ├── LICENSE-join.txt ├── LICENSE-jquery.txt ├── LICENSE-json-formatter.txt ├── LICENSE-loose-version.txt ├── LICENSE-matchMedia-polyfill.txt ├── LICENSE-modernizr.txt ├── LICENSE-mustache.txt ├── LICENSE-py4j.txt ├── LICENSE-respond.txt ├── LICENSE-sbt-launch-lib.txt ├── LICENSE-sorttable.js.txt ├── LICENSE-vis-timeline.txt └── LICENSE-xz.txt ├── mllib-local ├── benchmarks │ ├── BLASBenchmark-jdk21-results.txt │ └── BLASBenchmark-results.txt ├── pom.xml └── src │ ├── main │ └── scala │ │ ├── org │ │ └── apache │ │ │ └── spark │ │ │ └── ml │ │ │ ├── impl │ │ │ └── Utils.scala │ │ │ ├── linalg │ │ │ ├── BLAS.scala │ │ │ ├── Matrices.scala │ │ │ └── Vectors.scala │ │ │ └── stat │ │ │ └── distribution │ │ │ └── MultivariateGaussian.scala │ │ └── scala │ │ └── collection │ │ └── compat │ │ └── package.scala │ └── test │ └── scala │ └── org │ └── apache │ └── spark │ └── ml │ ├── SparkMLFunSuite.scala │ ├── impl │ └── UtilsSuite.scala │ ├── linalg │ ├── BLASBenchmark.scala │ ├── BLASSuite.scala │ ├── BreezeMatrixConversionSuite.scala │ ├── BreezeVectorConversionSuite.scala │ ├── MatricesSuite.scala │ └── VectorsSuite.scala │ ├── stat │ └── distribution │ │ └── MultivariateGaussianSuite.scala │ └── util │ ├── TestingUtils.scala │ └── TestingUtilsSuite.scala ├── mllib ├── benchmarks │ ├── UDTSerializationBenchmark-jdk21-results.txt │ └── UDTSerializationBenchmark-results.txt ├── pom.xml └── src │ ├── main │ ├── resources │ │ ├── META-INF │ │ │ └── services │ │ │ │ ├── org.apache.spark.ml.Estimator │ │ │ │ ├── org.apache.spark.ml.Transformer │ │ │ │ ├── org.apache.spark.ml.evaluation.Evaluator │ │ │ │ ├── org.apache.spark.ml.util.MLFormatRegister │ │ │ │ ├── org.apache.spark.sql.SparkSessionExtensionsProvider │ │ │ │ └── org.apache.spark.sql.sources.DataSourceRegister │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── ml │ │ │ └── feature │ │ │ └── stopwords │ │ │ ├── README │ │ │ ├── danish.txt │ │ │ ├── dutch.txt │ │ │ ├── english.txt │ │ │ ├── finnish.txt │ │ │ ├── french.txt │ │ │ ├── german.txt │ │ │ ├── hungarian.txt │ │ │ ├── italian.txt │ │ │ ├── norwegian.txt │ │ │ ├── portuguese.txt │ │ │ ├── russian.txt │ │ │ ├── spanish.txt │ │ │ ├── swedish.txt │ │ │ └── turkish.txt │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── ml │ │ ├── Estimator.scala │ │ ├── Model.scala │ │ ├── Pipeline.scala │ │ ├── Predictor.scala │ │ ├── Transformer.scala │ │ ├── ann │ │ │ ├── BreezeUtil.scala │ │ │ ├── Layer.scala │ │ │ └── LossFunction.scala │ │ ├── attribute │ │ │ ├── AttributeGroup.scala │ │ │ ├── AttributeKeys.scala │ │ │ ├── AttributeType.scala │ │ │ ├── attributes.scala │ │ │ ├── package-info.java │ │ │ └── package.scala │ │ ├── classification │ │ │ ├── ClassificationSummary.scala │ │ │ ├── Classifier.scala │ │ │ ├── DecisionTreeClassifier.scala │ │ │ ├── FMClassifier.scala │ │ │ ├── GBTClassifier.scala │ │ │ ├── LinearSVC.scala │ │ │ ├── LogisticRegression.scala │ │ │ ├── MultilayerPerceptronClassifier.scala │ │ │ ├── NaiveBayes.scala │ │ │ ├── OneVsRest.scala │ │ │ ├── ProbabilisticClassifier.scala │ │ │ └── RandomForestClassifier.scala │ │ ├── clustering │ │ │ ├── BisectingKMeans.scala │ │ │ ├── ClusteringSummary.scala │ │ │ ├── GaussianMixture.scala │ │ │ ├── KMeans.scala │ │ │ ├── LDA.scala │ │ │ └── PowerIterationClustering.scala │ │ ├── evaluation │ │ │ ├── BinaryClassificationEvaluator.scala │ │ │ ├── ClusteringEvaluator.scala │ │ │ ├── ClusteringMetrics.scala │ │ │ ├── Evaluator.scala │ │ │ ├── MulticlassClassificationEvaluator.scala │ │ │ ├── MultilabelClassificationEvaluator.scala │ │ │ ├── RankingEvaluator.scala │ │ │ └── RegressionEvaluator.scala │ │ ├── events.scala │ │ ├── feature │ │ │ ├── Binarizer.scala │ │ │ ├── BucketedRandomProjectionLSH.scala │ │ │ ├── Bucketizer.scala │ │ │ ├── ChiSqSelector.scala │ │ │ ├── CountVectorizer.scala │ │ │ ├── DCT.scala │ │ │ ├── ElementwiseProduct.scala │ │ │ ├── FeatureHasher.scala │ │ │ ├── HashingTF.scala │ │ │ ├── IDF.scala │ │ │ ├── Imputer.scala │ │ │ ├── Instance.scala │ │ │ ├── Interaction.scala │ │ │ ├── LSH.scala │ │ │ ├── LabeledPoint.scala │ │ │ ├── MaxAbsScaler.scala │ │ │ ├── MinHashLSH.scala │ │ │ ├── MinMaxScaler.scala │ │ │ ├── NGram.scala │ │ │ ├── Normalizer.scala │ │ │ ├── OneHotEncoder.scala │ │ │ ├── PCA.scala │ │ │ ├── PolynomialExpansion.scala │ │ │ ├── QuantileDiscretizer.scala │ │ │ ├── RFormula.scala │ │ │ ├── RFormulaParser.scala │ │ │ ├── RobustScaler.scala │ │ │ ├── SQLTransformer.scala │ │ │ ├── Selector.scala │ │ │ ├── StandardScaler.scala │ │ │ ├── StopWordsRemover.scala │ │ │ ├── StringIndexer.scala │ │ │ ├── TargetEncoder.scala │ │ │ ├── Tokenizer.scala │ │ │ ├── UnivariateFeatureSelector.scala │ │ │ ├── VarianceThresholdSelector.scala │ │ │ ├── VectorAssembler.scala │ │ │ ├── VectorIndexer.scala │ │ │ ├── VectorSizeHint.scala │ │ │ ├── VectorSlicer.scala │ │ │ ├── Word2Vec.scala │ │ │ ├── package-info.java │ │ │ └── package.scala │ │ ├── fpm │ │ │ ├── FPGrowth.scala │ │ │ └── PrefixSpan.scala │ │ ├── functions.scala │ │ ├── image │ │ │ ├── HadoopUtils.scala │ │ │ └── ImageSchema.scala │ │ ├── linalg │ │ │ ├── JsonMatrixConverter.scala │ │ │ ├── JsonVectorConverter.scala │ │ │ ├── MatrixUDT.scala │ │ │ ├── SQLDataTypes.scala │ │ │ └── VectorUDT.scala │ │ ├── optim │ │ │ ├── IterativelyReweightedLeastSquares.scala │ │ │ ├── NormalEquationSolver.scala │ │ │ ├── WeightedLeastSquares.scala │ │ │ ├── aggregator │ │ │ │ ├── AFTBlockAggregator.scala │ │ │ │ ├── BinaryLogisticBlockAggregator.scala │ │ │ │ ├── DifferentiableLossAggregator.scala │ │ │ │ ├── HingeBlockAggregator.scala │ │ │ │ ├── HuberBlockAggregator.scala │ │ │ │ ├── LeastSquaresBlockAggregator.scala │ │ │ │ └── MultinomialLogisticBlockAggregator.scala │ │ │ └── loss │ │ │ │ ├── DifferentiableRegularization.scala │ │ │ │ └── RDDLossFunction.scala │ │ ├── package-info.java │ │ ├── package.scala │ │ ├── param │ │ │ ├── params.scala │ │ │ └── shared │ │ │ │ ├── HasParallelism.scala │ │ │ │ ├── SharedParamsCodeGen.scala │ │ │ │ └── sharedParams.scala │ │ ├── python │ │ │ ├── MLSerDe.scala │ │ │ └── MLUtil.scala │ │ ├── r │ │ │ ├── AFTSurvivalRegressionWrapper.scala │ │ │ ├── ALSWrapper.scala │ │ │ ├── BisectingKMeansWrapper.scala │ │ │ ├── DecisionTreeClassifierWrapper.scala │ │ │ ├── DecisionTreeRegressorWrapper.scala │ │ │ ├── FMClassifierWrapper.scala │ │ │ ├── FMRegressorWrapper.scala │ │ │ ├── FPGrowthWrapper.scala │ │ │ ├── GBTClassifierWrapper.scala │ │ │ ├── GBTRegressorWrapper.scala │ │ │ ├── GaussianMixtureWrapper.scala │ │ │ ├── GeneralizedLinearRegressionWrapper.scala │ │ │ ├── IsotonicRegressionWrapper.scala │ │ │ ├── KMeansWrapper.scala │ │ │ ├── KSTestWrapper.scala │ │ │ ├── LDAWrapper.scala │ │ │ ├── LinearRegressionWrapper.scala │ │ │ ├── LinearSVCWrapper.scala │ │ │ ├── LogisticRegressionWrapper.scala │ │ │ ├── MultilayerPerceptronClassifierWrapper.scala │ │ │ ├── NaiveBayesWrapper.scala │ │ │ ├── PowerIterationClusteringWrapper.scala │ │ │ ├── PrefixSpanWrapper.scala │ │ │ ├── RWrapperUtils.scala │ │ │ ├── RWrappers.scala │ │ │ ├── RandomForestClassifierWrapper.scala │ │ │ └── RandomForestRegressorWrapper.scala │ │ ├── recommendation │ │ │ └── ALS.scala │ │ ├── regression │ │ │ ├── AFTSurvivalRegression.scala │ │ │ ├── DecisionTreeRegressor.scala │ │ │ ├── FMRegressor.scala │ │ │ ├── GBTRegressor.scala │ │ │ ├── GeneralizedLinearRegression.scala │ │ │ ├── IsotonicRegression.scala │ │ │ ├── LinearRegression.scala │ │ │ ├── RandomForestRegressor.scala │ │ │ └── Regressor.scala │ │ ├── source │ │ │ ├── image │ │ │ │ ├── ImageDataSource.scala │ │ │ │ ├── ImageFileFormat.scala │ │ │ │ └── ImageOptions.scala │ │ │ └── libsvm │ │ │ │ ├── LibSVMDataSource.scala │ │ │ │ ├── LibSVMOptions.scala │ │ │ │ └── LibSVMRelation.scala │ │ ├── stat │ │ │ ├── ANOVATest.scala │ │ │ ├── ChiSquareTest.scala │ │ │ ├── Correlation.scala │ │ │ ├── FValueTest.scala │ │ │ ├── KolmogorovSmirnovTest.scala │ │ │ ├── MultiClassSummarizer.scala │ │ │ └── Summarizer.scala │ │ ├── tree │ │ │ ├── Node.scala │ │ │ ├── Split.scala │ │ │ ├── impl │ │ │ │ ├── BaggedPoint.scala │ │ │ │ ├── DTStatsAggregator.scala │ │ │ │ ├── DecisionTreeMetadata.scala │ │ │ │ ├── GradientBoostedTrees.scala │ │ │ │ ├── RandomForest.scala │ │ │ │ ├── TimeTracker.scala │ │ │ │ └── TreePoint.scala │ │ │ ├── treeModels.scala │ │ │ └── treeParams.scala │ │ ├── tuning │ │ │ ├── CrossValidator.scala │ │ │ ├── ParamGridBuilder.scala │ │ │ ├── TrainValidationSplit.scala │ │ │ └── ValidatorParams.scala │ │ └── util │ │ │ ├── ConnectHelper.scala │ │ │ ├── DatasetUtils.scala │ │ │ ├── HasTrainingSummary.scala │ │ │ ├── Identifiable.scala │ │ │ ├── Instrumentation.scala │ │ │ ├── MetadataUtils.scala │ │ │ ├── ReadWrite.scala │ │ │ ├── SchemaUtils.scala │ │ │ ├── Summary.scala │ │ │ └── stopwatches.scala │ │ ├── mllib │ │ ├── JavaPackage.java │ │ ├── api │ │ │ └── python │ │ │ │ ├── FPGrowthModelWrapper.scala │ │ │ │ ├── GaussianMixtureModelWrapper.scala │ │ │ │ ├── LDAModelWrapper.scala │ │ │ │ ├── MatrixFactorizationModelWrapper.scala │ │ │ │ ├── PowerIterationClusteringModelWrapper.scala │ │ │ │ ├── PrefixSpanModelWrapper.scala │ │ │ │ ├── PythonMLLibAPI.scala │ │ │ │ ├── Word2VecModelWrapper.scala │ │ │ │ └── package.scala │ │ ├── classification │ │ │ ├── ClassificationModel.scala │ │ │ ├── LogisticRegression.scala │ │ │ ├── NaiveBayes.scala │ │ │ ├── SVM.scala │ │ │ ├── StreamingLogisticRegressionWithSGD.scala │ │ │ └── impl │ │ │ │ └── GLMClassificationModel.scala │ │ ├── clustering │ │ │ ├── BisectingKMeans.scala │ │ │ ├── BisectingKMeansModel.scala │ │ │ ├── DistanceMeasure.scala │ │ │ ├── GaussianMixture.scala │ │ │ ├── GaussianMixtureModel.scala │ │ │ ├── KMeans.scala │ │ │ ├── KMeansModel.scala │ │ │ ├── LDA.scala │ │ │ ├── LDAModel.scala │ │ │ ├── LDAOptimizer.scala │ │ │ ├── LDAUtils.scala │ │ │ ├── LocalKMeans.scala │ │ │ ├── PowerIterationClustering.scala │ │ │ └── StreamingKMeans.scala │ │ ├── evaluation │ │ │ ├── AreaUnderCurve.scala │ │ │ ├── BinaryClassificationMetrics.scala │ │ │ ├── MulticlassMetrics.scala │ │ │ ├── MultilabelMetrics.scala │ │ │ ├── RankingMetrics.scala │ │ │ ├── RegressionMetrics.scala │ │ │ └── binary │ │ │ │ ├── BinaryClassificationMetricComputers.scala │ │ │ │ ├── BinaryConfusionMatrix.scala │ │ │ │ └── BinaryLabelCounter.scala │ │ ├── feature │ │ │ ├── ChiSqSelector.scala │ │ │ ├── ElementwiseProduct.scala │ │ │ ├── HashingTF.scala │ │ │ ├── IDF.scala │ │ │ ├── Normalizer.scala │ │ │ ├── PCA.scala │ │ │ ├── StandardScaler.scala │ │ │ ├── VectorTransformer.scala │ │ │ └── Word2Vec.scala │ │ ├── fpm │ │ │ ├── AssociationRules.scala │ │ │ ├── FPGrowth.scala │ │ │ ├── FPTree.scala │ │ │ ├── LocalPrefixSpan.scala │ │ │ └── PrefixSpan.scala │ │ ├── linalg │ │ │ ├── ARPACK.scala │ │ │ ├── BLAS.scala │ │ │ ├── CholeskyDecomposition.scala │ │ │ ├── EigenValueDecomposition.scala │ │ │ ├── LAPACK.scala │ │ │ ├── Matrices.scala │ │ │ ├── SingularValueDecomposition.scala │ │ │ ├── Vectors.scala │ │ │ └── distributed │ │ │ │ ├── BlockMatrix.scala │ │ │ │ ├── CoordinateMatrix.scala │ │ │ │ ├── DistributedMatrix.scala │ │ │ │ ├── IndexedRowMatrix.scala │ │ │ │ └── RowMatrix.scala │ │ ├── optimization │ │ │ ├── Gradient.scala │ │ │ ├── GradientDescent.scala │ │ │ ├── LBFGS.scala │ │ │ ├── NNLS.scala │ │ │ ├── Optimizer.scala │ │ │ └── Updater.scala │ │ ├── package-info.java │ │ ├── package.scala │ │ ├── pmml │ │ │ ├── PMMLExportable.scala │ │ │ └── export │ │ │ │ ├── BinaryClassificationPMMLModelExport.scala │ │ │ │ ├── GeneralizedLinearPMMLModelExport.scala │ │ │ │ ├── KMeansPMMLModelExport.scala │ │ │ │ ├── PMMLModelExport.scala │ │ │ │ └── PMMLModelExportFactory.scala │ │ ├── random │ │ │ ├── RandomDataGenerator.scala │ │ │ └── RandomRDDs.scala │ │ ├── rdd │ │ │ ├── MLPairRDDFunctions.scala │ │ │ ├── RDDFunctions.scala │ │ │ ├── RandomRDD.scala │ │ │ └── SlidingRDD.scala │ │ ├── recommendation │ │ │ ├── ALS.scala │ │ │ └── MatrixFactorizationModel.scala │ │ ├── regression │ │ │ ├── GeneralizedLinearAlgorithm.scala │ │ │ ├── IsotonicRegression.scala │ │ │ ├── LabeledPoint.scala │ │ │ ├── Lasso.scala │ │ │ ├── LinearRegression.scala │ │ │ ├── RegressionModel.scala │ │ │ ├── RidgeRegression.scala │ │ │ ├── StreamingLinearAlgorithm.scala │ │ │ ├── StreamingLinearRegressionWithSGD.scala │ │ │ └── impl │ │ │ │ └── GLMRegressionModel.scala │ │ ├── stat │ │ │ ├── KernelDensity.scala │ │ │ ├── MultivariateOnlineSummarizer.scala │ │ │ ├── MultivariateStatisticalSummary.scala │ │ │ ├── Statistics.scala │ │ │ ├── correlation │ │ │ │ ├── Correlation.scala │ │ │ │ ├── PearsonCorrelation.scala │ │ │ │ └── SpearmanCorrelation.scala │ │ │ ├── distribution │ │ │ │ └── MultivariateGaussian.scala │ │ │ └── test │ │ │ │ ├── ChiSqTest.scala │ │ │ │ ├── KolmogorovSmirnovTest.scala │ │ │ │ ├── StreamingTest.scala │ │ │ │ ├── StreamingTestMethod.scala │ │ │ │ └── TestResult.scala │ │ ├── tree │ │ │ ├── DecisionTree.scala │ │ │ ├── GradientBoostedTrees.scala │ │ │ ├── RandomForest.scala │ │ │ ├── configuration │ │ │ │ ├── Algo.scala │ │ │ │ ├── BoostingStrategy.scala │ │ │ │ ├── EnsembleCombiningStrategy.scala │ │ │ │ ├── FeatureType.scala │ │ │ │ ├── QuantileStrategy.scala │ │ │ │ └── Strategy.scala │ │ │ ├── impurity │ │ │ │ ├── Entropy.scala │ │ │ │ ├── Gini.scala │ │ │ │ ├── Impurities.scala │ │ │ │ ├── Impurity.scala │ │ │ │ └── Variance.scala │ │ │ ├── loss │ │ │ │ ├── AbsoluteError.scala │ │ │ │ ├── LogLoss.scala │ │ │ │ ├── Loss.scala │ │ │ │ ├── Losses.scala │ │ │ │ └── SquaredError.scala │ │ │ ├── model │ │ │ │ ├── DecisionTreeModel.scala │ │ │ │ ├── InformationGainStats.scala │ │ │ │ ├── Node.scala │ │ │ │ ├── Predict.scala │ │ │ │ ├── Split.scala │ │ │ │ └── treeEnsembleModels.scala │ │ │ └── package.scala │ │ └── util │ │ │ ├── DataValidators.scala │ │ │ ├── KMeansDataGenerator.scala │ │ │ ├── LinearDataGenerator.scala │ │ │ ├── LogisticRegressionDataGenerator.scala │ │ │ ├── MFDataGenerator.scala │ │ │ ├── MLUtils.scala │ │ │ ├── NumericParser.scala │ │ │ ├── SVMDataGenerator.scala │ │ │ └── modelSaveLoad.scala │ │ └── sql │ │ └── ml │ │ └── InternalFunctionRegistration.scala │ └── test │ ├── java │ └── org │ │ └── apache │ │ └── spark │ │ ├── SharedSparkSession.java │ │ ├── ml │ │ ├── JavaPipelineSuite.java │ │ ├── attribute │ │ │ ├── JavaAttributeGroupSuite.java │ │ │ └── JavaAttributeSuite.java │ │ ├── classification │ │ │ ├── JavaDecisionTreeClassifierSuite.java │ │ │ ├── JavaGBTClassifierSuite.java │ │ │ ├── JavaLogisticRegressionSuite.java │ │ │ ├── JavaMultilayerPerceptronClassifierSuite.java │ │ │ ├── JavaNaiveBayesSuite.java │ │ │ ├── JavaOneVsRestSuite.java │ │ │ └── JavaRandomForestClassifierSuite.java │ │ ├── clustering │ │ │ └── JavaKMeansSuite.java │ │ ├── feature │ │ │ ├── JavaBucketizerSuite.java │ │ │ ├── JavaDCTSuite.java │ │ │ ├── JavaHashingTFSuite.java │ │ │ ├── JavaNormalizerSuite.java │ │ │ ├── JavaPCASuite.java │ │ │ ├── JavaPolynomialExpansionSuite.java │ │ │ ├── JavaStandardScalerSuite.java │ │ │ ├── JavaStopWordsRemoverSuite.java │ │ │ ├── JavaStringIndexerSuite.java │ │ │ ├── JavaTargetEncoderSuite.java │ │ │ ├── JavaTokenizerSuite.java │ │ │ ├── JavaVectorAssemblerSuite.java │ │ │ ├── JavaVectorIndexerSuite.java │ │ │ ├── JavaVectorSlicerSuite.java │ │ │ └── JavaWord2VecSuite.java │ │ ├── linalg │ │ │ └── JavaSQLDataTypesSuite.java │ │ ├── param │ │ │ ├── JavaParamsSuite.java │ │ │ └── JavaTestParams.java │ │ ├── regression │ │ │ ├── JavaDecisionTreeRegressorSuite.java │ │ │ ├── JavaGBTRegressorSuite.java │ │ │ ├── JavaLinearRegressionSuite.java │ │ │ └── JavaRandomForestRegressorSuite.java │ │ ├── source │ │ │ └── libsvm │ │ │ │ └── JavaLibSVMRelationSuite.java │ │ ├── stat │ │ │ ├── JavaKolmogorovSmirnovTestSuite.java │ │ │ └── JavaSummarizerSuite.java │ │ ├── tuning │ │ │ └── JavaCrossValidatorSuite.java │ │ └── util │ │ │ └── JavaDefaultReadWriteSuite.java │ │ └── mllib │ │ ├── classification │ │ ├── JavaLogisticRegressionSuite.java │ │ ├── JavaNaiveBayesSuite.java │ │ ├── JavaSVMSuite.java │ │ └── JavaStreamingLogisticRegressionSuite.java │ │ ├── clustering │ │ ├── JavaBisectingKMeansSuite.java │ │ ├── JavaGaussianMixtureSuite.java │ │ ├── JavaKMeansSuite.java │ │ ├── JavaLDASuite.java │ │ └── JavaStreamingKMeansSuite.java │ │ ├── evaluation │ │ └── JavaRankingMetricsSuite.java │ │ ├── feature │ │ ├── JavaTfIdfSuite.java │ │ └── JavaWord2VecSuite.java │ │ ├── fpm │ │ ├── JavaAssociationRulesSuite.java │ │ ├── JavaFPGrowthSuite.java │ │ └── JavaPrefixSpanSuite.java │ │ ├── linalg │ │ ├── JavaMatricesSuite.java │ │ ├── JavaVectorsSuite.java │ │ └── distributed │ │ │ └── JavaRowMatrixSuite.java │ │ ├── random │ │ └── JavaRandomRDDsSuite.java │ │ ├── recommendation │ │ └── JavaALSSuite.java │ │ ├── regression │ │ ├── JavaIsotonicRegressionSuite.java │ │ ├── JavaLassoSuite.java │ │ ├── JavaLinearRegressionSuite.java │ │ ├── JavaRidgeRegressionSuite.java │ │ └── JavaStreamingLinearRegressionSuite.java │ │ ├── stat │ │ └── JavaStatisticsSuite.java │ │ ├── tree │ │ └── JavaDecisionTreeSuite.java │ │ └── util │ │ └── JavaMLUtilsSuite.java │ ├── resources │ ├── META-INF │ │ └── services │ │ │ └── org.apache.spark.ml.util.MLFormatRegister │ ├── images │ │ └── partitioned │ │ │ ├── cls=kittens │ │ │ ├── date=2018-01 │ │ │ │ ├── 29.5.a_b_EGDP022204.jpg │ │ │ │ └── not-image.txt │ │ │ └── date=2018-02 │ │ │ │ ├── 54893.jpg │ │ │ │ ├── DP153539.jpg │ │ │ │ └── DP802813.jpg │ │ │ └── cls=multichannel │ │ │ ├── date=2018-01 │ │ │ ├── BGRA.png │ │ │ └── BGRA_alpha_60.png │ │ │ └── date=2018-02 │ │ │ ├── chr30.4.184.jpg │ │ │ └── grayscale.jpg │ ├── iris_libsvm.txt │ ├── log4j2.properties │ └── ml-models │ │ ├── dtc-2.4.7 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-bd7ae42f-c890-406c-894c-ca4eac67c690-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-bd7ae42f-c890-406c-894c-ca4eac67c690-c000.snappy.parquet │ │ └── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ ├── dtr-2.4.7 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-39b027f0-a437-4b3d-84af-d861adcb9ca8-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-39b027f0-a437-4b3d-84af-d861adcb9ca8-c000.snappy.parquet │ │ └── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ ├── gbtc-2.4.7 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-dacbde64-c861-41c7-91c0-6da8cc01fb43-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-dacbde64-c861-41c7-91c0-6da8cc01fb43-c000.snappy.parquet │ │ ├── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ └── treesMetadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-81137d9f-31e3-4a90-813c-ddc394101e21-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-81137d9f-31e3-4a90-813c-ddc394101e21-c000.snappy.parquet │ │ ├── gbtr-2.4.7 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-3b5433ff-d346-4511-9aab-639288bfae6d-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-3b5433ff-d346-4511-9aab-639288bfae6d-c000.snappy.parquet │ │ ├── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ └── treesMetadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-6b9124f5-87fe-4fd8-ad9c-4be239c2215a-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-6b9124f5-87fe-4fd8-ad9c-4be239c2215a-c000.snappy.parquet │ │ ├── hashingTF-2.4.4 │ │ └── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ ├── mlp-2.4.4 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-fa18aaf6-d8df-4b90-8231-eb5f6ac12138-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-fa18aaf6-d8df-4b90-8231-eb5f6ac12138-c000.snappy.parquet │ │ └── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ ├── rfc-2.4.7 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-e41a7b98-91f8-4485-b112-25b4b11c9009-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-e41a7b98-91f8-4485-b112-25b4b11c9009-c000.snappy.parquet │ │ ├── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ └── treesMetadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-21082d24-b666-4c4e-a823-70c7afdcbdc5-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-21082d24-b666-4c4e-a823-70c7afdcbdc5-c000.snappy.parquet │ │ ├── rfr-2.4.7 │ │ ├── data │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-4a69607d-6edb-40fc-b681-981caaeca996-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-4a69607d-6edb-40fc-b681-981caaeca996-c000.snappy.parquet │ │ ├── metadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000 │ │ └── treesMetadata │ │ │ ├── ._SUCCESS.crc │ │ │ ├── .part-00000-dfe4db51-d349-447a-9b86-d95edaabcde8-c000.snappy.parquet.crc │ │ │ ├── _SUCCESS │ │ │ └── part-00000-dfe4db51-d349-447a-9b86-d95edaabcde8-c000.snappy.parquet │ │ └── strIndexerModel-2.4.4 │ │ ├── data │ │ ├── ._SUCCESS.crc │ │ ├── .part-00000-f09b03f6-6e17-4756-b9ca-c5e505dcd898-c000.snappy.parquet.crc │ │ ├── _SUCCESS │ │ └── part-00000-f09b03f6-6e17-4756-b9ca-c5e505dcd898-c000.snappy.parquet │ │ └── metadata │ │ ├── ._SUCCESS.crc │ │ ├── .part-00000.crc │ │ ├── _SUCCESS │ │ └── part-00000 │ └── scala │ └── org │ └── apache │ └── spark │ ├── ml │ ├── FunctionsSuite.scala │ ├── MLEventsSuite.scala │ ├── PipelineSuite.scala │ ├── PredictorSuite.scala │ ├── ann │ │ ├── ANNSuite.scala │ │ └── GradientSuite.scala │ ├── attribute │ │ ├── AttributeGroupSuite.scala │ │ └── AttributeSuite.scala │ ├── classification │ │ ├── ClassifierSuite.scala │ │ ├── DecisionTreeClassifierSuite.scala │ │ ├── FMClassifierSuite.scala │ │ ├── GBTClassifierSuite.scala │ │ ├── LinearSVCSuite.scala │ │ ├── LogisticRegressionSuite.scala │ │ ├── MultilayerPerceptronClassifierSuite.scala │ │ ├── NaiveBayesSuite.scala │ │ ├── OneVsRestSuite.scala │ │ ├── ProbabilisticClassifierSuite.scala │ │ └── RandomForestClassifierSuite.scala │ ├── clustering │ │ ├── BisectingKMeansSuite.scala │ │ ├── GaussianMixtureSuite.scala │ │ ├── KMeansSuite.scala │ │ ├── LDASuite.scala │ │ └── PowerIterationClusteringSuite.scala │ ├── evaluation │ │ ├── BinaryClassificationEvaluatorSuite.scala │ │ ├── ClusteringEvaluatorSuite.scala │ │ ├── MulticlassClassificationEvaluatorSuite.scala │ │ ├── MultilabelClassificationEvaluatorSuite.scala │ │ ├── RankingEvaluatorSuite.scala │ │ └── RegressionEvaluatorSuite.scala │ ├── feature │ │ ├── BinarizerSuite.scala │ │ ├── BucketedRandomProjectionLSHSuite.scala │ │ ├── BucketizerSuite.scala │ │ ├── ChiSqSelectorSuite.scala │ │ ├── CountVectorizerSuite.scala │ │ ├── DCTSuite.scala │ │ ├── ElementwiseProductSuite.scala │ │ ├── FeatureHasherSuite.scala │ │ ├── HashingTFSuite.scala │ │ ├── IDFSuite.scala │ │ ├── ImputerSuite.scala │ │ ├── InstanceSuite.scala │ │ ├── InteractionSuite.scala │ │ ├── LSHTest.scala │ │ ├── LabeledPointSuite.scala │ │ ├── MaxAbsScalerSuite.scala │ │ ├── MinHashLSHSuite.scala │ │ ├── MinMaxScalerSuite.scala │ │ ├── NGramSuite.scala │ │ ├── NormalizerSuite.scala │ │ ├── OneHotEncoderSuite.scala │ │ ├── PCASuite.scala │ │ ├── PolynomialExpansionSuite.scala │ │ ├── QuantileDiscretizerSuite.scala │ │ ├── RFormulaParserSuite.scala │ │ ├── RFormulaSuite.scala │ │ ├── RobustScalerSuite.scala │ │ ├── SQLTransformerSuite.scala │ │ ├── StandardScalerSuite.scala │ │ ├── StopWordsRemoverSuite.scala │ │ ├── StringIndexerSuite.scala │ │ ├── TargetEncoderSuite.scala │ │ ├── TokenizerSuite.scala │ │ ├── UnivariateFeatureSelectorSuite.scala │ │ ├── VarianceThresholdSelectorSuite.scala │ │ ├── VectorAssemblerSuite.scala │ │ ├── VectorIndexerSuite.scala │ │ ├── VectorSizeHintSuite.scala │ │ ├── VectorSlicerSuite.scala │ │ └── Word2VecSuite.scala │ ├── fpm │ │ ├── FPGrowthSuite.scala │ │ └── PrefixSpanSuite.scala │ ├── linalg │ │ ├── JsonMatrixConverterSuite.scala │ │ ├── JsonVectorConverterSuite.scala │ │ ├── MatrixUDTSuite.scala │ │ ├── SQLDataTypesSuite.scala │ │ └── VectorUDTSuite.scala │ ├── optim │ │ ├── IterativelyReweightedLeastSquaresSuite.scala │ │ ├── WeightedLeastSquaresSuite.scala │ │ ├── aggregator │ │ │ ├── BinaryLogisticBlockAggregatorSuite.scala │ │ │ ├── DifferentiableLossAggregatorSuite.scala │ │ │ ├── HingeBlockAggregatorSuite.scala │ │ │ ├── HuberBlockAggregatorSuite.scala │ │ │ ├── LeastSquaresBlockAggregatorSuite.scala │ │ │ └── MultinomialLogisticBlockAggregatorSuite.scala │ │ └── loss │ │ │ ├── DifferentiableRegularizationSuite.scala │ │ │ └── RDDLossFunctionSuite.scala │ ├── param │ │ ├── ParamsSuite.scala │ │ ├── TestParams.scala │ │ └── shared │ │ │ └── SharedParamsSuite.scala │ ├── python │ │ └── MLSerDeSuite.scala │ ├── r │ │ └── RWrapperUtilsSuite.scala │ ├── recommendation │ │ ├── ALSSuite.scala │ │ └── CollectTopKSuite.scala │ ├── regression │ │ ├── AFTSurvivalRegressionSuite.scala │ │ ├── DecisionTreeRegressorSuite.scala │ │ ├── FMRegressorSuite.scala │ │ ├── GBTRegressorSuite.scala │ │ ├── GeneralizedLinearRegressionSuite.scala │ │ ├── IsotonicRegressionSuite.scala │ │ ├── LinearRegressionSuite.scala │ │ └── RandomForestRegressorSuite.scala │ ├── source │ │ ├── image │ │ │ └── ImageFileFormatSuite.scala │ │ └── libsvm │ │ │ └── LibSVMRelationSuite.scala │ ├── stat │ │ ├── ANOVATestSuite.scala │ │ ├── ChiSquareTestSuite.scala │ │ ├── CorrelationSuite.scala │ │ ├── FValueTestSuite.scala │ │ ├── KolmogorovSmirnovTestSuite.scala │ │ ├── MultiClassSummarizerSuite.scala │ │ └── SummarizerSuite.scala │ ├── tree │ │ └── impl │ │ │ ├── BaggedPointSuite.scala │ │ │ ├── GradientBoostedTreesSuite.scala │ │ │ ├── RandomForestSuite.scala │ │ │ ├── TreePointSuite.scala │ │ │ └── TreeTests.scala │ ├── tuning │ │ ├── CrossValidatorSuite.scala │ │ ├── ParamGridBuilderSuite.scala │ │ ├── TrainValidationSplitSuite.scala │ │ └── ValidatorParamsSuiteHelpers.scala │ └── util │ │ ├── DefaultReadWriteTest.scala │ │ ├── IdentifiableSuite.scala │ │ ├── MLTest.scala │ │ ├── MLTestSuite.scala │ │ ├── MLTestingUtils.scala │ │ ├── PMMLReadWriteTest.scala │ │ ├── PMMLUtils.scala │ │ ├── ReadWriteSuite.scala │ │ ├── StopwatchSuite.scala │ │ └── TempDirectory.scala │ └── mllib │ ├── api │ └── python │ │ └── PythonMLLibAPISuite.scala │ ├── classification │ ├── LogisticRegressionSuite.scala │ ├── NaiveBayesSuite.scala │ ├── SVMSuite.scala │ └── StreamingLogisticRegressionSuite.scala │ ├── clustering │ ├── BisectingKMeansSuite.scala │ ├── DistanceMeasureSuite.scala │ ├── GaussianMixtureSuite.scala │ ├── KMeansSuite.scala │ ├── LDASuite.scala │ ├── PowerIterationClusteringSuite.scala │ └── StreamingKMeansSuite.scala │ ├── evaluation │ ├── AreaUnderCurveSuite.scala │ ├── BinaryClassificationMetricsSuite.scala │ ├── MulticlassMetricsSuite.scala │ ├── MultilabelMetricsSuite.scala │ ├── RankingMetricsSuite.scala │ └── RegressionMetricsSuite.scala │ ├── feature │ ├── ChiSqSelectorSuite.scala │ ├── ElementwiseProductSuite.scala │ ├── HashingTFSuite.scala │ ├── IDFSuite.scala │ ├── NormalizerSuite.scala │ ├── PCASuite.scala │ ├── StandardScalerSuite.scala │ └── Word2VecSuite.scala │ ├── fpm │ ├── AssociationRulesSuite.scala │ ├── FPGrowthSuite.scala │ ├── FPTreeSuite.scala │ └── PrefixSpanSuite.scala │ ├── linalg │ ├── BLASSuite.scala │ ├── BreezeMatrixConversionSuite.scala │ ├── BreezeVectorConversionSuite.scala │ ├── MatricesSuite.scala │ ├── UDTSerializationBenchmark.scala │ ├── VectorsSuite.scala │ └── distributed │ │ ├── BlockMatrixSuite.scala │ │ ├── CoordinateMatrixSuite.scala │ │ ├── IndexedRowMatrixSuite.scala │ │ └── RowMatrixSuite.scala │ ├── optimization │ ├── GradientDescentSuite.scala │ ├── LBFGSSuite.scala │ └── NNLSSuite.scala │ ├── pmml │ └── export │ │ ├── BinaryClassificationPMMLModelExportSuite.scala │ │ ├── GeneralizedLinearPMMLModelExportSuite.scala │ │ ├── KMeansPMMLModelExportSuite.scala │ │ └── PMMLModelExportFactorySuite.scala │ ├── random │ ├── RandomDataGeneratorSuite.scala │ └── RandomRDDsSuite.scala │ ├── rdd │ ├── MLPairRDDFunctionsSuite.scala │ └── RDDFunctionsSuite.scala │ ├── recommendation │ ├── ALSSuite.scala │ └── MatrixFactorizationModelSuite.scala │ ├── regression │ ├── IsotonicRegressionSuite.scala │ ├── LabeledPointSuite.scala │ ├── LassoSuite.scala │ ├── LinearRegressionSuite.scala │ ├── RidgeRegressionSuite.scala │ └── StreamingLinearRegressionSuite.scala │ ├── stat │ ├── CorrelationSuite.scala │ ├── HypothesisTestSuite.scala │ ├── KernelDensitySuite.scala │ ├── MultivariateOnlineSummarizerSuite.scala │ ├── StreamingTestSuite.scala │ └── distribution │ │ └── MultivariateGaussianSuite.scala │ ├── tree │ ├── DecisionTreeSuite.scala │ ├── EnsembleTestHelper.scala │ ├── GradientBoostedTreesSuite.scala │ ├── ImpuritySuite.scala │ └── RandomForestSuite.scala │ └── util │ ├── LocalClusterSparkContext.scala │ ├── MLUtilsSuite.scala │ ├── MLlibTestSparkContext.scala │ ├── NumericParserSuite.scala │ ├── TestingUtils.scala │ └── TestingUtilsSuite.scala ├── pom.xml ├── project ├── MimaBuild.scala ├── MimaExcludes.scala ├── SparkBuild.scala ├── build.properties └── plugins.sbt ├── python ├── .coveragerc ├── .gitignore ├── MANIFEST.in ├── README.md ├── conf_viztracer │ ├── daemon_viztracer.py │ └── spark-defaults.conf ├── conf_vscode │ ├── README.md │ └── sitecustomize.py ├── docs │ ├── Makefile │ ├── make.bat │ ├── make2.bat │ └── source │ │ ├── _static │ │ └── css │ │ │ └── pyspark.css │ │ ├── _templates │ │ ├── autosummary │ │ │ ├── accessor_attribute.rst │ │ │ ├── accessor_method.rst │ │ │ ├── class.rst │ │ │ ├── class_with_docs.rst │ │ │ └── plot_class.rst │ │ ├── layout.html │ │ └── spark_footer.html │ │ ├── conf.py │ │ ├── development │ │ ├── contributing.rst │ │ ├── debugging.rst │ │ ├── index.rst │ │ ├── logger.rst │ │ ├── setting_ide.rst │ │ └── testing.rst │ │ ├── getting_started │ │ ├── index.rst │ │ ├── install.rst │ │ ├── quickstart_connect.ipynb │ │ ├── quickstart_df.ipynb │ │ ├── quickstart_ps.ipynb │ │ └── testing_pyspark.ipynb │ │ ├── index.rst │ │ ├── migration_guide │ │ ├── index.rst │ │ ├── koalas_to_pyspark.rst │ │ └── pyspark_upgrade.rst │ │ ├── reference │ │ ├── index.rst │ │ ├── pyspark.errors.rst │ │ ├── pyspark.logger.rst │ │ ├── pyspark.ml.rst │ │ ├── pyspark.mllib.rst │ │ ├── pyspark.pandas │ │ │ ├── extensions.rst │ │ │ ├── frame.rst │ │ │ ├── general_functions.rst │ │ │ ├── groupby.rst │ │ │ ├── index.rst │ │ │ ├── indexing.rst │ │ │ ├── io.rst │ │ │ ├── ml.rst │ │ │ ├── options.rst │ │ │ ├── resampling.rst │ │ │ ├── series.rst │ │ │ ├── testing.rst │ │ │ └── window.rst │ │ ├── pyspark.pipelines.rst │ │ ├── pyspark.resource.rst │ │ ├── pyspark.rst │ │ ├── pyspark.sql │ │ │ ├── avro.rst │ │ │ ├── catalog.rst │ │ │ ├── column.rst │ │ │ ├── configuration.rst │ │ │ ├── core_classes.rst │ │ │ ├── data_types.rst │ │ │ ├── dataframe.rst │ │ │ ├── datasource.rst │ │ │ ├── functions.rst │ │ │ ├── grouping.rst │ │ │ ├── index.rst │ │ │ ├── io.rst │ │ │ ├── observation.rst │ │ │ ├── protobuf.rst │ │ │ ├── row.rst │ │ │ ├── spark_session.rst │ │ │ ├── stateful_processor.rst │ │ │ ├── udf.rst │ │ │ ├── udtf.rst │ │ │ ├── variant_val.rst │ │ │ └── window.rst │ │ ├── pyspark.ss │ │ │ ├── core_classes.rst │ │ │ ├── index.rst │ │ │ ├── io.rst │ │ │ └── query_management.rst │ │ ├── pyspark.streaming.rst │ │ └── pyspark.testing.rst │ │ ├── tutorial │ │ ├── arrow_pandas.rst │ │ ├── index.rst │ │ ├── pandas_on_spark │ │ │ ├── best_practices.rst │ │ │ ├── faq.rst │ │ │ ├── from_to_dbms.rst │ │ │ ├── index.rst │ │ │ ├── options.rst │ │ │ ├── pandas_pyspark.rst │ │ │ ├── transform_apply.rst │ │ │ ├── typehints.rst │ │ │ └── types.rst │ │ ├── python_packaging.rst │ │ └── sql │ │ │ ├── arrow_pandas.rst │ │ │ ├── arrow_python_udtf.rst │ │ │ ├── index.rst │ │ │ ├── python_data_source.rst │ │ │ ├── python_udtf.rst │ │ │ └── type_conversions.rst │ │ └── user_guide │ │ ├── ansi_migration_guide.ipynb │ │ ├── assets │ │ ├── pyspark-udf-profile.png │ │ ├── pyspark-ui-print.png │ │ ├── pyspark-ui-sql-broadcast.png │ │ └── pyspark-ui-sql.png │ │ ├── bugbusting.ipynb │ │ ├── dataframes.ipynb │ │ ├── dataprep.ipynb │ │ ├── index.rst │ │ ├── loadandbehold.ipynb │ │ ├── sql.ipynb │ │ ├── touroftypes.ipynb │ │ └── udfandudtf.ipynb ├── lib │ ├── PY4J_LICENSE.txt │ └── py4j-0.10.9.9-src.zip ├── mypy.ini ├── packaging │ ├── classic │ │ ├── setup.cfg │ │ └── setup.py │ ├── client │ │ ├── setup.cfg │ │ └── setup.py │ └── connect │ │ ├── pyspark_connect │ │ └── __init__.py │ │ ├── setup.cfg │ │ └── setup.py ├── pyspark │ ├── __init__.py │ ├── _globals.py │ ├── _typing.pyi │ ├── accumulators.py │ ├── cloudpickle │ │ ├── __init__.py │ │ ├── cloudpickle.py │ │ └── cloudpickle_fast.py │ ├── conf.py │ ├── core │ │ ├── __init__.py │ │ ├── broadcast.py │ │ ├── context.py │ │ ├── files.py │ │ ├── rdd.py │ │ └── status.py │ ├── daemon.py │ ├── errors │ │ ├── __init__.py │ │ ├── error-conditions.json │ │ ├── error_classes.py │ │ ├── exceptions │ │ │ ├── __init__.py │ │ │ ├── base.py │ │ │ ├── captured.py │ │ │ ├── connect.py │ │ │ └── tblib.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── connect │ │ │ │ ├── __init__.py │ │ │ │ └── test_parity_traceback.py │ │ │ ├── test_connect_errors_conversion.py │ │ │ ├── test_errors.py │ │ │ └── test_traceback.py │ │ └── utils.py │ ├── errors_doc_gen.py │ ├── find_spark_home.py │ ├── install.py │ ├── instrumentation_utils.py │ ├── java_gateway.py │ ├── join.py │ ├── logger │ │ ├── __init__.py │ │ ├── logger.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── connect │ │ │ │ ├── __init__.py │ │ │ │ └── test_parity_logger.py │ │ │ └── test_logger.py │ │ └── worker_io.py │ ├── loose_version.py │ ├── ml │ │ ├── __init__.py │ │ ├── _typing.pyi │ │ ├── base.py │ │ ├── classification.py │ │ ├── clustering.py │ │ ├── common.py │ │ ├── connect │ │ │ ├── __init__.py │ │ │ ├── base.py │ │ │ ├── classification.py │ │ │ ├── evaluation.py │ │ │ ├── feature.py │ │ │ ├── functions.py │ │ │ ├── io_utils.py │ │ │ ├── pipeline.py │ │ │ ├── proto.py │ │ │ ├── readwrite.py │ │ │ ├── serialize.py │ │ │ ├── summarizer.py │ │ │ ├── tuning.py │ │ │ └── util.py │ │ ├── deepspeed │ │ │ ├── __init__.py │ │ │ ├── deepspeed_distributor.py │ │ │ └── tests │ │ │ │ ├── __init__.py │ │ │ │ └── test_deepspeed_distributor.py │ │ ├── dl_util.py │ │ ├── evaluation.py │ │ ├── feature.py │ │ ├── fpm.py │ │ ├── functions.py │ │ ├── image.py │ │ ├── linalg │ │ │ └── __init__.py │ │ ├── model_cache.py │ │ ├── param │ │ │ ├── __init__.py │ │ │ ├── _shared_params_code_gen.py │ │ │ └── shared.py │ │ ├── pipeline.py │ │ ├── recommendation.py │ │ ├── regression.py │ │ ├── stat.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── connect │ │ │ │ ├── __init__.py │ │ │ │ ├── test_connect_cache.py │ │ │ │ ├── test_connect_classification.py │ │ │ │ ├── test_connect_evaluation.py │ │ │ │ ├── test_connect_feature.py │ │ │ │ ├── test_connect_function.py │ │ │ │ ├── test_connect_pipeline.py │ │ │ │ ├── test_connect_summarizer.py │ │ │ │ ├── test_connect_tuning.py │ │ │ │ ├── test_legacy_mode_classification.py │ │ │ │ ├── test_legacy_mode_evaluation.py │ │ │ │ ├── test_legacy_mode_feature.py │ │ │ │ ├── test_legacy_mode_pipeline.py │ │ │ │ ├── test_legacy_mode_summarizer.py │ │ │ │ ├── test_legacy_mode_tuning.py │ │ │ │ ├── test_parity_als.py │ │ │ │ ├── test_parity_classification.py │ │ │ │ ├── test_parity_clustering.py │ │ │ │ ├── test_parity_evaluation.py │ │ │ │ ├── test_parity_feature.py │ │ │ │ ├── test_parity_fpm.py │ │ │ │ ├── test_parity_functions.py │ │ │ │ ├── test_parity_ovr.py │ │ │ │ ├── test_parity_pipeline.py │ │ │ │ ├── test_parity_regression.py │ │ │ │ ├── test_parity_stat.py │ │ │ │ ├── test_parity_torch_data_loader.py │ │ │ │ ├── test_parity_torch_distributor.py │ │ │ │ └── test_parity_tuning.py │ │ │ ├── test_algorithms.py │ │ │ ├── test_als.py │ │ │ ├── test_base.py │ │ │ ├── test_classification.py │ │ │ ├── test_clustering.py │ │ │ ├── test_dl_util.py │ │ │ ├── test_evaluation.py │ │ │ ├── test_feature.py │ │ │ ├── test_fpm.py │ │ │ ├── test_functions.py │ │ │ ├── test_image.py │ │ │ ├── test_linalg.py │ │ │ ├── test_model_cache.py │ │ │ ├── test_ovr.py │ │ │ ├── test_param.py │ │ │ ├── test_persistence.py │ │ │ ├── test_pipeline.py │ │ │ ├── test_regression.py │ │ │ ├── test_stat.py │ │ │ ├── test_training_summary.py │ │ │ ├── test_tuning.py │ │ │ ├── test_util.py │ │ │ ├── test_wrapper.py │ │ │ ├── tuning │ │ │ │ ├── __init__.py │ │ │ │ ├── test_cv_io_basic.py │ │ │ │ ├── test_cv_io_nested.py │ │ │ │ ├── test_cv_io_pipeline.py │ │ │ │ ├── test_tuning.py │ │ │ │ ├── test_tvs_io_basic.py │ │ │ │ ├── test_tvs_io_nested.py │ │ │ │ └── test_tvs_io_pipeline.py │ │ │ └── typing │ │ │ │ ├── test_classification.yml │ │ │ │ ├── test_clustering.yaml │ │ │ │ ├── test_evaluation.yml │ │ │ │ ├── test_feature.yml │ │ │ │ ├── test_param.yml │ │ │ │ ├── test_readable.yml │ │ │ │ └── test_regression.yml │ │ ├── torch │ │ │ ├── __init__.py │ │ │ ├── data.py │ │ │ ├── distributor.py │ │ │ ├── log_communication.py │ │ │ ├── tests │ │ │ │ ├── __init__.py │ │ │ │ ├── test_data_loader.py │ │ │ │ ├── test_distributor.py │ │ │ │ └── test_log_communication.py │ │ │ └── torch_run_process_wrapper.py │ │ ├── tree.py │ │ ├── tuning.py │ │ ├── util.py │ │ └── wrapper.py │ ├── mllib │ │ ├── __init__.py │ │ ├── _typing.pyi │ │ ├── classification.py │ │ ├── clustering.py │ │ ├── common.py │ │ ├── evaluation.py │ │ ├── feature.py │ │ ├── fpm.py │ │ ├── linalg │ │ │ ├── __init__.py │ │ │ └── distributed.py │ │ ├── random.py │ │ ├── recommendation.py │ │ ├── regression.py │ │ ├── stat │ │ │ ├── KernelDensity.py │ │ │ ├── __init__.py │ │ │ ├── _statistics.py │ │ │ ├── distribution.py │ │ │ └── test.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── test_algorithms.py │ │ │ ├── test_feature.py │ │ │ ├── test_linalg.py │ │ │ ├── test_stat.py │ │ │ ├── test_streaming_algorithms.py │ │ │ └── test_util.py │ │ ├── tree.py │ │ └── util.py │ ├── pandas │ │ ├── __init__.py │ │ ├── _typing.py │ │ ├── accessors.py │ │ ├── base.py │ │ ├── categorical.py │ │ ├── config.py │ │ ├── correlation.py │ │ ├── data_type_ops │ │ │ ├── __init__.py │ │ │ ├── base.py │ │ │ ├── binary_ops.py │ │ │ ├── boolean_ops.py │ │ │ ├── categorical_ops.py │ │ │ ├── complex_ops.py │ │ │ ├── date_ops.py │ │ │ ├── datetime_ops.py │ │ │ ├── null_ops.py │ │ │ ├── num_ops.py │ │ │ ├── string_ops.py │ │ │ ├── timedelta_ops.py │ │ │ └── udt_ops.py │ │ ├── datetimes.py │ │ ├── exceptions.py │ │ ├── extensions.py │ │ ├── frame.py │ │ ├── generic.py │ │ ├── groupby.py │ │ ├── indexes │ │ │ ├── __init__.py │ │ │ ├── base.py │ │ │ ├── category.py │ │ │ ├── datetimes.py │ │ │ ├── multi.py │ │ │ └── timedelta.py │ │ ├── indexing.py │ │ ├── internal.py │ │ ├── missing │ │ │ ├── __init__.py │ │ │ ├── common.py │ │ │ ├── frame.py │ │ │ ├── general_functions.py │ │ │ ├── groupby.py │ │ │ ├── indexes.py │ │ │ ├── resample.py │ │ │ ├── scalars.py │ │ │ ├── series.py │ │ │ └── window.py │ │ ├── mlflow.py │ │ ├── namespace.py │ │ ├── numpy_compat.py │ │ ├── plot │ │ │ ├── __init__.py │ │ │ ├── core.py │ │ │ ├── matplotlib.py │ │ │ └── plotly.py │ │ ├── resample.py │ │ ├── series.py │ │ ├── spark │ │ │ ├── __init__.py │ │ │ ├── accessors.py │ │ │ └── utils.py │ │ ├── sql_formatter.py │ │ ├── sql_processor.py │ │ ├── strings.py │ │ ├── supported_api_gen.py │ │ ├── testing.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── computation │ │ │ │ ├── __init__.py │ │ │ │ ├── test_any_all.py │ │ │ │ ├── test_apply_func.py │ │ │ │ ├── test_binary_ops.py │ │ │ │ ├── test_combine.py │ │ │ │ ├── test_compute.py │ │ │ │ ├── test_corr.py │ │ │ │ ├── test_corrwith.py │ │ │ │ ├── test_cov.py │ │ │ │ ├── test_cumulative.py │ │ │ │ ├── test_describe.py │ │ │ │ ├── test_eval.py │ │ │ │ ├── test_melt.py │ │ │ │ ├── test_missing_data.py │ │ │ │ ├── test_pivot.py │ │ │ │ ├── test_pivot_table.py │ │ │ │ ├── test_pivot_table_adv.py │ │ │ │ ├── test_pivot_table_multi_idx.py │ │ │ │ ├── test_pivot_table_multi_idx_adv.py │ │ │ │ └── test_stats.py │ │ │ ├── connect │ │ │ │ ├── __init__.py │ │ │ │ ├── computation │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_any_all.py │ │ │ │ │ ├── test_parity_apply_func.py │ │ │ │ │ ├── test_parity_binary_ops.py │ │ │ │ │ ├── test_parity_combine.py │ │ │ │ │ ├── test_parity_compute.py │ │ │ │ │ ├── test_parity_corr.py │ │ │ │ │ ├── test_parity_corrwith.py │ │ │ │ │ ├── test_parity_cov.py │ │ │ │ │ ├── test_parity_cumulative.py │ │ │ │ │ ├── test_parity_describe.py │ │ │ │ │ ├── test_parity_eval.py │ │ │ │ │ ├── test_parity_melt.py │ │ │ │ │ ├── test_parity_missing_data.py │ │ │ │ │ ├── test_parity_pivot.py │ │ │ │ │ ├── test_parity_pivot_table.py │ │ │ │ │ ├── test_parity_pivot_table_adv.py │ │ │ │ │ ├── test_parity_pivot_table_multi_idx.py │ │ │ │ │ ├── test_parity_pivot_table_multi_idx_adv.py │ │ │ │ │ └── test_parity_stats.py │ │ │ │ ├── data_type_ops │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_as_type.py │ │ │ │ │ ├── test_parity_base.py │ │ │ │ │ ├── test_parity_binary_ops.py │ │ │ │ │ ├── test_parity_boolean_ops.py │ │ │ │ │ ├── test_parity_categorical_ops.py │ │ │ │ │ ├── test_parity_complex_ops.py │ │ │ │ │ ├── test_parity_date_ops.py │ │ │ │ │ ├── test_parity_datetime_ops.py │ │ │ │ │ ├── test_parity_null_ops.py │ │ │ │ │ ├── test_parity_num_arithmetic.py │ │ │ │ │ ├── test_parity_num_mod.py │ │ │ │ │ ├── test_parity_num_mul_div.py │ │ │ │ │ ├── test_parity_num_ops.py │ │ │ │ │ ├── test_parity_num_pow.py │ │ │ │ │ ├── test_parity_num_reverse.py │ │ │ │ │ ├── test_parity_string_ops.py │ │ │ │ │ ├── test_parity_timedelta_ops.py │ │ │ │ │ └── test_parity_udt_ops.py │ │ │ │ ├── diff_frames_ops │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_align.py │ │ │ │ │ ├── test_parity_arithmetic.py │ │ │ │ │ ├── test_parity_arithmetic_chain.py │ │ │ │ │ ├── test_parity_arithmetic_chain_ext.py │ │ │ │ │ ├── test_parity_arithmetic_chain_ext_float.py │ │ │ │ │ ├── test_parity_arithmetic_ext.py │ │ │ │ │ ├── test_parity_arithmetic_ext_float.py │ │ │ │ │ ├── test_parity_assign_frame.py │ │ │ │ │ ├── test_parity_assign_series.py │ │ │ │ │ ├── test_parity_basic.py │ │ │ │ │ ├── test_parity_basic_slow.py │ │ │ │ │ ├── test_parity_bitwise.py │ │ │ │ │ ├── test_parity_combine_first.py │ │ │ │ │ ├── test_parity_compare_series.py │ │ │ │ │ ├── test_parity_concat_inner.py │ │ │ │ │ ├── test_parity_concat_outer.py │ │ │ │ │ ├── test_parity_corrwith.py │ │ │ │ │ ├── test_parity_cov.py │ │ │ │ │ ├── test_parity_dot_frame.py │ │ │ │ │ ├── test_parity_dot_series.py │ │ │ │ │ ├── test_parity_error.py │ │ │ │ │ ├── test_parity_groupby.py │ │ │ │ │ ├── test_parity_groupby_aggregate.py │ │ │ │ │ ├── test_parity_groupby_apply.py │ │ │ │ │ ├── test_parity_groupby_cumulative.py │ │ │ │ │ ├── test_parity_groupby_diff.py │ │ │ │ │ ├── test_parity_groupby_diff_len.py │ │ │ │ │ ├── test_parity_groupby_expanding.py │ │ │ │ │ ├── test_parity_groupby_expanding_adv.py │ │ │ │ │ ├── test_parity_groupby_expanding_count.py │ │ │ │ │ ├── test_parity_groupby_fillna.py │ │ │ │ │ ├── test_parity_groupby_filter.py │ │ │ │ │ ├── test_parity_groupby_rolling.py │ │ │ │ │ ├── test_parity_groupby_rolling_adv.py │ │ │ │ │ ├── test_parity_groupby_rolling_count.py │ │ │ │ │ ├── test_parity_groupby_shift.py │ │ │ │ │ ├── test_parity_groupby_split_apply_combine.py │ │ │ │ │ ├── test_parity_groupby_transform.py │ │ │ │ │ ├── test_parity_index.py │ │ │ │ │ ├── test_parity_series.py │ │ │ │ │ ├── test_parity_setitem_frame.py │ │ │ │ │ └── test_parity_setitem_series.py │ │ │ │ ├── frame │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_asfreq.py │ │ │ │ │ ├── test_parity_asof.py │ │ │ │ │ ├── test_parity_attrs.py │ │ │ │ │ ├── test_parity_axis.py │ │ │ │ │ ├── test_parity_constructor.py │ │ │ │ │ ├── test_parity_conversion.py │ │ │ │ │ ├── test_parity_interpolate.py │ │ │ │ │ ├── test_parity_interpolate_error.py │ │ │ │ │ ├── test_parity_reindexing.py │ │ │ │ │ ├── test_parity_reshaping.py │ │ │ │ │ ├── test_parity_spark.py │ │ │ │ │ ├── test_parity_take.py │ │ │ │ │ ├── test_parity_take_adv.py │ │ │ │ │ ├── test_parity_time_series.py │ │ │ │ │ └── test_parity_truncate.py │ │ │ │ ├── groupby │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_aggregate.py │ │ │ │ │ ├── test_parity_apply_func.py │ │ │ │ │ ├── test_parity_corr.py │ │ │ │ │ ├── test_parity_cumulative.py │ │ │ │ │ ├── test_parity_describe.py │ │ │ │ │ ├── test_parity_groupby.py │ │ │ │ │ ├── test_parity_grouping.py │ │ │ │ │ ├── test_parity_head_tail.py │ │ │ │ │ ├── test_parity_index.py │ │ │ │ │ ├── test_parity_missing.py │ │ │ │ │ ├── test_parity_missing_data.py │ │ │ │ │ ├── test_parity_nlargest_nsmallest.py │ │ │ │ │ ├── test_parity_raises.py │ │ │ │ │ ├── test_parity_rank.py │ │ │ │ │ ├── test_parity_size.py │ │ │ │ │ ├── test_parity_split_apply.py │ │ │ │ │ ├── test_parity_split_apply_count.py │ │ │ │ │ ├── test_parity_split_apply_first.py │ │ │ │ │ ├── test_parity_split_apply_last.py │ │ │ │ │ ├── test_parity_split_apply_min_max.py │ │ │ │ │ ├── test_parity_split_apply_skew.py │ │ │ │ │ ├── test_parity_split_apply_std.py │ │ │ │ │ ├── test_parity_split_apply_var.py │ │ │ │ │ ├── test_parity_stat.py │ │ │ │ │ ├── test_parity_stat_adv.py │ │ │ │ │ ├── test_parity_stat_ddof.py │ │ │ │ │ ├── test_parity_stat_func.py │ │ │ │ │ ├── test_parity_stat_prod.py │ │ │ │ │ └── test_parity_value_counts.py │ │ │ │ ├── indexes │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_align.py │ │ │ │ │ ├── test_parity_append.py │ │ │ │ │ ├── test_parity_asof.py │ │ │ │ │ ├── test_parity_astype.py │ │ │ │ │ ├── test_parity_basic.py │ │ │ │ │ ├── test_parity_category.py │ │ │ │ │ ├── test_parity_conversion.py │ │ │ │ │ ├── test_parity_datetime.py │ │ │ │ │ ├── test_parity_datetime_at.py │ │ │ │ │ ├── test_parity_datetime_between.py │ │ │ │ │ ├── test_parity_datetime_ceil.py │ │ │ │ │ ├── test_parity_datetime_floor.py │ │ │ │ │ ├── test_parity_datetime_iso.py │ │ │ │ │ ├── test_parity_datetime_map.py │ │ │ │ │ ├── test_parity_datetime_property.py │ │ │ │ │ ├── test_parity_datetime_round.py │ │ │ │ │ ├── test_parity_default.py │ │ │ │ │ ├── test_parity_delete.py │ │ │ │ │ ├── test_parity_diff.py │ │ │ │ │ ├── test_parity_drop.py │ │ │ │ │ ├── test_parity_getattr.py │ │ │ │ │ ├── test_parity_indexing.py │ │ │ │ │ ├── test_parity_indexing_adv.py │ │ │ │ │ ├── test_parity_indexing_basic.py │ │ │ │ │ ├── test_parity_indexing_iloc.py │ │ │ │ │ ├── test_parity_indexing_loc.py │ │ │ │ │ ├── test_parity_indexing_loc_2d.py │ │ │ │ │ ├── test_parity_indexing_loc_multi_idx.py │ │ │ │ │ ├── test_parity_insert.py │ │ │ │ │ ├── test_parity_intersection.py │ │ │ │ │ ├── test_parity_level.py │ │ │ │ │ ├── test_parity_map.py │ │ │ │ │ ├── test_parity_missing.py │ │ │ │ │ ├── test_parity_monotonic.py │ │ │ │ │ ├── test_parity_name.py │ │ │ │ │ ├── test_parity_reindex.py │ │ │ │ │ ├── test_parity_rename.py │ │ │ │ │ ├── test_parity_repeat.py │ │ │ │ │ ├── test_parity_reset_index.py │ │ │ │ │ ├── test_parity_sort.py │ │ │ │ │ ├── test_parity_stat.py │ │ │ │ │ ├── test_parity_symmetric_diff.py │ │ │ │ │ ├── test_parity_take.py │ │ │ │ │ ├── test_parity_timedelta.py │ │ │ │ │ ├── test_parity_union.py │ │ │ │ │ └── test_parity_unique.py │ │ │ │ ├── io │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_csv.py │ │ │ │ │ ├── test_parity_dataframe_conversion.py │ │ │ │ │ ├── test_parity_dataframe_spark_io.py │ │ │ │ │ ├── test_parity_feather.py │ │ │ │ │ ├── test_parity_io.py │ │ │ │ │ ├── test_parity_series_conversion.py │ │ │ │ │ └── test_parity_stata.py │ │ │ │ ├── plot │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_frame_plot.py │ │ │ │ │ ├── test_parity_frame_plot_matplotlib.py │ │ │ │ │ ├── test_parity_frame_plot_plotly.py │ │ │ │ │ ├── test_parity_series_plot.py │ │ │ │ │ ├── test_parity_series_plot_matplotlib.py │ │ │ │ │ └── test_parity_series_plot_plotly.py │ │ │ │ ├── resample │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_error.py │ │ │ │ │ ├── test_parity_frame.py │ │ │ │ │ ├── test_parity_missing.py │ │ │ │ │ ├── test_parity_on.py │ │ │ │ │ ├── test_parity_series.py │ │ │ │ │ └── test_parity_timezone.py │ │ │ │ ├── reshape │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_get_dummies.py │ │ │ │ │ ├── test_parity_get_dummies_kwargs.py │ │ │ │ │ ├── test_parity_get_dummies_multiindex.py │ │ │ │ │ ├── test_parity_get_dummies_object.py │ │ │ │ │ ├── test_parity_get_dummies_prefix.py │ │ │ │ │ └── test_parity_merge_asof.py │ │ │ │ ├── series │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_all_any.py │ │ │ │ │ ├── test_parity_arg_ops.py │ │ │ │ │ ├── test_parity_as_of.py │ │ │ │ │ ├── test_parity_as_type.py │ │ │ │ │ ├── test_parity_compute.py │ │ │ │ │ ├── test_parity_conversion.py │ │ │ │ │ ├── test_parity_cumulative.py │ │ │ │ │ ├── test_parity_datetime.py │ │ │ │ │ ├── test_parity_index.py │ │ │ │ │ ├── test_parity_interpolate.py │ │ │ │ │ ├── test_parity_missing_data.py │ │ │ │ │ ├── test_parity_series.py │ │ │ │ │ ├── test_parity_sort.py │ │ │ │ │ ├── test_parity_stat.py │ │ │ │ │ ├── test_parity_string_ops_adv.py │ │ │ │ │ └── test_parity_string_ops_basic.py │ │ │ │ ├── test_connect_plotting.py │ │ │ │ ├── test_parity_categorical.py │ │ │ │ ├── test_parity_config.py │ │ │ │ ├── test_parity_extension.py │ │ │ │ ├── test_parity_frame_spark.py │ │ │ │ ├── test_parity_generic_functions.py │ │ │ │ ├── test_parity_indexops_spark.py │ │ │ │ ├── test_parity_internal.py │ │ │ │ ├── test_parity_namespace.py │ │ │ │ ├── test_parity_numpy_compat.py │ │ │ │ ├── test_parity_repr.py │ │ │ │ ├── test_parity_scalars.py │ │ │ │ ├── test_parity_spark_functions.py │ │ │ │ ├── test_parity_sql.py │ │ │ │ ├── test_parity_typedef.py │ │ │ │ ├── test_parity_utils.py │ │ │ │ └── window │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_ewm_error.py │ │ │ │ │ ├── test_parity_ewm_mean.py │ │ │ │ │ ├── test_parity_expanding.py │ │ │ │ │ ├── test_parity_expanding_adv.py │ │ │ │ │ ├── test_parity_expanding_error.py │ │ │ │ │ ├── test_parity_groupby_ewm_mean.py │ │ │ │ │ ├── test_parity_groupby_expanding.py │ │ │ │ │ ├── test_parity_groupby_expanding_adv.py │ │ │ │ │ ├── test_parity_groupby_rolling.py │ │ │ │ │ ├── test_parity_groupby_rolling_adv.py │ │ │ │ │ ├── test_parity_groupby_rolling_count.py │ │ │ │ │ ├── test_parity_missing.py │ │ │ │ │ ├── test_parity_rolling.py │ │ │ │ │ ├── test_parity_rolling_adv.py │ │ │ │ │ ├── test_parity_rolling_count.py │ │ │ │ │ └── test_parity_rolling_error.py │ │ │ ├── data_type_ops │ │ │ │ ├── __init__.py │ │ │ │ ├── test_as_type.py │ │ │ │ ├── test_base.py │ │ │ │ ├── test_binary_ops.py │ │ │ │ ├── test_boolean_ops.py │ │ │ │ ├── test_categorical_ops.py │ │ │ │ ├── test_complex_ops.py │ │ │ │ ├── test_date_ops.py │ │ │ │ ├── test_datetime_ops.py │ │ │ │ ├── test_null_ops.py │ │ │ │ ├── test_num_arithmetic.py │ │ │ │ ├── test_num_mod.py │ │ │ │ ├── test_num_mul_div.py │ │ │ │ ├── test_num_ops.py │ │ │ │ ├── test_num_pow.py │ │ │ │ ├── test_num_reverse.py │ │ │ │ ├── test_string_ops.py │ │ │ │ ├── test_timedelta_ops.py │ │ │ │ ├── test_udt_ops.py │ │ │ │ └── testing_utils.py │ │ │ ├── diff_frames_ops │ │ │ │ ├── __init__.py │ │ │ │ ├── test_align.py │ │ │ │ ├── test_arithmetic.py │ │ │ │ ├── test_arithmetic_chain.py │ │ │ │ ├── test_arithmetic_chain_ext.py │ │ │ │ ├── test_arithmetic_chain_ext_float.py │ │ │ │ ├── test_arithmetic_ext.py │ │ │ │ ├── test_arithmetic_ext_float.py │ │ │ │ ├── test_assign_frame.py │ │ │ │ ├── test_assign_series.py │ │ │ │ ├── test_basic.py │ │ │ │ ├── test_basic_slow.py │ │ │ │ ├── test_bitwise.py │ │ │ │ ├── test_combine_first.py │ │ │ │ ├── test_compare_series.py │ │ │ │ ├── test_concat_inner.py │ │ │ │ ├── test_concat_outer.py │ │ │ │ ├── test_corrwith.py │ │ │ │ ├── test_cov.py │ │ │ │ ├── test_dot_frame.py │ │ │ │ ├── test_dot_series.py │ │ │ │ ├── test_error.py │ │ │ │ ├── test_groupby.py │ │ │ │ ├── test_groupby_aggregate.py │ │ │ │ ├── test_groupby_apply.py │ │ │ │ ├── test_groupby_cumulative.py │ │ │ │ ├── test_groupby_diff.py │ │ │ │ ├── test_groupby_diff_len.py │ │ │ │ ├── test_groupby_expanding.py │ │ │ │ ├── test_groupby_expanding_adv.py │ │ │ │ ├── test_groupby_expanding_count.py │ │ │ │ ├── test_groupby_fillna.py │ │ │ │ ├── test_groupby_filter.py │ │ │ │ ├── test_groupby_rolling.py │ │ │ │ ├── test_groupby_rolling_adv.py │ │ │ │ ├── test_groupby_rolling_count.py │ │ │ │ ├── test_groupby_shift.py │ │ │ │ ├── test_groupby_split_apply_combine.py │ │ │ │ ├── test_groupby_transform.py │ │ │ │ ├── test_index.py │ │ │ │ ├── test_series.py │ │ │ │ ├── test_setitem_frame.py │ │ │ │ └── test_setitem_series.py │ │ │ ├── frame │ │ │ │ ├── __init__.py │ │ │ │ ├── test_asfreq.py │ │ │ │ ├── test_asof.py │ │ │ │ ├── test_attrs.py │ │ │ │ ├── test_axis.py │ │ │ │ ├── test_constructor.py │ │ │ │ ├── test_conversion.py │ │ │ │ ├── test_interpolate.py │ │ │ │ ├── test_interpolate_error.py │ │ │ │ ├── test_reindexing.py │ │ │ │ ├── test_reshaping.py │ │ │ │ ├── test_spark.py │ │ │ │ ├── test_take.py │ │ │ │ ├── test_take_adv.py │ │ │ │ ├── test_time_series.py │ │ │ │ └── test_truncate.py │ │ │ ├── groupby │ │ │ │ ├── __init__.py │ │ │ │ ├── test_aggregate.py │ │ │ │ ├── test_apply_func.py │ │ │ │ ├── test_corr.py │ │ │ │ ├── test_cumulative.py │ │ │ │ ├── test_describe.py │ │ │ │ ├── test_groupby.py │ │ │ │ ├── test_grouping.py │ │ │ │ ├── test_head_tail.py │ │ │ │ ├── test_index.py │ │ │ │ ├── test_missing.py │ │ │ │ ├── test_missing_data.py │ │ │ │ ├── test_nlargest_nsmallest.py │ │ │ │ ├── test_raises.py │ │ │ │ ├── test_rank.py │ │ │ │ ├── test_size.py │ │ │ │ ├── test_split_apply.py │ │ │ │ ├── test_split_apply_count.py │ │ │ │ ├── test_split_apply_first.py │ │ │ │ ├── test_split_apply_last.py │ │ │ │ ├── test_split_apply_min_max.py │ │ │ │ ├── test_split_apply_skew.py │ │ │ │ ├── test_split_apply_std.py │ │ │ │ ├── test_split_apply_var.py │ │ │ │ ├── test_stat.py │ │ │ │ ├── test_stat_adv.py │ │ │ │ ├── test_stat_ddof.py │ │ │ │ ├── test_stat_func.py │ │ │ │ ├── test_stat_prod.py │ │ │ │ └── test_value_counts.py │ │ │ ├── indexes │ │ │ │ ├── __init__.py │ │ │ │ ├── test_align.py │ │ │ │ ├── test_append.py │ │ │ │ ├── test_asof.py │ │ │ │ ├── test_astype.py │ │ │ │ ├── test_basic.py │ │ │ │ ├── test_category.py │ │ │ │ ├── test_conversion.py │ │ │ │ ├── test_datetime.py │ │ │ │ ├── test_datetime_at.py │ │ │ │ ├── test_datetime_between.py │ │ │ │ ├── test_datetime_ceil.py │ │ │ │ ├── test_datetime_floor.py │ │ │ │ ├── test_datetime_iso.py │ │ │ │ ├── test_datetime_map.py │ │ │ │ ├── test_datetime_property.py │ │ │ │ ├── test_datetime_round.py │ │ │ │ ├── test_default.py │ │ │ │ ├── test_delete.py │ │ │ │ ├── test_diff.py │ │ │ │ ├── test_drop.py │ │ │ │ ├── test_getattr.py │ │ │ │ ├── test_indexing.py │ │ │ │ ├── test_indexing_adv.py │ │ │ │ ├── test_indexing_basic.py │ │ │ │ ├── test_indexing_iloc.py │ │ │ │ ├── test_indexing_loc.py │ │ │ │ ├── test_indexing_loc_2d.py │ │ │ │ ├── test_indexing_loc_multi_idx.py │ │ │ │ ├── test_insert.py │ │ │ │ ├── test_intersection.py │ │ │ │ ├── test_level.py │ │ │ │ ├── test_map.py │ │ │ │ ├── test_missing.py │ │ │ │ ├── test_monotonic.py │ │ │ │ ├── test_name.py │ │ │ │ ├── test_reindex.py │ │ │ │ ├── test_rename.py │ │ │ │ ├── test_repeat.py │ │ │ │ ├── test_reset_index.py │ │ │ │ ├── test_sort.py │ │ │ │ ├── test_stat.py │ │ │ │ ├── test_symmetric_diff.py │ │ │ │ ├── test_take.py │ │ │ │ ├── test_timedelta.py │ │ │ │ ├── test_union.py │ │ │ │ └── test_unique.py │ │ │ ├── io │ │ │ │ ├── __init__.py │ │ │ │ ├── test_csv.py │ │ │ │ ├── test_dataframe_conversion.py │ │ │ │ ├── test_dataframe_spark_io.py │ │ │ │ ├── test_feather.py │ │ │ │ ├── test_io.py │ │ │ │ ├── test_series_conversion.py │ │ │ │ └── test_stata.py │ │ │ ├── plot │ │ │ │ ├── __init__.py │ │ │ │ ├── test_frame_plot.py │ │ │ │ ├── test_frame_plot_matplotlib.py │ │ │ │ ├── test_frame_plot_plotly.py │ │ │ │ ├── test_series_plot.py │ │ │ │ ├── test_series_plot_matplotlib.py │ │ │ │ └── test_series_plot_plotly.py │ │ │ ├── resample │ │ │ │ ├── __init__.py │ │ │ │ ├── test_error.py │ │ │ │ ├── test_frame.py │ │ │ │ ├── test_missing.py │ │ │ │ ├── test_on.py │ │ │ │ ├── test_series.py │ │ │ │ └── test_timezone.py │ │ │ ├── reshape │ │ │ │ ├── __init__.py │ │ │ │ ├── test_get_dummies.py │ │ │ │ ├── test_get_dummies_kwargs.py │ │ │ │ ├── test_get_dummies_multiindex.py │ │ │ │ ├── test_get_dummies_object.py │ │ │ │ ├── test_get_dummies_prefix.py │ │ │ │ └── test_merge_asof.py │ │ │ ├── series │ │ │ │ ├── __init__.py │ │ │ │ ├── test_all_any.py │ │ │ │ ├── test_arg_ops.py │ │ │ │ ├── test_as_of.py │ │ │ │ ├── test_as_type.py │ │ │ │ ├── test_compute.py │ │ │ │ ├── test_conversion.py │ │ │ │ ├── test_cumulative.py │ │ │ │ ├── test_datetime.py │ │ │ │ ├── test_index.py │ │ │ │ ├── test_interpolate.py │ │ │ │ ├── test_missing_data.py │ │ │ │ ├── test_series.py │ │ │ │ ├── test_sort.py │ │ │ │ ├── test_stat.py │ │ │ │ ├── test_string_ops_adv.py │ │ │ │ └── test_string_ops_basic.py │ │ │ ├── test_categorical.py │ │ │ ├── test_config.py │ │ │ ├── test_extension.py │ │ │ ├── test_frame_spark.py │ │ │ ├── test_generic_functions.py │ │ │ ├── test_indexops_spark.py │ │ │ ├── test_internal.py │ │ │ ├── test_namespace.py │ │ │ ├── test_numpy_compat.py │ │ │ ├── test_repr.py │ │ │ ├── test_scalars.py │ │ │ ├── test_spark_functions.py │ │ │ ├── test_sql.py │ │ │ ├── test_typedef.py │ │ │ ├── test_utils.py │ │ │ └── window │ │ │ │ ├── __init__.py │ │ │ │ ├── test_ewm_error.py │ │ │ │ ├── test_ewm_mean.py │ │ │ │ ├── test_expanding.py │ │ │ │ ├── test_expanding_adv.py │ │ │ │ ├── test_expanding_error.py │ │ │ │ ├── test_groupby_ewm_mean.py │ │ │ │ ├── test_groupby_expanding.py │ │ │ │ ├── test_groupby_expanding_adv.py │ │ │ │ ├── test_groupby_rolling.py │ │ │ │ ├── test_groupby_rolling_adv.py │ │ │ │ ├── test_groupby_rolling_count.py │ │ │ │ ├── test_missing.py │ │ │ │ ├── test_rolling.py │ │ │ │ ├── test_rolling_adv.py │ │ │ │ ├── test_rolling_count.py │ │ │ │ └── test_rolling_error.py │ │ ├── typedef │ │ │ ├── __init__.py │ │ │ └── typehints.py │ │ ├── usage_logging │ │ │ ├── __init__.py │ │ │ └── usage_logger.py │ │ ├── utils.py │ │ └── window.py │ ├── pipelines │ │ ├── __init__.py │ │ ├── add_pipeline_analysis_context.py │ │ ├── api.py │ │ ├── block_session_mutations.py │ │ ├── cli.py │ │ ├── flow.py │ │ ├── graph_element_registry.py │ │ ├── init_cli.py │ │ ├── logging_utils.py │ │ ├── output.py │ │ ├── source_code_location.py │ │ ├── spark_connect_graph_element_registry.py │ │ ├── spark_connect_pipeline.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── local_graph_element_registry.py │ │ │ ├── test_add_pipeline_analysis_context.py │ │ │ ├── test_block_session_mutations.py │ │ │ ├── test_cli.py │ │ │ ├── test_decorators.py │ │ │ ├── test_graph_element_registry.py │ │ │ ├── test_init_cli.py │ │ │ └── test_spark_connect.py │ │ └── type_error_utils.py │ ├── profiler.py │ ├── py.typed │ ├── rddsampler.py │ ├── resource │ │ ├── __init__.py │ │ ├── information.py │ │ ├── profile.py │ │ ├── requests.py │ │ └── tests │ │ │ ├── __init__.py │ │ │ ├── test_connect_resources.py │ │ │ └── test_resources.py │ ├── resultiterable.py │ ├── serializers.py │ ├── shell.py │ ├── shuffle.py │ ├── sql │ │ ├── __init__.py │ │ ├── _typing.pyi │ │ ├── avro │ │ │ ├── __init__.py │ │ │ └── functions.py │ │ ├── catalog.py │ │ ├── classic │ │ │ ├── __init__.py │ │ │ ├── column.py │ │ │ ├── dataframe.py │ │ │ ├── table_arg.py │ │ │ └── window.py │ │ ├── column.py │ │ ├── conf.py │ │ ├── connect │ │ │ ├── __init__.py │ │ │ ├── _typing.py │ │ │ ├── avro │ │ │ │ ├── __init__.py │ │ │ │ └── functions.py │ │ │ ├── catalog.py │ │ │ ├── client │ │ │ │ ├── __init__.py │ │ │ │ ├── artifact.py │ │ │ │ ├── core.py │ │ │ │ ├── reattach.py │ │ │ │ └── retries.py │ │ │ ├── column.py │ │ │ ├── conf.py │ │ │ ├── conversion.py │ │ │ ├── dataframe.py │ │ │ ├── datasource.py │ │ │ ├── expressions.py │ │ │ ├── functions │ │ │ │ ├── __init__.py │ │ │ │ ├── builtin.py │ │ │ │ └── partitioning.py │ │ │ ├── group.py │ │ │ ├── logging.py │ │ │ ├── merge.py │ │ │ ├── observation.py │ │ │ ├── plan.py │ │ │ ├── profiler.py │ │ │ ├── proto │ │ │ │ ├── __init__.py │ │ │ │ ├── base_pb2.py │ │ │ │ ├── base_pb2.pyi │ │ │ │ ├── base_pb2_grpc.py │ │ │ │ ├── catalog_pb2.py │ │ │ │ ├── catalog_pb2.pyi │ │ │ │ ├── commands_pb2.py │ │ │ │ ├── commands_pb2.pyi │ │ │ │ ├── common_pb2.py │ │ │ │ ├── common_pb2.pyi │ │ │ │ ├── example_plugins_pb2.py │ │ │ │ ├── example_plugins_pb2.pyi │ │ │ │ ├── expressions_pb2.py │ │ │ │ ├── expressions_pb2.pyi │ │ │ │ ├── ml_common_pb2.py │ │ │ │ ├── ml_common_pb2.pyi │ │ │ │ ├── ml_pb2.py │ │ │ │ ├── ml_pb2.pyi │ │ │ │ ├── pipelines_pb2.py │ │ │ │ ├── pipelines_pb2.pyi │ │ │ │ ├── relations_pb2.py │ │ │ │ ├── relations_pb2.pyi │ │ │ │ ├── types_pb2.py │ │ │ │ └── types_pb2.pyi │ │ │ ├── protobuf │ │ │ │ ├── __init__.py │ │ │ │ └── functions.py │ │ │ ├── readwriter.py │ │ │ ├── resource │ │ │ │ ├── __init__.py │ │ │ │ └── profile.py │ │ │ ├── session.py │ │ │ ├── shell │ │ │ │ ├── __init__.py │ │ │ │ └── progress.py │ │ │ ├── sql_formatter.py │ │ │ ├── streaming │ │ │ │ ├── __init__.py │ │ │ │ ├── query.py │ │ │ │ ├── readwriter.py │ │ │ │ └── worker │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── foreach_batch_worker.py │ │ │ │ │ └── listener_worker.py │ │ │ ├── table_arg.py │ │ │ ├── tvf.py │ │ │ ├── types.py │ │ │ ├── udf.py │ │ │ ├── udtf.py │ │ │ ├── utils.py │ │ │ └── window.py │ │ ├── context.py │ │ ├── conversion.py │ │ ├── dataframe.py │ │ ├── datasource.py │ │ ├── datasource_internal.py │ │ ├── functions │ │ │ ├── __init__.py │ │ │ ├── builtin.py │ │ │ └── partitioning.py │ │ ├── geo_utils.py │ │ ├── group.py │ │ ├── internal.py │ │ ├── merge.py │ │ ├── metrics.py │ │ ├── observation.py │ │ ├── pandas │ │ │ ├── __init__.py │ │ │ ├── _typing │ │ │ │ ├── __init__.pyi │ │ │ │ └── protocols │ │ │ │ │ ├── __init__.pyi │ │ │ │ │ ├── frame.pyi │ │ │ │ │ └── series.pyi │ │ │ ├── conversion.py │ │ │ ├── functions.py │ │ │ ├── functions.pyi │ │ │ ├── group_ops.py │ │ │ ├── map_ops.py │ │ │ ├── serializers.py │ │ │ ├── typehints.py │ │ │ ├── types.py │ │ │ └── utils.py │ │ ├── plot │ │ │ ├── __init__.py │ │ │ ├── core.py │ │ │ └── plotly.py │ │ ├── profiler.py │ │ ├── protobuf │ │ │ ├── __init__.py │ │ │ └── functions.py │ │ ├── readwriter.py │ │ ├── session.py │ │ ├── sql_formatter.py │ │ ├── streaming │ │ │ ├── __init__.py │ │ │ ├── benchmark │ │ │ │ ├── __init__.py │ │ │ │ ├── benchmark_tws_state_server.py │ │ │ │ ├── tws_utils.py │ │ │ │ └── utils.py │ │ │ ├── list_state_client.py │ │ │ ├── listener.py │ │ │ ├── map_state_client.py │ │ │ ├── proto │ │ │ │ ├── StateMessage_pb2.py │ │ │ │ ├── StateMessage_pb2.pyi │ │ │ │ └── __init__.py │ │ │ ├── python_streaming_source_runner.py │ │ │ ├── query.py │ │ │ ├── readwriter.py │ │ │ ├── state.py │ │ │ ├── stateful_processor.py │ │ │ ├── stateful_processor_api_client.py │ │ │ ├── stateful_processor_util.py │ │ │ ├── transform_with_state_driver_worker.py │ │ │ └── value_state_client.py │ │ ├── table_arg.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── arrow │ │ │ │ ├── __init__.py │ │ │ │ ├── test_arrow.py │ │ │ │ ├── test_arrow_cogrouped_map.py │ │ │ │ ├── test_arrow_grouped_map.py │ │ │ │ ├── test_arrow_map.py │ │ │ │ ├── test_arrow_python_udf.py │ │ │ │ ├── test_arrow_udf.py │ │ │ │ ├── test_arrow_udf_grouped_agg.py │ │ │ │ ├── test_arrow_udf_scalar.py │ │ │ │ ├── test_arrow_udf_typehints.py │ │ │ │ ├── test_arrow_udf_window.py │ │ │ │ └── test_arrow_udtf.py │ │ │ ├── connect │ │ │ │ ├── __init__.py │ │ │ │ ├── arrow │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_arrow.py │ │ │ │ │ ├── test_parity_arrow_cogrouped_map.py │ │ │ │ │ ├── test_parity_arrow_grouped_map.py │ │ │ │ │ ├── test_parity_arrow_map.py │ │ │ │ │ ├── test_parity_arrow_python_udf.py │ │ │ │ │ ├── test_parity_arrow_udf.py │ │ │ │ │ ├── test_parity_arrow_udf_grouped_agg.py │ │ │ │ │ ├── test_parity_arrow_udf_scalar.py │ │ │ │ │ ├── test_parity_arrow_udf_window.py │ │ │ │ │ └── test_parity_arrow_udtf.py │ │ │ │ ├── client │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_artifact.py │ │ │ │ │ ├── test_artifact_localcluster.py │ │ │ │ │ ├── test_client.py │ │ │ │ │ ├── test_client_retries.py │ │ │ │ │ └── test_reattach.py │ │ │ │ ├── pandas │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── streaming │ │ │ │ │ │ ├── __init__.py │ │ │ │ │ │ ├── test_parity_pandas_grouped_map_with_state.py │ │ │ │ │ │ ├── test_parity_pandas_transform_with_state.py │ │ │ │ │ │ ├── test_parity_pandas_transform_with_state_state_variable.py │ │ │ │ │ │ ├── test_parity_transform_with_state.py │ │ │ │ │ │ └── test_parity_transform_with_state_state_variable.py │ │ │ │ │ ├── test_parity_pandas_cogrouped_map.py │ │ │ │ │ ├── test_parity_pandas_grouped_map.py │ │ │ │ │ ├── test_parity_pandas_map.py │ │ │ │ │ ├── test_parity_pandas_udf.py │ │ │ │ │ ├── test_parity_pandas_udf_grouped_agg.py │ │ │ │ │ ├── test_parity_pandas_udf_scalar.py │ │ │ │ │ └── test_parity_pandas_udf_window.py │ │ │ │ ├── shell │ │ │ │ │ ├── __init__.py │ │ │ │ │ └── test_progress.py │ │ │ │ ├── streaming │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_parity_foreach.py │ │ │ │ │ ├── test_parity_foreach_batch.py │ │ │ │ │ ├── test_parity_listener.py │ │ │ │ │ └── test_parity_streaming.py │ │ │ │ ├── test_connect_basic.py │ │ │ │ ├── test_connect_channel.py │ │ │ │ ├── test_connect_clone_session.py │ │ │ │ ├── test_connect_collection.py │ │ │ │ ├── test_connect_column.py │ │ │ │ ├── test_connect_creation.py │ │ │ │ ├── test_connect_dataframe_property.py │ │ │ │ ├── test_connect_error.py │ │ │ │ ├── test_connect_function.py │ │ │ │ ├── test_connect_plan.py │ │ │ │ ├── test_connect_readwriter.py │ │ │ │ ├── test_connect_retry.py │ │ │ │ ├── test_connect_session.py │ │ │ │ ├── test_connect_stat.py │ │ │ │ ├── test_df_debug.py │ │ │ │ ├── test_parity_catalog.py │ │ │ │ ├── test_parity_collection.py │ │ │ │ ├── test_parity_column.py │ │ │ │ ├── test_parity_conf.py │ │ │ │ ├── test_parity_creation.py │ │ │ │ ├── test_parity_dataframe.py │ │ │ │ ├── test_parity_dataframe_query_context.py │ │ │ │ ├── test_parity_datasources.py │ │ │ │ ├── test_parity_errors.py │ │ │ │ ├── test_parity_frame_plot.py │ │ │ │ ├── test_parity_frame_plot_plotly.py │ │ │ │ ├── test_parity_functions.py │ │ │ │ ├── test_parity_geographytype.py │ │ │ │ ├── test_parity_geometrytype.py │ │ │ │ ├── test_parity_group.py │ │ │ │ ├── test_parity_job_cancellation.py │ │ │ │ ├── test_parity_memory_profiler.py │ │ │ │ ├── test_parity_observation.py │ │ │ │ ├── test_parity_python_datasource.py │ │ │ │ ├── test_parity_python_streaming_datasource.py │ │ │ │ ├── test_parity_readwriter.py │ │ │ │ ├── test_parity_repartition.py │ │ │ │ ├── test_parity_serde.py │ │ │ │ ├── test_parity_sql.py │ │ │ │ ├── test_parity_stat.py │ │ │ │ ├── test_parity_subquery.py │ │ │ │ ├── test_parity_tvf.py │ │ │ │ ├── test_parity_types.py │ │ │ │ ├── test_parity_udf.py │ │ │ │ ├── test_parity_udf_combinations.py │ │ │ │ ├── test_parity_udf_profiler.py │ │ │ │ ├── test_parity_udtf.py │ │ │ │ ├── test_parity_unified_udf.py │ │ │ │ ├── test_resources.py │ │ │ │ ├── test_session.py │ │ │ │ └── test_utils.py │ │ │ ├── pandas │ │ │ │ ├── __init__.py │ │ │ │ ├── helper │ │ │ │ │ ├── __init__.py │ │ │ │ │ └── helper_pandas_transform_with_state.py │ │ │ │ ├── streaming │ │ │ │ │ ├── __init__.py │ │ │ │ │ ├── test_pandas_transform_with_state.py │ │ │ │ │ ├── test_pandas_transform_with_state_checkpoint_v2.py │ │ │ │ │ ├── test_pandas_transform_with_state_state_variable.py │ │ │ │ │ ├── test_pandas_transform_with_state_state_variable_checkpoint_v2.py │ │ │ │ │ ├── test_transform_with_state.py │ │ │ │ │ ├── test_transform_with_state_checkpoint_v2.py │ │ │ │ │ ├── test_transform_with_state_state_variable.py │ │ │ │ │ └── test_transform_with_state_state_variable_checkpoint_v2.py │ │ │ │ ├── test_converter.py │ │ │ │ ├── test_pandas_cogrouped_map.py │ │ │ │ ├── test_pandas_grouped_map.py │ │ │ │ ├── test_pandas_grouped_map_with_state.py │ │ │ │ ├── test_pandas_map.py │ │ │ │ ├── test_pandas_sqlmetrics.py │ │ │ │ ├── test_pandas_udf.py │ │ │ │ ├── test_pandas_udf_grouped_agg.py │ │ │ │ ├── test_pandas_udf_scalar.py │ │ │ │ ├── test_pandas_udf_typehints.py │ │ │ │ ├── test_pandas_udf_typehints_with_future_annotations.py │ │ │ │ └── test_pandas_udf_window.py │ │ │ ├── plot │ │ │ │ ├── __init__.py │ │ │ │ ├── test_frame_plot.py │ │ │ │ └── test_frame_plot_plotly.py │ │ │ ├── streaming │ │ │ │ ├── __init__.py │ │ │ │ ├── test_streaming.py │ │ │ │ ├── test_streaming_foreach.py │ │ │ │ ├── test_streaming_foreach_batch.py │ │ │ │ └── test_streaming_listener.py │ │ │ ├── test_artifact.py │ │ │ ├── test_catalog.py │ │ │ ├── test_collection.py │ │ │ ├── test_column.py │ │ │ ├── test_conf.py │ │ │ ├── test_connect_compatibility.py │ │ │ ├── test_context.py │ │ │ ├── test_conversion.py │ │ │ ├── test_creation.py │ │ │ ├── test_dataframe.py │ │ │ ├── test_dataframe_query_context.py │ │ │ ├── test_datasources.py │ │ │ ├── test_errors.py │ │ │ ├── test_functions.py │ │ │ ├── test_geographytype.py │ │ │ ├── test_geometrytype.py │ │ │ ├── test_group.py │ │ │ ├── test_job_cancellation.py │ │ │ ├── test_listener.py │ │ │ ├── test_observation.py │ │ │ ├── test_python_datasource.py │ │ │ ├── test_python_streaming_datasource.py │ │ │ ├── test_readwriter.py │ │ │ ├── test_repartition.py │ │ │ ├── test_resources.py │ │ │ ├── test_serde.py │ │ │ ├── test_session.py │ │ │ ├── test_sql.py │ │ │ ├── test_stat.py │ │ │ ├── test_subquery.py │ │ │ ├── test_tvf.py │ │ │ ├── test_types.py │ │ │ ├── test_udf.py │ │ │ ├── test_udf_combinations.py │ │ │ ├── test_udf_profiler.py │ │ │ ├── test_udtf.py │ │ │ ├── test_unified_udf.py │ │ │ ├── test_utils.py │ │ │ ├── typing │ │ │ │ ├── test_column.yml │ │ │ │ ├── test_dataframe.yml │ │ │ │ ├── test_functions.yml │ │ │ │ ├── test_readwriter.yml │ │ │ │ ├── test_session.yml │ │ │ │ └── test_udf.yml │ │ │ └── udf_type_tests │ │ │ │ ├── README.md │ │ │ │ ├── __init__.py │ │ │ │ ├── golden_pandas_udf_input_types.txt │ │ │ │ ├── golden_pandas_udf_return_type_coercion.txt │ │ │ │ ├── golden_udf_input_types_arrow_disabled.txt │ │ │ │ ├── golden_udf_input_types_arrow_enabled.txt │ │ │ │ ├── golden_udf_input_types_arrow_legacy_pandas.txt │ │ │ │ ├── golden_udf_return_type_coercion_arrow_disabled.txt │ │ │ │ ├── golden_udf_return_type_coercion_arrow_enabled.txt │ │ │ │ ├── golden_udf_return_type_coercion_arrow_legacy_pandas.txt │ │ │ │ ├── test_udf_input_types.py │ │ │ │ ├── test_udf_return_types.py │ │ │ │ └── type_table_utils.py │ │ ├── tvf.py │ │ ├── tvf_argument.py │ │ ├── types.py │ │ ├── udf.py │ │ ├── udtf.py │ │ ├── utils.py │ │ ├── variant_utils.py │ │ ├── window.py │ │ └── worker │ │ │ ├── __init__.py │ │ │ ├── analyze_udtf.py │ │ │ ├── commit_data_source_write.py │ │ │ ├── create_data_source.py │ │ │ ├── data_source_pushdown_filters.py │ │ │ ├── lookup_data_sources.py │ │ │ ├── plan_data_source_read.py │ │ │ ├── python_streaming_sink_runner.py │ │ │ └── write_into_data_source.py │ ├── statcounter.py │ ├── storagelevel.py │ ├── streaming │ │ ├── __init__.py │ │ ├── context.py │ │ ├── dstream.py │ │ ├── kinesis.py │ │ ├── listener.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── test_context.py │ │ │ ├── test_dstream.py │ │ │ ├── test_kinesis.py │ │ │ └── test_listener.py │ │ └── util.py │ ├── taskcontext.py │ ├── testing │ │ ├── __init__.py │ │ ├── connectutils.py │ │ ├── mllibutils.py │ │ ├── mlutils.py │ │ ├── objects.py │ │ ├── pandasutils.py │ │ ├── sqlutils.py │ │ ├── streamingutils.py │ │ ├── tests │ │ │ ├── __init__.py │ │ │ ├── test_fail.py │ │ │ ├── test_fail_in_set_up_class.py │ │ │ ├── test_no_tests.py │ │ │ ├── test_pass_all.py │ │ │ ├── test_skip_all.py │ │ │ ├── test_skip_class.py │ │ │ └── test_skip_set_up_class.py │ │ └── utils.py │ ├── tests │ │ ├── __init__.py │ │ ├── test_appsubmit.py │ │ ├── test_broadcast.py │ │ ├── test_conf.py │ │ ├── test_context.py │ │ ├── test_daemon.py │ │ ├── test_install_spark.py │ │ ├── test_join.py │ │ ├── test_memory_profiler.py │ │ ├── test_pin_thread.py │ │ ├── test_profiler.py │ │ ├── test_rdd.py │ │ ├── test_rddbarrier.py │ │ ├── test_rddsampler.py │ │ ├── test_readwrite.py │ │ ├── test_serializers.py │ │ ├── test_shuffle.py │ │ ├── test_stage_sched.py │ │ ├── test_statcounter.py │ │ ├── test_taskcontext.py │ │ ├── test_util.py │ │ ├── test_worker.py │ │ └── typing │ │ │ ├── test_context.yml │ │ │ ├── test_core.yml │ │ │ ├── test_rdd.yml │ │ │ └── test_resultiterable.yml │ ├── traceback_utils.py │ ├── util.py │ ├── version.py │ ├── worker.py │ └── worker_util.py ├── run-tests ├── run-tests-with-coverage ├── run-tests.py ├── run-with-viztracer ├── run-with-vscode-breakpoints ├── test_coverage │ └── sitecustomize.py └── test_support │ ├── SimpleHTTPServer.py │ ├── hello │ ├── hello.txt │ └── sub_hello │ │ └── sub_hello.txt │ ├── log4j2.properties │ ├── sql │ ├── ages_newlines.csv │ ├── orc_partitioned │ │ ├── _SUCCESS │ │ ├── b=0 │ │ │ └── c=0 │ │ │ │ ├── .part-r-00000-829af031-b970-49d6-ad39-30460a0be2c8.orc.crc │ │ │ │ └── part-r-00000-829af031-b970-49d6-ad39-30460a0be2c8.orc │ │ └── b=1 │ │ │ └── c=1 │ │ │ ├── .part-r-00000-829af031-b970-49d6-ad39-30460a0be2c8.orc.crc │ │ │ └── part-r-00000-829af031-b970-49d6-ad39-30460a0be2c8.orc │ ├── people.json │ ├── people1.json │ ├── people_array.json │ ├── people_array_utf16le.json │ ├── streaming │ │ ├── text-test.txt │ │ └── time │ │ │ └── text-with-time-test.txt │ └── text-test.txt │ ├── test_pytorch_training_file.py │ ├── userlib-0.1.zip │ └── userlibrary.py ├── repl ├── pom.xml └── src │ ├── main │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── repl │ │ ├── Main.scala │ │ ├── Signaling.scala │ │ └── SparkILoop.scala │ └── test │ ├── resources │ └── log4j2.properties │ └── scala │ └── org │ └── apache │ └── spark │ └── repl │ ├── IntSumUdf.scala │ ├── ReplSuite.scala │ ├── SingletonReplSuite.scala │ └── SparkShellSuite.scala ├── resource-managers ├── kubernetes │ ├── core │ │ ├── pom.xml │ │ ├── src │ │ │ ├── main │ │ │ │ ├── resources │ │ │ │ │ └── META-INF │ │ │ │ │ │ └── services │ │ │ │ │ │ ├── org.apache.spark.deploy.SparkDiagnosticsSetter │ │ │ │ │ │ ├── org.apache.spark.deploy.SparkSubmitOperation │ │ │ │ │ │ └── org.apache.spark.scheduler.ExternalClusterManager │ │ │ │ └── scala │ │ │ │ │ └── org │ │ │ │ │ └── apache │ │ │ │ │ └── spark │ │ │ │ │ ├── deploy │ │ │ │ │ └── k8s │ │ │ │ │ │ ├── Config.scala │ │ │ │ │ │ ├── Constants.scala │ │ │ │ │ │ ├── KubernetesConf.scala │ │ │ │ │ │ ├── KubernetesDriverSpec.scala │ │ │ │ │ │ ├── KubernetesExecutorSpec.scala │ │ │ │ │ │ ├── KubernetesUtils.scala │ │ │ │ │ │ ├── KubernetesVolumeSpec.scala │ │ │ │ │ │ ├── KubernetesVolumeUtils.scala │ │ │ │ │ │ ├── SparkKubernetesClientFactory.scala │ │ │ │ │ │ ├── SparkKubernetesDiagnosticsSetter.scala │ │ │ │ │ │ ├── SparkPod.scala │ │ │ │ │ │ ├── features │ │ │ │ │ │ ├── BasicDriverFeatureStep.scala │ │ │ │ │ │ ├── BasicExecutorFeatureStep.scala │ │ │ │ │ │ ├── DriverCommandFeatureStep.scala │ │ │ │ │ │ ├── DriverKubernetesCredentialsFeatureStep.scala │ │ │ │ │ │ ├── DriverServiceFeatureStep.scala │ │ │ │ │ │ ├── EnvSecretsFeatureStep.scala │ │ │ │ │ │ ├── ExecutorKubernetesCredentialsFeatureStep.scala │ │ │ │ │ │ ├── HadoopConfDriverFeatureStep.scala │ │ │ │ │ │ ├── HadoopConfExecutorFeatureStep.scala │ │ │ │ │ │ ├── KerberosConfDriverFeatureStep.scala │ │ │ │ │ │ ├── KubernetesDriverCustomFeatureConfigStep.scala │ │ │ │ │ │ ├── KubernetesExecutorCustomFeatureConfigStep.scala │ │ │ │ │ │ ├── KubernetesFeatureConfigStep.scala │ │ │ │ │ │ ├── LocalDirsFeatureStep.scala │ │ │ │ │ │ ├── MountSecretsFeatureStep.scala │ │ │ │ │ │ ├── MountVolumesFeatureStep.scala │ │ │ │ │ │ └── PodTemplateConfigMapStep.scala │ │ │ │ │ │ └── submit │ │ │ │ │ │ ├── K8sSubmitOps.scala │ │ │ │ │ │ ├── KubernetesClientApplication.scala │ │ │ │ │ │ ├── KubernetesClientUtils.scala │ │ │ │ │ │ ├── KubernetesDriverBuilder.scala │ │ │ │ │ │ ├── LoggingPodStatusWatcher.scala │ │ │ │ │ │ └── MainAppResource.scala │ │ │ │ │ ├── scheduler │ │ │ │ │ └── cluster │ │ │ │ │ │ └── k8s │ │ │ │ │ │ ├── AbstractPodsAllocator.scala │ │ │ │ │ │ ├── DeploymentPodsAllocator.scala │ │ │ │ │ │ ├── ExecutorPodStates.scala │ │ │ │ │ │ ├── ExecutorPodsAllocator.scala │ │ │ │ │ │ ├── ExecutorPodsLifecycleManager.scala │ │ │ │ │ │ ├── ExecutorPodsPollingSnapshotSource.scala │ │ │ │ │ │ ├── ExecutorPodsSnapshot.scala │ │ │ │ │ │ ├── ExecutorPodsSnapshotsStore.scala │ │ │ │ │ │ ├── ExecutorPodsSnapshotsStoreImpl.scala │ │ │ │ │ │ ├── ExecutorPodsWatchSnapshotSource.scala │ │ │ │ │ │ ├── ExecutorRollPlugin.scala │ │ │ │ │ │ ├── KubernetesClusterManager.scala │ │ │ │ │ │ ├── KubernetesClusterMessage.scala │ │ │ │ │ │ ├── KubernetesClusterSchedulerBackend.scala │ │ │ │ │ │ ├── KubernetesExecutorBackend.scala │ │ │ │ │ │ ├── KubernetesExecutorBuilder.scala │ │ │ │ │ │ └── StatefulSetPodsAllocator.scala │ │ │ │ │ └── shuffle │ │ │ │ │ ├── KubernetesLocalDiskShuffleDataIO.scala │ │ │ │ │ └── KubernetesLocalDiskShuffleExecutorComponents.scala │ │ │ └── test │ │ │ │ ├── resources │ │ │ │ ├── driver-podgroup-template.yml │ │ │ │ └── log4j2.properties │ │ │ │ └── scala │ │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ ├── deploy │ │ │ │ └── k8s │ │ │ │ │ ├── Fabric8Aliases.scala │ │ │ │ │ ├── KubernetesConfSuite.scala │ │ │ │ │ ├── KubernetesTestConf.scala │ │ │ │ │ ├── KubernetesUtilsSuite.scala │ │ │ │ │ ├── KubernetesVolumeUtilsSuite.scala │ │ │ │ │ ├── PodBuilderSuite.scala │ │ │ │ │ ├── SecretVolumeUtils.scala │ │ │ │ │ ├── SparkKubernetesDiagnosticsSetterSuite.scala │ │ │ │ │ ├── features │ │ │ │ │ ├── BasicDriverFeatureStepSuite.scala │ │ │ │ │ ├── BasicExecutorFeatureStepSuite.scala │ │ │ │ │ ├── DriverCommandFeatureStepSuite.scala │ │ │ │ │ ├── DriverKubernetesCredentialsFeatureStepSuite.scala │ │ │ │ │ ├── DriverServiceFeatureStepSuite.scala │ │ │ │ │ ├── EnvSecretsFeatureStepSuite.scala │ │ │ │ │ ├── ExecutorKubernetesCredentialsFeatureStepSuite.scala │ │ │ │ │ ├── HadoopConfDriverFeatureStepSuite.scala │ │ │ │ │ ├── HadoopConfExecutorFeatureStepSuite.scala │ │ │ │ │ ├── KerberosConfDriverFeatureStepSuite.scala │ │ │ │ │ ├── KubernetesFeaturesTestUtils.scala │ │ │ │ │ ├── LocalDirsFeatureStepSuite.scala │ │ │ │ │ ├── MountSecretsFeatureStepSuite.scala │ │ │ │ │ ├── MountVolumesFeatureStepSuite.scala │ │ │ │ │ └── PodTemplateConfigMapStepSuite.scala │ │ │ │ │ └── submit │ │ │ │ │ ├── ClientSuite.scala │ │ │ │ │ ├── K8sSubmitOpSuite.scala │ │ │ │ │ ├── KubernetesClientUtilsSuite.scala │ │ │ │ │ └── KubernetesDriverBuilderSuite.scala │ │ │ │ ├── scheduler │ │ │ │ └── cluster │ │ │ │ │ └── k8s │ │ │ │ │ ├── DeploymentAllocatorSuite.scala │ │ │ │ │ ├── DeterministicExecutorPodsSnapshotsStore.scala │ │ │ │ │ ├── ExecutorLifecycleTestUtils.scala │ │ │ │ │ ├── ExecutorPodsAllocatorSuite.scala │ │ │ │ │ ├── ExecutorPodsLifecycleManagerSuite.scala │ │ │ │ │ ├── ExecutorPodsPollingSnapshotSourceSuite.scala │ │ │ │ │ ├── ExecutorPodsSnapshotSuite.scala │ │ │ │ │ ├── ExecutorPodsSnapshotsStoreSuite.scala │ │ │ │ │ ├── ExecutorPodsWatchSnapshotSourceSuite.scala │ │ │ │ │ ├── ExecutorRollPluginSuite.scala │ │ │ │ │ ├── KubernetesClusterManagerSuite.scala │ │ │ │ │ ├── KubernetesClusterSchedulerBackendSuite.scala │ │ │ │ │ ├── KubernetesExecutorBuilderSuite.scala │ │ │ │ │ └── StatefulSetAllocatorSuite.scala │ │ │ │ └── shuffle │ │ │ │ ├── KubernetesLocalDiskShuffleDataIOSuite.scala │ │ │ │ └── ShuffleChecksumUtilsSuite.scala │ │ └── volcano │ │ │ └── src │ │ │ ├── main │ │ │ └── scala │ │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── deploy │ │ │ │ └── k8s │ │ │ │ └── features │ │ │ │ └── VolcanoFeatureStep.scala │ │ │ └── test │ │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── deploy │ │ │ └── k8s │ │ │ └── features │ │ │ └── VolcanoFeatureStepSuite.scala │ ├── docker │ │ └── src │ │ │ └── main │ │ │ └── dockerfiles │ │ │ └── spark │ │ │ ├── Dockerfile │ │ │ ├── bindings │ │ │ ├── R │ │ │ │ └── Dockerfile │ │ │ └── python │ │ │ │ └── Dockerfile │ │ │ ├── decom.sh │ │ │ └── entrypoint.sh │ └── integration-tests │ │ ├── README.md │ │ ├── dev │ │ ├── dev-run-integration-tests.sh │ │ └── spark-rbac.yaml │ │ ├── pom.xml │ │ ├── scripts │ │ └── setup-integration-test-env.sh │ │ ├── src │ │ └── test │ │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── deploy │ │ │ │ └── k8s │ │ │ │ └── integrationtest │ │ │ │ └── YuniKornTag.java │ │ │ ├── resources │ │ │ ├── driver-schedule-template.yml │ │ │ ├── driver-template.yml │ │ │ ├── executor-template.yml │ │ │ ├── log-config-test-log4j.properties │ │ │ ├── log4j2.properties │ │ │ ├── pagerank_data.txt │ │ │ └── volcano │ │ │ │ ├── driver-podgroup-template-memory-3g.yml │ │ │ │ ├── high-priority-driver-podgroup-template.yml │ │ │ │ ├── high-priority-driver-template.yml │ │ │ │ ├── low-priority-driver-podgroup-template.yml │ │ │ │ ├── low-priority-driver-template.yml │ │ │ │ ├── medium-priority-driver-podgroup-template.yml │ │ │ │ ├── medium-priority-driver-template.yml │ │ │ │ ├── priorityClasses.yml │ │ │ │ ├── queue-driver-podgroup-template.yml │ │ │ │ ├── queue0-driver-podgroup-template.yml │ │ │ │ └── queue1-driver-podgroup-template.yml │ │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── deploy │ │ │ └── k8s │ │ │ └── integrationtest │ │ │ ├── BasicTestsSuite.scala │ │ │ ├── ClientModeTestsSuite.scala │ │ │ ├── DecommissionSuite.scala │ │ │ ├── DepsTestsSuite.scala │ │ │ ├── KubernetesSuite.scala │ │ │ ├── KubernetesTestComponents.scala │ │ │ ├── PVTestsSuite.scala │ │ │ ├── PodTemplateSuite.scala │ │ │ ├── ProcessUtils.scala │ │ │ ├── PythonTestsSuite.scala │ │ │ ├── RTestsSuite.scala │ │ │ ├── SecretsTestsSuite.scala │ │ │ ├── SparkConfPropagateSuite.scala │ │ │ ├── SparkReadinessWatcher.scala │ │ │ ├── TestConstants.scala │ │ │ ├── Utils.scala │ │ │ ├── VolumeSuite.scala │ │ │ ├── YuniKornSuite.scala │ │ │ └── backend │ │ │ ├── IntegrationTestBackend.scala │ │ │ ├── cloud │ │ │ └── KubeConfigBackend.scala │ │ │ ├── docker │ │ │ └── DockerForDesktopBackend.scala │ │ │ └── minikube │ │ │ ├── Minikube.scala │ │ │ └── MinikubeTestBackend.scala │ │ ├── tests │ │ ├── autoscale.py │ │ ├── decommissioning.py │ │ ├── decommissioning_cleanup.py │ │ ├── py_container_checks.py │ │ ├── pyfiles.py │ │ ├── pyfiles_connect.py │ │ ├── python_executable_check.py │ │ └── worker_memory_check.py │ │ └── volcano │ │ └── src │ │ └── test │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── deploy │ │ └── k8s │ │ └── integrationtest │ │ ├── VolcanoSuite.scala │ │ └── VolcanoTestsSuite.scala └── yarn │ ├── pom.xml │ └── src │ ├── main │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── deploy │ │ │ └── yarn │ │ │ ├── AmIpFilter.java │ │ │ ├── AmIpPrincipal.java │ │ │ ├── AmIpServletRequestWrapper.java │ │ │ └── ProxyUtils.java │ ├── resources │ │ ├── META-INF │ │ │ └── services │ │ │ │ └── org.apache.spark.scheduler.ExternalClusterManager │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── deploy │ │ │ └── yarn │ │ │ └── config.properties │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── deploy │ │ └── yarn │ │ │ ├── ApplicationMaster.scala │ │ │ ├── ApplicationMasterArguments.scala │ │ │ ├── ApplicationMasterSource.scala │ │ │ ├── Client.scala │ │ │ ├── ClientArguments.scala │ │ │ ├── ClientDistributedCacheManager.scala │ │ │ ├── ExecutorRunnable.scala │ │ │ ├── LocalityPreferredContainerPlacementStrategy.scala │ │ │ ├── ResourceRequestHelper.scala │ │ │ ├── SparkRackResolver.scala │ │ │ ├── YarnAllocator.scala │ │ │ ├── YarnAllocatorNodeHealthTracker.scala │ │ │ ├── YarnProxyRedirectFilter.scala │ │ │ ├── YarnRMClient.scala │ │ │ ├── YarnSparkHadoopUtil.scala │ │ │ └── config │ │ │ └── package.scala │ │ ├── executor │ │ └── YarnCoarseGrainedExecutorBackend.scala │ │ ├── launcher │ │ └── YarnCommandBuilderUtils.scala │ │ ├── scheduler │ │ └── cluster │ │ │ ├── YarnClientSchedulerBackend.scala │ │ │ ├── YarnClusterManager.scala │ │ │ ├── YarnClusterScheduler.scala │ │ │ ├── YarnClusterSchedulerBackend.scala │ │ │ ├── YarnScheduler.scala │ │ │ └── YarnSchedulerBackend.scala │ │ └── util │ │ └── YarnContainerInfoHelper.scala │ └── test │ ├── resources │ ├── certchain.pem │ ├── key.pem │ ├── keystore │ ├── log4j2.properties │ ├── truststore │ ├── unencrypted-certchain.pem │ ├── unencrypted-key.pem │ └── untrusted-keystore │ └── scala │ └── org │ └── apache │ └── spark │ ├── deploy │ └── yarn │ │ ├── AmIpFilterSuite.scala │ │ ├── ApplicationMasterSuite.scala │ │ ├── BaseYarnClusterSuite.scala │ │ ├── ClientDistributedCacheManagerSuite.scala │ │ ├── ClientSuite.scala │ │ ├── ContainerPlacementStrategySuite.scala │ │ ├── ExecutorRunnableSuite.scala │ │ ├── LocalityPlacementStrategySuite.scala │ │ ├── ResourceRequestHelperSuite.scala │ │ ├── ResourceRequestTestHelper.scala │ │ ├── YarnAllocatorHealthTrackerSuite.scala │ │ ├── YarnAllocatorSuite.scala │ │ ├── YarnClusterSuite.scala │ │ ├── YarnProxyRedirectFilterSuite.scala │ │ ├── YarnShuffleAlternateNameConfigSuite.scala │ │ ├── YarnShuffleIntegrationSuite.scala │ │ └── YarnSparkHadoopUtilSuite.scala │ ├── launcher │ └── TestClasspathBuilder.scala │ ├── network │ ├── shuffle │ │ └── ShuffleTestAccessor.scala │ └── yarn │ │ ├── SslYarnShuffleServiceSuite.scala │ │ ├── YarnShuffleServiceMetricsSuite.scala │ │ ├── YarnShuffleServiceSuite.scala │ │ └── YarnTestAccessor.scala │ └── scheduler │ └── cluster │ └── YarnSchedulerBackendSuite.scala ├── sbin ├── decommission-worker.sh ├── spark-config.sh ├── spark-daemon.sh ├── spark-daemons.sh ├── start-all.sh ├── start-connect-server.sh ├── start-history-server.sh ├── start-master.sh ├── start-thriftserver.sh ├── start-worker.sh ├── start-workers.sh ├── stop-all.sh ├── stop-connect-server.sh ├── stop-history-server.sh ├── stop-master.sh ├── stop-thriftserver.sh ├── stop-worker.sh ├── stop-workers.sh └── workers.sh ├── scalastyle-config.xml ├── sql ├── README.md ├── api │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── antlr4 │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── catalyst │ │ │ │ └── parser │ │ │ │ ├── SqlBaseLexer.g4 │ │ │ │ └── SqlBaseParser.g4 │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ ├── api │ │ │ │ └── java │ │ │ │ │ └── function │ │ │ │ │ ├── FlatMapGroupsWithStateFunction.java │ │ │ │ │ └── MapGroupsWithStateFunction.java │ │ │ │ └── sql │ │ │ │ ├── RowFactory.java │ │ │ │ ├── SaveMode.java │ │ │ │ ├── api │ │ │ │ └── java │ │ │ │ │ ├── UDF0.java │ │ │ │ │ ├── UDF1.java │ │ │ │ │ ├── UDF10.java │ │ │ │ │ ├── UDF11.java │ │ │ │ │ ├── UDF12.java │ │ │ │ │ ├── UDF13.java │ │ │ │ │ ├── UDF14.java │ │ │ │ │ ├── UDF15.java │ │ │ │ │ ├── UDF16.java │ │ │ │ │ ├── UDF17.java │ │ │ │ │ ├── UDF18.java │ │ │ │ │ ├── UDF19.java │ │ │ │ │ ├── UDF2.java │ │ │ │ │ ├── UDF20.java │ │ │ │ │ ├── UDF21.java │ │ │ │ │ ├── UDF22.java │ │ │ │ │ ├── UDF3.java │ │ │ │ │ ├── UDF4.java │ │ │ │ │ ├── UDF5.java │ │ │ │ │ ├── UDF6.java │ │ │ │ │ ├── UDF7.java │ │ │ │ │ ├── UDF8.java │ │ │ │ │ ├── UDF9.java │ │ │ │ │ └── package-info.java │ │ │ │ ├── connector │ │ │ │ └── catalog │ │ │ │ │ ├── Identifier.java │ │ │ │ │ ├── IdentifierImpl.java │ │ │ │ │ └── IdentityColumnSpec.java │ │ │ │ ├── expressions │ │ │ │ └── javalang │ │ │ │ │ └── typed.java │ │ │ │ ├── streaming │ │ │ │ ├── GroupStateTimeout.java │ │ │ │ ├── OutputMode.java │ │ │ │ ├── TimeMode.java │ │ │ │ └── Trigger.java │ │ │ │ └── types │ │ │ │ ├── DataTypes.java │ │ │ │ ├── Geography.java │ │ │ │ ├── Geometry.java │ │ │ │ └── SQLUserDefinedType.java │ │ ├── resources │ │ │ ├── gregorian-julian-rebase-micros.json │ │ │ └── julian-gregorian-rebase-micros.json │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ ├── AnalysisException.scala │ │ │ ├── Artifact.scala │ │ │ ├── Column.scala │ │ │ ├── DataFrameNaFunctions.scala │ │ │ ├── DataFrameReader.scala │ │ │ ├── DataFrameStatFunctions.scala │ │ │ ├── DataFrameWriter.scala │ │ │ ├── DataFrameWriterV2.scala │ │ │ ├── Dataset.scala │ │ │ ├── DatasetHolder.scala │ │ │ ├── Encoder.scala │ │ │ ├── Encoders.scala │ │ │ ├── ForeachWriter.scala │ │ │ ├── KeyValueGroupedDataset.scala │ │ │ ├── MergeIntoWriter.scala │ │ │ ├── Observation.scala │ │ │ ├── RelationalGroupedDataset.scala │ │ │ ├── Row.scala │ │ │ ├── RuntimeConfig.scala │ │ │ ├── SQLContext.scala │ │ │ ├── SQLImplicits.scala │ │ │ ├── SparkSession.scala │ │ │ ├── TableValuedFunction.scala │ │ │ ├── UDFRegistration.scala │ │ │ ├── avro │ │ │ └── functions.scala │ │ │ ├── catalog │ │ │ ├── Catalog.scala │ │ │ └── interface.scala │ │ │ ├── catalyst │ │ │ ├── DefinedByConstructorParams.scala │ │ │ ├── JavaTypeInference.scala │ │ │ ├── ScalaReflection.scala │ │ │ ├── WalkedTypePath.scala │ │ │ ├── analysis │ │ │ │ ├── NonEmptyException.scala │ │ │ │ ├── SqlApiAnalysis.scala │ │ │ │ ├── alreadyExistException.scala │ │ │ │ └── noSuchItemsExceptions.scala │ │ │ ├── encoders │ │ │ │ ├── AgnosticEncoder.scala │ │ │ │ ├── OuterScopes.scala │ │ │ │ ├── RowEncoder.scala │ │ │ │ └── codecs.scala │ │ │ ├── expressions │ │ │ │ ├── OrderUtils.scala │ │ │ │ └── rows.scala │ │ │ ├── parser │ │ │ │ ├── DataTypeAstBuilder.scala │ │ │ │ ├── DataTypeParserInterface.scala │ │ │ │ ├── LegacyTypeStringParser.scala │ │ │ │ ├── PositionMapper.scala │ │ │ │ ├── SparkParserErrorStrategy.scala │ │ │ │ ├── SubstituteParmsAstBuilder.scala │ │ │ │ └── parsers.scala │ │ │ ├── plans │ │ │ │ └── logical │ │ │ │ │ ├── LogicalGroupState.scala │ │ │ │ │ ├── TimeMode.scala │ │ │ │ │ └── groupStateTimeouts.scala │ │ │ ├── streaming │ │ │ │ └── InternalOutputModes.scala │ │ │ ├── trees │ │ │ │ ├── QueryContexts.scala │ │ │ │ └── origin.scala │ │ │ └── util │ │ │ │ ├── AttributeNameParser.scala │ │ │ │ ├── CaseInsensitiveMap.scala │ │ │ │ ├── DataTypeJsonUtils.scala │ │ │ │ ├── DateFormatter.scala │ │ │ │ ├── DateTimeFormatterHelper.scala │ │ │ │ ├── MathUtils.scala │ │ │ │ ├── QuotingUtils.scala │ │ │ │ ├── RebaseDateTime.scala │ │ │ │ ├── ResolveDefaultColumnsUtils.scala │ │ │ │ ├── SparkCharVarcharUtils.scala │ │ │ │ ├── SparkDateTimeUtils.scala │ │ │ │ ├── SparkIntervalUtils.scala │ │ │ │ ├── SparkParserUtils.scala │ │ │ │ ├── StringConcat.scala │ │ │ │ ├── TimeFormatter.scala │ │ │ │ ├── TimestampFormatter.scala │ │ │ │ └── UDTUtils.scala │ │ │ ├── errors │ │ │ ├── CompilationErrors.scala │ │ │ ├── DataTypeErrors.scala │ │ │ ├── DataTypeErrorsBase.scala │ │ │ ├── ExecutionErrors.scala │ │ │ └── QueryParsingErrors.scala │ │ │ ├── execution │ │ │ └── streaming │ │ │ │ └── Triggers.scala │ │ │ ├── expressions │ │ │ ├── Aggregator.scala │ │ │ ├── ReduceAggregator.scala │ │ │ ├── UserDefinedFunction.scala │ │ │ ├── Window.scala │ │ │ ├── WindowSpec.scala │ │ │ ├── scalalang │ │ │ │ └── typed.scala │ │ │ └── udaf.scala │ │ │ ├── functions.scala │ │ │ ├── internal │ │ │ ├── LegacyBehaviorPolicy.scala │ │ │ ├── SqlApiConf.scala │ │ │ ├── SqlApiConfHelper.scala │ │ │ ├── TableValuedFunctionArgument.scala │ │ │ ├── ToScalaUDF.scala │ │ │ ├── columnNodes.scala │ │ │ ├── typedaggregators.scala │ │ │ └── types │ │ │ │ ├── AbstractArrayType.scala │ │ │ │ ├── AbstractMapType.scala │ │ │ │ ├── AbstractStringType.scala │ │ │ │ ├── CartesianSpatialReferenceSystemMapper.java │ │ │ │ ├── GeographicSpatialReferenceSystemMapper.java │ │ │ │ ├── SpatialReferenceSystemCache.java │ │ │ │ ├── SpatialReferenceSystemInformation.java │ │ │ │ └── SpatialReferenceSystemMapper.java │ │ │ ├── package.scala │ │ │ ├── protobuf │ │ │ └── functions.scala │ │ │ ├── streaming │ │ │ ├── DataStreamReader.scala │ │ │ ├── DataStreamWriter.scala │ │ │ ├── ExpiredTimerInfo.scala │ │ │ ├── GroupState.scala │ │ │ ├── ListState.scala │ │ │ ├── MapState.scala │ │ │ ├── QueryInfo.scala │ │ │ ├── StatefulProcessor.scala │ │ │ ├── StatefulProcessorHandle.scala │ │ │ ├── StreamingCheckpointManager.scala │ │ │ ├── StreamingQuery.scala │ │ │ ├── StreamingQueryListener.scala │ │ │ ├── StreamingQueryManager.scala │ │ │ ├── StreamingQueryStatus.scala │ │ │ ├── TTLConfig.scala │ │ │ ├── TimerValues.scala │ │ │ ├── ValueState.scala │ │ │ └── progress.scala │ │ │ ├── types │ │ │ ├── AbstractDataType.scala │ │ │ ├── ArrayType.scala │ │ │ ├── BinaryType.scala │ │ │ ├── BooleanType.scala │ │ │ ├── ByteType.scala │ │ │ ├── CalendarIntervalType.scala │ │ │ ├── CharType.scala │ │ │ ├── DataType.scala │ │ │ ├── DateType.scala │ │ │ ├── DayTimeIntervalType.scala │ │ │ ├── Decimal.scala │ │ │ ├── DecimalType.scala │ │ │ ├── DoubleType.scala │ │ │ ├── FloatType.scala │ │ │ ├── GeographyType.scala │ │ │ ├── GeometryType.scala │ │ │ ├── IntegerType.scala │ │ │ ├── LongType.scala │ │ │ ├── MapType.scala │ │ │ ├── Metadata.scala │ │ │ ├── NullType.scala │ │ │ ├── ObjectType.scala │ │ │ ├── ShortType.scala │ │ │ ├── SpatialType.scala │ │ │ ├── StringType.scala │ │ │ ├── StructField.scala │ │ │ ├── StructType.scala │ │ │ ├── TimeType.scala │ │ │ ├── TimestampNTZType.scala │ │ │ ├── TimestampType.scala │ │ │ ├── UDTRegistration.scala │ │ │ ├── UpCastRule.scala │ │ │ ├── UserDefinedType.scala │ │ │ ├── VarcharType.scala │ │ │ ├── VariantType.scala │ │ │ └── YearMonthIntervalType.scala │ │ │ └── util │ │ │ ├── ArrowUtils.scala │ │ │ ├── ArtifactUtils.scala │ │ │ └── ProtobufUtils.scala │ │ └── test │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ ├── SparkSessionBuilderImplementationBindingSuite.scala │ │ └── StaticProcedureSuiteBase.scala ├── catalyst │ ├── benchmarks │ │ ├── CalendarIntervalBenchmark-jdk21-results.txt │ │ ├── CalendarIntervalBenchmark-results.txt │ │ ├── EnumTypeSetBenchmark-jdk21-results.txt │ │ ├── EnumTypeSetBenchmark-results.txt │ │ ├── EscapePathBenchmark-jdk21-results.txt │ │ ├── EscapePathBenchmark-results.txt │ │ ├── GenericArrayDataBenchmark-jdk21-results.txt │ │ ├── GenericArrayDataBenchmark-results.txt │ │ ├── HashBenchmark-jdk21-results.txt │ │ ├── HashBenchmark-results.txt │ │ ├── HashByteArrayBenchmark-jdk21-results.txt │ │ ├── HashByteArrayBenchmark-results.txt │ │ ├── HexBenchmark-jdk21-results.txt │ │ ├── HexBenchmark-results.txt │ │ ├── InternalRowComparableWrapperBenchmark-jdk21-results.txt │ │ ├── InternalRowComparableWrapperBenchmark-results.txt │ │ ├── UnsafeProjectionBenchmark-jdk21-results.txt │ │ └── UnsafeProjectionBenchmark-results.txt │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ ├── catalyst │ │ │ │ ├── expressions │ │ │ │ │ ├── ArrayExpressionUtils.java │ │ │ │ │ ├── ArrayOfDecimalsSerDe.java │ │ │ │ │ ├── BitmapExpressionUtils.java │ │ │ │ │ ├── ExpressionDescription.java │ │ │ │ │ ├── ExpressionImplUtils.java │ │ │ │ │ ├── ExpressionInfo.java │ │ │ │ │ ├── FixedLengthRowBasedKeyValueBatch.java │ │ │ │ │ ├── RowBasedKeyValueBatch.java │ │ │ │ │ ├── SpecializedGetters.java │ │ │ │ │ ├── SpecializedGettersReader.java │ │ │ │ │ ├── ToJavaArrayUtils.java │ │ │ │ │ ├── UnsafeArrayData.java │ │ │ │ │ ├── UnsafeDataUtils.java │ │ │ │ │ ├── UnsafeMapData.java │ │ │ │ │ ├── UnsafeRow.java │ │ │ │ │ ├── UnsafeRowChecksum.scala │ │ │ │ │ ├── VariableLengthRowBasedKeyValueBatch.java │ │ │ │ │ ├── XXH64.java │ │ │ │ │ ├── codegen │ │ │ │ │ │ ├── BufferHolder.java │ │ │ │ │ │ ├── UnsafeArrayWriter.java │ │ │ │ │ │ ├── UnsafeRowWriter.java │ │ │ │ │ │ └── UnsafeWriter.java │ │ │ │ │ ├── json │ │ │ │ │ │ └── JsonExpressionUtils.java │ │ │ │ │ └── xml │ │ │ │ │ │ └── UDFXPathUtil.java │ │ │ │ └── util │ │ │ │ │ ├── CharVarcharCodegenUtils.java │ │ │ │ │ ├── Geo.java │ │ │ │ │ ├── Geography.java │ │ │ │ │ ├── Geometry.java │ │ │ │ │ ├── HadoopCompressionCodec.java │ │ │ │ │ └── STUtils.java │ │ │ │ ├── connector │ │ │ │ ├── ExternalCommandRunner.java │ │ │ │ ├── catalog │ │ │ │ │ ├── CatalogExtension.java │ │ │ │ │ ├── CatalogPlugin.java │ │ │ │ │ ├── Column.java │ │ │ │ │ ├── ColumnDefaultValue.java │ │ │ │ │ ├── DefaultValue.java │ │ │ │ │ ├── DelegatingCatalogExtension.java │ │ │ │ │ ├── FunctionCatalog.java │ │ │ │ │ ├── MetadataColumn.java │ │ │ │ │ ├── NamespaceChange.java │ │ │ │ │ ├── ProcedureCatalog.java │ │ │ │ │ ├── SessionConfigSupport.java │ │ │ │ │ ├── StagedTable.java │ │ │ │ │ ├── StagingTableCatalog.java │ │ │ │ │ ├── SupportsAtomicPartitionManagement.java │ │ │ │ │ ├── SupportsCatalogOptions.java │ │ │ │ │ ├── SupportsDelete.java │ │ │ │ │ ├── SupportsDeleteV2.java │ │ │ │ │ ├── SupportsMetadataColumns.java │ │ │ │ │ ├── SupportsNamespaces.java │ │ │ │ │ ├── SupportsPartitionManagement.java │ │ │ │ │ ├── SupportsRead.java │ │ │ │ │ ├── SupportsRowLevelOperations.java │ │ │ │ │ ├── SupportsV1OverwriteWithSaveAsTable.java │ │ │ │ │ ├── SupportsWrite.java │ │ │ │ │ ├── Table.java │ │ │ │ │ ├── TableCapability.java │ │ │ │ │ ├── TableCatalog.java │ │ │ │ │ ├── TableCatalogCapability.java │ │ │ │ │ ├── TableChange.java │ │ │ │ │ ├── TableInfo.java │ │ │ │ │ ├── TableProvider.java │ │ │ │ │ ├── TableSummary.java │ │ │ │ │ ├── TableWritePrivilege.java │ │ │ │ │ ├── TruncatableTable.java │ │ │ │ │ ├── View.java │ │ │ │ │ ├── ViewCatalog.java │ │ │ │ │ ├── ViewChange.java │ │ │ │ │ ├── ViewInfo.java │ │ │ │ │ ├── constraints │ │ │ │ │ │ ├── BaseConstraint.java │ │ │ │ │ │ ├── Check.java │ │ │ │ │ │ ├── Constraint.java │ │ │ │ │ │ ├── ForeignKey.java │ │ │ │ │ │ ├── PrimaryKey.java │ │ │ │ │ │ └── Unique.java │ │ │ │ │ ├── functions │ │ │ │ │ │ ├── AggregateFunction.java │ │ │ │ │ │ ├── BoundFunction.java │ │ │ │ │ │ ├── Function.java │ │ │ │ │ │ ├── Reducer.java │ │ │ │ │ │ ├── ReducibleFunction.java │ │ │ │ │ │ ├── ScalarFunction.java │ │ │ │ │ │ └── UnboundFunction.java │ │ │ │ │ ├── index │ │ │ │ │ │ ├── SupportsIndex.java │ │ │ │ │ │ └── TableIndex.java │ │ │ │ │ └── procedures │ │ │ │ │ │ ├── BoundProcedure.java │ │ │ │ │ │ ├── Procedure.java │ │ │ │ │ │ ├── ProcedureParameter.java │ │ │ │ │ │ └── UnboundProcedure.java │ │ │ │ ├── distributions │ │ │ │ │ ├── ClusteredDistribution.java │ │ │ │ │ ├── Distribution.java │ │ │ │ │ ├── Distributions.java │ │ │ │ │ ├── OrderedDistribution.java │ │ │ │ │ └── UnspecifiedDistribution.java │ │ │ │ ├── expressions │ │ │ │ │ ├── Cast.java │ │ │ │ │ ├── Expression.java │ │ │ │ │ ├── Expressions.java │ │ │ │ │ ├── Extract.java │ │ │ │ │ ├── GeneralScalarExpression.java │ │ │ │ │ ├── GetArrayItem.java │ │ │ │ │ ├── Literal.java │ │ │ │ │ ├── NamedReference.java │ │ │ │ │ ├── NullOrdering.java │ │ │ │ │ ├── SortDirection.java │ │ │ │ │ ├── SortOrder.java │ │ │ │ │ ├── Transform.java │ │ │ │ │ ├── UserDefinedScalarFunc.java │ │ │ │ │ ├── aggregate │ │ │ │ │ │ ├── AggregateFunc.java │ │ │ │ │ │ ├── Aggregation.java │ │ │ │ │ │ ├── Avg.java │ │ │ │ │ │ ├── Count.java │ │ │ │ │ │ ├── CountStar.java │ │ │ │ │ │ ├── GeneralAggregateFunc.java │ │ │ │ │ │ ├── Max.java │ │ │ │ │ │ ├── Min.java │ │ │ │ │ │ ├── Sum.java │ │ │ │ │ │ └── UserDefinedAggregateFunc.java │ │ │ │ │ └── filter │ │ │ │ │ │ ├── AlwaysFalse.java │ │ │ │ │ │ ├── AlwaysTrue.java │ │ │ │ │ │ ├── And.java │ │ │ │ │ │ ├── Not.java │ │ │ │ │ │ ├── Or.java │ │ │ │ │ │ └── Predicate.java │ │ │ │ ├── join │ │ │ │ │ └── JoinType.java │ │ │ │ ├── metric │ │ │ │ │ ├── CustomAvgMetric.java │ │ │ │ │ ├── CustomMetric.java │ │ │ │ │ ├── CustomSumMetric.java │ │ │ │ │ └── CustomTaskMetric.java │ │ │ │ ├── read │ │ │ │ │ ├── Batch.java │ │ │ │ │ ├── HasPartitionKey.java │ │ │ │ │ ├── HasPartitionStatistics.java │ │ │ │ │ ├── InputPartition.java │ │ │ │ │ ├── LocalScan.java │ │ │ │ │ ├── PartitionReader.java │ │ │ │ │ ├── PartitionReaderFactory.java │ │ │ │ │ ├── Scan.java │ │ │ │ │ ├── ScanBuilder.java │ │ │ │ │ ├── Statistics.java │ │ │ │ │ ├── SupportsPushDownAggregates.java │ │ │ │ │ ├── SupportsPushDownFilters.java │ │ │ │ │ ├── SupportsPushDownJoin.java │ │ │ │ │ ├── SupportsPushDownLimit.java │ │ │ │ │ ├── SupportsPushDownOffset.java │ │ │ │ │ ├── SupportsPushDownRequiredColumns.java │ │ │ │ │ ├── SupportsPushDownTableSample.java │ │ │ │ │ ├── SupportsPushDownTopN.java │ │ │ │ │ ├── SupportsPushDownV2Filters.java │ │ │ │ │ ├── SupportsPushDownVariants.java │ │ │ │ │ ├── SupportsReportOrdering.java │ │ │ │ │ ├── SupportsReportPartitioning.java │ │ │ │ │ ├── SupportsReportStatistics.java │ │ │ │ │ ├── SupportsRuntimeFiltering.java │ │ │ │ │ ├── SupportsRuntimeV2Filtering.java │ │ │ │ │ ├── VariantAccessInfo.java │ │ │ │ │ ├── colstats │ │ │ │ │ │ ├── ColumnStatistics.java │ │ │ │ │ │ ├── Histogram.java │ │ │ │ │ │ └── HistogramBin.java │ │ │ │ │ ├── partitioning │ │ │ │ │ │ ├── KeyGroupedPartitioning.java │ │ │ │ │ │ ├── Partitioning.java │ │ │ │ │ │ └── UnknownPartitioning.java │ │ │ │ │ └── streaming │ │ │ │ │ │ ├── AcceptsLatestSeenOffset.java │ │ │ │ │ │ ├── CompositeReadLimit.java │ │ │ │ │ │ ├── ContinuousPartitionReader.java │ │ │ │ │ │ ├── ContinuousPartitionReaderFactory.java │ │ │ │ │ │ ├── ContinuousStream.java │ │ │ │ │ │ ├── MicroBatchStream.java │ │ │ │ │ │ ├── Offset.java │ │ │ │ │ │ ├── PartitionOffset.java │ │ │ │ │ │ ├── ReadAllAvailable.java │ │ │ │ │ │ ├── ReadLimit.java │ │ │ │ │ │ ├── ReadMaxBytes.java │ │ │ │ │ │ ├── ReadMaxFiles.java │ │ │ │ │ │ ├── ReadMaxRows.java │ │ │ │ │ │ ├── ReadMinRows.java │ │ │ │ │ │ ├── ReportsSinkMetrics.java │ │ │ │ │ │ ├── ReportsSourceMetrics.java │ │ │ │ │ │ ├── SparkDataStream.java │ │ │ │ │ │ ├── SupportsAdmissionControl.java │ │ │ │ │ │ ├── SupportsRealTimeMode.java │ │ │ │ │ │ ├── SupportsRealTimeRead.java │ │ │ │ │ │ └── SupportsTriggerAvailableNow.java │ │ │ │ ├── util │ │ │ │ │ └── V2ExpressionSQLBuilder.java │ │ │ │ └── write │ │ │ │ │ ├── BatchWrite.java │ │ │ │ │ ├── DataWriter.java │ │ │ │ │ ├── DataWriterFactory.java │ │ │ │ │ ├── DeltaBatchWrite.java │ │ │ │ │ ├── DeltaWrite.java │ │ │ │ │ ├── DeltaWriteBuilder.java │ │ │ │ │ ├── DeltaWriter.java │ │ │ │ │ ├── DeltaWriterFactory.java │ │ │ │ │ ├── LogicalWriteInfo.java │ │ │ │ │ ├── MergeSummary.java │ │ │ │ │ ├── PhysicalWriteInfo.java │ │ │ │ │ ├── RequiresDistributionAndOrdering.java │ │ │ │ │ ├── RowLevelOperation.java │ │ │ │ │ ├── RowLevelOperationBuilder.java │ │ │ │ │ ├── RowLevelOperationInfo.java │ │ │ │ │ ├── SupportsDelta.java │ │ │ │ │ ├── SupportsDynamicOverwrite.java │ │ │ │ │ ├── SupportsOverwrite.java │ │ │ │ │ ├── SupportsOverwriteV2.java │ │ │ │ │ ├── SupportsTruncate.java │ │ │ │ │ ├── Write.java │ │ │ │ │ ├── WriteBuilder.java │ │ │ │ │ ├── WriteSummary.java │ │ │ │ │ ├── WriterCommitMessage.java │ │ │ │ │ └── streaming │ │ │ │ │ ├── StreamingDataWriterFactory.java │ │ │ │ │ └── StreamingWrite.java │ │ │ │ ├── util │ │ │ │ ├── CaseInsensitiveStringMap.java │ │ │ │ └── NumericHistogram.java │ │ │ │ └── vectorized │ │ │ │ ├── ArrowColumnVector.java │ │ │ │ ├── ColumnVector.java │ │ │ │ ├── ColumnarArray.java │ │ │ │ ├── ColumnarBatch.java │ │ │ │ ├── ColumnarBatchRow.java │ │ │ │ ├── ColumnarMap.java │ │ │ │ └── ColumnarRow.java │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ ├── catalyst │ │ │ ├── CapturesConfig.scala │ │ │ ├── CatalystTypeConverters.scala │ │ │ ├── CurrentUserContext.scala │ │ │ ├── DataSourceOptions.scala │ │ │ ├── DeserializerBuildHelper.scala │ │ │ ├── ExtendedAnalysisException.scala │ │ │ ├── FileSourceOptions.scala │ │ │ ├── InternalRow.scala │ │ │ ├── OrderedFilters.scala │ │ │ ├── ProjectingInternalRow.scala │ │ │ ├── QueryPlanningTracker.scala │ │ │ ├── SQLConfHelper.scala │ │ │ ├── SerializerBuildHelper.scala │ │ │ ├── SqlScriptingContextManager.scala │ │ │ ├── StructFilters.scala │ │ │ ├── analysis │ │ │ │ ├── AliasResolution.scala │ │ │ │ ├── AlreadyExistException.scala │ │ │ │ ├── Analyzer.scala │ │ │ │ ├── AnsiGetDateFieldOperationsTypeCoercion.scala │ │ │ │ ├── AnsiStringPromotionTypeCoercion.scala │ │ │ │ ├── AnsiTypeCoercion.scala │ │ │ │ ├── ApplyCharTypePaddingHelper.scala │ │ │ │ ├── ApplyDefaultCollationToStringType.scala │ │ │ │ ├── ApplyLimitAll.scala │ │ │ │ ├── AssignmentUtils.scala │ │ │ │ ├── BinaryArithmeticWithDatetimeResolver.scala │ │ │ │ ├── BooleanEqualityTypeCoercion.scala │ │ │ │ ├── CTESubstitution.scala │ │ │ │ ├── CheckAnalysis.scala │ │ │ │ ├── CollationRulesRunner.scala │ │ │ │ ├── CollationTypeCasts.scala │ │ │ │ ├── CollationTypeCoercion.scala │ │ │ │ ├── ColumnResolutionHelper.scala │ │ │ │ ├── DecimalPrecision.scala │ │ │ │ ├── DecimalPrecisionTypeCoercion.scala │ │ │ │ ├── DeduplicateRelations.scala │ │ │ │ ├── DeduplicateUnionChildOutput.scala │ │ │ │ ├── DivisionTypeCoercion.scala │ │ │ │ ├── EliminateLazyExpression.scala │ │ │ │ ├── ExtractDistributedSequenceID.scala │ │ │ │ ├── FunctionRegistry.scala │ │ │ │ ├── FunctionResolution.scala │ │ │ │ ├── GeneratorResolution.scala │ │ │ │ ├── HintErrorLogger.scala │ │ │ │ ├── IdentifierResolution.scala │ │ │ │ ├── IntegralDivisionTypeCoercion.scala │ │ │ │ ├── KeepLegacyOutputs.scala │ │ │ │ ├── LambdaBinder.scala │ │ │ │ ├── LiteralFunctionResolution.scala │ │ │ │ ├── MultiInstanceRelation.scala │ │ │ │ ├── NamedRelation.scala │ │ │ │ ├── NaturalAndUsingJoinResolution.scala │ │ │ │ ├── NoSuchItemException.scala │ │ │ │ ├── NondeterministicExpressionCollection.scala │ │ │ │ ├── NormalizeableRelation.scala │ │ │ │ ├── ParameterizedQueryArgumentsValidator.scala │ │ │ │ ├── PlanToString.scala │ │ │ │ ├── PullOutNondeterministic.scala │ │ │ │ ├── RelationCache.scala │ │ │ │ ├── RelationResolution.scala │ │ │ │ ├── RelationTimeTravel.scala │ │ │ │ ├── ResolveCatalogs.scala │ │ │ │ ├── ResolveCollationName.scala │ │ │ │ ├── ResolveColumnDefaultInCommandInputQuery.scala │ │ │ │ ├── ResolveCommandsWithIfExists.scala │ │ │ │ ├── ResolveDataFrameDropColumns.scala │ │ │ │ ├── ResolveEventTimeWatermark.scala │ │ │ │ ├── ResolveHints.scala │ │ │ │ ├── ResolveIdentifierClause.scala │ │ │ │ ├── ResolveInlineTables.scala │ │ │ │ ├── ResolveInsertionBase.scala │ │ │ │ ├── ResolveLateralColumnAliasReference.scala │ │ │ │ ├── ResolveMergeIntoSchemaEvolution.scala │ │ │ │ ├── ResolvePartitionSpec.scala │ │ │ │ ├── ResolveReferencesInAggregate.scala │ │ │ │ ├── ResolveReferencesInSort.scala │ │ │ │ ├── ResolveReferencesInUpdate.scala │ │ │ │ ├── ResolveRowLevelCommandAssignments.scala │ │ │ │ ├── ResolveSetVariable.scala │ │ │ │ ├── ResolveTableConstraints.scala │ │ │ │ ├── ResolveTableSpec.scala │ │ │ │ ├── ResolveTimeWindows.scala │ │ │ │ ├── ResolveUnion.scala │ │ │ │ ├── ResolveUpdateEventTimeWatermarkColumn.scala │ │ │ │ ├── ResolveWithCTE.scala │ │ │ │ ├── RewriteCollationJoin.scala │ │ │ │ ├── RewriteDeleteFromTable.scala │ │ │ │ ├── RewriteMergeIntoTable.scala │ │ │ │ ├── RewriteRowLevelCommand.scala │ │ │ │ ├── RewriteUpdateTable.scala │ │ │ │ ├── SQLFunctionExpression.scala │ │ │ │ ├── SQLFunctionNode.scala │ │ │ │ ├── StackTypeCoercion.scala │ │ │ │ ├── StreamingJoinHelper.scala │ │ │ │ ├── StringLiteralTypeCoercion.scala │ │ │ │ ├── StringPromotionTypeCoercion.scala │ │ │ │ ├── SubqueryExpressionInLambdaOrHigherOrderFunctionValidator.scala │ │ │ │ ├── TableOutputResolver.scala │ │ │ │ ├── TimeTravelSpec.scala │ │ │ │ ├── TypeCheckResult.scala │ │ │ │ ├── TypeCoercion.scala │ │ │ │ ├── TypeCoercionBase.scala │ │ │ │ ├── TypeCoercionHelper.scala │ │ │ │ ├── TypeCoercionValidation.scala │ │ │ │ ├── UnsupportedOperationChecker.scala │ │ │ │ ├── UpCastResolution.scala │ │ │ │ ├── UpdateAttributeNullability.scala │ │ │ │ ├── V2TableReference.scala │ │ │ │ ├── ValidateSubqueryExpression.scala │ │ │ │ ├── VariableResolution.scala │ │ │ │ ├── ViewResolution.scala │ │ │ │ ├── WindowResolution.scala │ │ │ │ ├── higherOrderFunctions.scala │ │ │ │ ├── package.scala │ │ │ │ ├── parameters.scala │ │ │ │ ├── resolver │ │ │ │ │ ├── AggregateExpressionResolver.scala │ │ │ │ │ ├── AggregateResolutionResult.scala │ │ │ │ │ ├── AggregateResolver.scala │ │ │ │ │ ├── AggregateWithLcaResolutionResult.scala │ │ │ │ │ ├── AliasResolver.scala │ │ │ │ │ ├── AnalyzerBridgeState.scala │ │ │ │ │ ├── AttributeScopeStack.scala │ │ │ │ │ ├── AutoGeneratedAliasProvider.scala │ │ │ │ │ ├── BinaryArithmeticResolver.scala │ │ │ │ │ ├── BridgedRelationId.scala │ │ │ │ │ ├── BridgedRelationMetadataProvider.scala │ │ │ │ │ ├── CandidatesForResolution.scala │ │ │ │ │ ├── CoercesExpressionTypes.scala │ │ │ │ │ ├── CteScope.scala │ │ │ │ │ ├── DefaultCollationTypeCoercion.scala │ │ │ │ │ ├── DelegatesResolutionToExtensions.scala │ │ │ │ │ ├── ExplicitlyUnsupportedResolverFeature.scala │ │ │ │ │ ├── ExpressionIdAssigner.scala │ │ │ │ │ ├── ExpressionResolutionContext.scala │ │ │ │ │ ├── ExpressionResolutionValidator.scala │ │ │ │ │ ├── ExpressionResolver.scala │ │ │ │ │ ├── ExpressionTreeTraversal.scala │ │ │ │ │ ├── FilterResolver.scala │ │ │ │ │ ├── FunctionResolver.scala │ │ │ │ │ ├── GroupingAndAggregateExpressionsExtractor.scala │ │ │ │ │ ├── HavingResolver.scala │ │ │ │ │ ├── HybridAnalyzer.scala │ │ │ │ │ ├── IdentifierAndCteSubstituor.scala │ │ │ │ │ ├── IdentifierMap.scala │ │ │ │ │ ├── JoinResolver.scala │ │ │ │ │ ├── KeyTransformingMap.scala │ │ │ │ │ ├── LateralColumnAliasProhibitedRegistry.scala │ │ │ │ │ ├── LateralColumnAliasRegistry.scala │ │ │ │ │ ├── LateralColumnAliasRegistryImpl.scala │ │ │ │ │ ├── LateralColumnAliasResolver.scala │ │ │ │ │ ├── LimitLikeExpressionValidator.scala │ │ │ │ │ ├── MetadataResolver.scala │ │ │ │ │ ├── NameScope.scala │ │ │ │ │ ├── NameTarget.scala │ │ │ │ │ ├── OperatorWithUncomparableTypeValidator.scala │ │ │ │ │ ├── OrdinalReplacementExpressions.scala │ │ │ │ │ ├── OrdinalResolver.scala │ │ │ │ │ ├── OutputType.scala │ │ │ │ │ ├── PlanLogger.scala │ │ │ │ │ ├── PlanRewriter.scala │ │ │ │ │ ├── ProducesUnresolvedSubtree.scala │ │ │ │ │ ├── ProhibitedResolver.scala │ │ │ │ │ ├── ProjectResolver.scala │ │ │ │ │ ├── PruneMetadataColumns.scala │ │ │ │ │ ├── RelationId.scala │ │ │ │ │ ├── RelationMetadataProvider.scala │ │ │ │ │ ├── ResolutionCheckRunner.scala │ │ │ │ │ ├── ResolutionValidator.scala │ │ │ │ │ ├── ResolvedAggregateExpressions.scala │ │ │ │ │ ├── ResolvedProjectList.scala │ │ │ │ │ ├── ResolvedSubqueryExpressionPlan.scala │ │ │ │ │ ├── Resolver.scala │ │ │ │ │ ├── ResolverExtension.scala │ │ │ │ │ ├── ResolverGuard.scala │ │ │ │ │ ├── ResolverMetricTracker.scala │ │ │ │ │ ├── ResolverRunner.scala │ │ │ │ │ ├── ResolverTag.scala │ │ │ │ │ ├── ResolvesExpressionChildren.scala │ │ │ │ │ ├── ResolvesNameByHiddenOutput.scala │ │ │ │ │ ├── RewritesAliasesInTopLcaProject.scala │ │ │ │ │ ├── SemanticComparator.scala │ │ │ │ │ ├── SemiStructuredExtractResolver.scala │ │ │ │ │ ├── SetOperationLikeResolver.scala │ │ │ │ │ ├── SortResolver.scala │ │ │ │ │ ├── SubqueryExpressionResolver.scala │ │ │ │ │ ├── SubqueryScope.scala │ │ │ │ │ ├── TimezoneAwareExpressionResolver.scala │ │ │ │ │ ├── TreeNodeResolver.scala │ │ │ │ │ ├── UnresolvedCteRelationRef.scala │ │ │ │ │ ├── UnsupportedExpressionInOperatorValidation.scala │ │ │ │ │ ├── ValidatesFilter.scala │ │ │ │ │ ├── ViewResolver.scala │ │ │ │ │ └── package.scala │ │ │ │ ├── timeZoneAnalysis.scala │ │ │ │ ├── unresolved.scala │ │ │ │ ├── v2ResolutionPlans.scala │ │ │ │ └── view.scala │ │ │ ├── catalog │ │ │ │ ├── ExternalCatalog.scala │ │ │ │ ├── ExternalCatalogUtils.scala │ │ │ │ ├── ExternalCatalogWithListener.scala │ │ │ │ ├── FunctionExpressionBuilder.scala │ │ │ │ ├── GlobalTempViewManager.scala │ │ │ │ ├── InMemoryCatalog.scala │ │ │ │ ├── InvalidUDFClassException.scala │ │ │ │ ├── RoutineLanguage.scala │ │ │ │ ├── SQLFunction.scala │ │ │ │ ├── SessionCatalog.scala │ │ │ │ ├── SqlScriptingContextManager.scala │ │ │ │ ├── SqlScriptingExecutionContextExtension.scala │ │ │ │ ├── UserDefinedFunction.scala │ │ │ │ ├── UserDefinedFunctionErrors.scala │ │ │ │ ├── VariableManager.scala │ │ │ │ ├── events.scala │ │ │ │ ├── functionResources.scala │ │ │ │ └── interface.scala │ │ │ ├── csv │ │ │ │ ├── CSVExprUtils.scala │ │ │ │ ├── CSVHeaderChecker.scala │ │ │ │ ├── CSVInferSchema.scala │ │ │ │ ├── CSVOptions.scala │ │ │ │ ├── UnivocityGenerator.scala │ │ │ │ └── UnivocityParser.scala │ │ │ ├── dsl │ │ │ │ └── package.scala │ │ │ ├── encoders │ │ │ │ ├── EncoderUtils.scala │ │ │ │ ├── ExpressionEncoder.scala │ │ │ │ ├── KryoSerializationCodecImpl.scala │ │ │ │ └── package.scala │ │ │ ├── expressions │ │ │ │ ├── AliasHelper.scala │ │ │ │ ├── AnalysisAwareExpression.scala │ │ │ │ ├── ApplyFunctionExpression.scala │ │ │ │ ├── ApproxTopKExpressions.scala │ │ │ │ ├── AttributeMap.scala │ │ │ │ ├── AttributeSet.scala │ │ │ │ ├── Between.scala │ │ │ │ ├── BloomFilterMightContain.scala │ │ │ │ ├── BoundAttribute.scala │ │ │ │ ├── CallMethodViaReflection.scala │ │ │ │ ├── Cast.scala │ │ │ │ ├── CodeGeneratorWithInterpretedFallback.scala │ │ │ │ ├── CollationKey.scala │ │ │ │ ├── DirectShufflePartitionID.scala │ │ │ │ ├── DistributedSequenceID.scala │ │ │ │ ├── DynamicPruning.scala │ │ │ │ ├── EquivalentExpressions.scala │ │ │ │ ├── EvalHelper.scala │ │ │ │ ├── EvalMode.scala │ │ │ │ ├── ExpectsInputTypes.scala │ │ │ │ ├── ExprUtils.scala │ │ │ │ ├── Expression.scala │ │ │ │ ├── ExpressionSet.scala │ │ │ │ ├── ExpressionsEvaluator.scala │ │ │ │ ├── FunctionTableSubqueryArgumentExpression.scala │ │ │ │ ├── GetStructFieldObject.scala │ │ │ │ ├── InterpretedMutableProjection.scala │ │ │ │ ├── InterpretedSafeProjection.scala │ │ │ │ ├── InterpretedUnsafeProjection.scala │ │ │ │ ├── JoinedRow.scala │ │ │ │ ├── MonotonicallyIncreasingID.scala │ │ │ │ ├── NamedArgumentExpression.scala │ │ │ │ ├── NumericEvalContext.scala │ │ │ │ ├── PartitionTransforms.scala │ │ │ │ ├── Projection.scala │ │ │ │ ├── ProjectionOverSchema.scala │ │ │ │ ├── PythonUDF.scala │ │ │ │ ├── ScalaUDF.scala │ │ │ │ ├── SchemaPruning.scala │ │ │ │ ├── SelectedField.scala │ │ │ │ ├── SemiStructuredExtract.scala │ │ │ │ ├── SessionWindow.scala │ │ │ │ ├── SortOrder.scala │ │ │ │ ├── SparkPartitionID.scala │ │ │ │ ├── SpecificInternalRow.scala │ │ │ │ ├── SubExprEvaluationRuntime.scala │ │ │ │ ├── TimeWindow.scala │ │ │ │ ├── ToJavaArray.scala │ │ │ │ ├── ToPrettyString.scala │ │ │ │ ├── ToStringBase.scala │ │ │ │ ├── TransformExpression.scala │ │ │ │ ├── TryEval.scala │ │ │ │ ├── UnwrapUDT.scala │ │ │ │ ├── V2ExpressionUtils.scala │ │ │ │ ├── VariableReference.scala │ │ │ │ ├── WindowTime.scala │ │ │ │ ├── With.scala │ │ │ │ ├── aggregate │ │ │ │ │ ├── AnyValue.scala │ │ │ │ │ ├── ApproxCountDistinctForIntervals.scala │ │ │ │ │ ├── ApproxTopKAggregates.scala │ │ │ │ │ ├── ApproximatePercentile.scala │ │ │ │ │ ├── Average.scala │ │ │ │ │ ├── BloomFilterAggregate.scala │ │ │ │ │ ├── CentralMomentAgg.scala │ │ │ │ │ ├── Corr.scala │ │ │ │ │ ├── Count.scala │ │ │ │ │ ├── CountIf.scala │ │ │ │ │ ├── CountMinSketchAgg.scala │ │ │ │ │ ├── Covariance.scala │ │ │ │ │ ├── First.scala │ │ │ │ │ ├── HistogramNumeric.scala │ │ │ │ │ ├── HyperLogLogPlusPlus.scala │ │ │ │ │ ├── Last.scala │ │ │ │ │ ├── Max.scala │ │ │ │ │ ├── MaxByAndMinBy.scala │ │ │ │ │ ├── Min.scala │ │ │ │ │ ├── Mode.scala │ │ │ │ │ ├── PandasAggregate.scala │ │ │ │ │ ├── PivotFirst.scala │ │ │ │ │ ├── Product.scala │ │ │ │ │ ├── Sum.scala │ │ │ │ │ ├── SupportsOrderingWithinGroup.scala │ │ │ │ │ ├── V2Aggregator.scala │ │ │ │ │ ├── bitwiseAggregates.scala │ │ │ │ │ ├── boolAggregates.scala │ │ │ │ │ ├── collect.scala │ │ │ │ │ ├── datasketchesAggregates.scala │ │ │ │ │ ├── interfaces.scala │ │ │ │ │ ├── kllAggregates.scala │ │ │ │ │ ├── linearRegression.scala │ │ │ │ │ ├── percentiles.scala │ │ │ │ │ └── thetasketchesAggregates.scala │ │ │ │ ├── arithmetic.scala │ │ │ │ ├── avroSqlFunctions.scala │ │ │ │ ├── bitmapExpressions.scala │ │ │ │ ├── bitwiseExpressions.scala │ │ │ │ ├── codegen │ │ │ │ │ ├── CodeFormatter.scala │ │ │ │ │ ├── CodeGenerator.scala │ │ │ │ │ ├── CodegenFallback.scala │ │ │ │ │ ├── GenerateMutableProjection.scala │ │ │ │ │ ├── GenerateOrdering.scala │ │ │ │ │ ├── GeneratePredicate.scala │ │ │ │ │ ├── GenerateSafeProjection.scala │ │ │ │ │ ├── GenerateUnsafeProjection.scala │ │ │ │ │ ├── GenerateUnsafeRowJoiner.scala │ │ │ │ │ ├── javaCode.scala │ │ │ │ │ └── package.scala │ │ │ │ ├── collationExpressions.scala │ │ │ │ ├── collectionOperations.scala │ │ │ │ ├── complexTypeCreator.scala │ │ │ │ ├── complexTypeExtractors.scala │ │ │ │ ├── conditionalExpressions.scala │ │ │ │ ├── constraintExpressions.scala │ │ │ │ ├── constraints.scala │ │ │ │ ├── csv │ │ │ │ │ └── CsvExpressionEvalUtils.scala │ │ │ │ ├── csvExpressions.scala │ │ │ │ ├── datasketchesExpressions.scala │ │ │ │ ├── datetimeExpressions.scala │ │ │ │ ├── decimalExpressions.scala │ │ │ │ ├── generators.scala │ │ │ │ ├── grouping.scala │ │ │ │ ├── hash.scala │ │ │ │ ├── higherOrderFunctions.scala │ │ │ │ ├── inputFileBlock.scala │ │ │ │ ├── intervalExpressions.scala │ │ │ │ ├── json │ │ │ │ │ └── JsonExpressionEvalUtils.scala │ │ │ │ ├── jsonExpressions.scala │ │ │ │ ├── kllExpressions.scala │ │ │ │ ├── literals.scala │ │ │ │ ├── maskExpressions.scala │ │ │ │ ├── mathExpressions.scala │ │ │ │ ├── misc.scala │ │ │ │ ├── namedExpressions.scala │ │ │ │ ├── nullExpressions.scala │ │ │ │ ├── numberFormatExpressions.scala │ │ │ │ ├── objects │ │ │ │ │ └── objects.scala │ │ │ │ ├── ordering.scala │ │ │ │ ├── package.scala │ │ │ │ ├── pipeOperators.scala │ │ │ │ ├── predicates.scala │ │ │ │ ├── randomExpressions.scala │ │ │ │ ├── regexpExpressions.scala │ │ │ │ ├── rows.scala │ │ │ │ ├── st │ │ │ │ │ ├── STExpressionUtils.scala │ │ │ │ │ └── stExpressions.scala │ │ │ │ ├── stringExpressions.scala │ │ │ │ ├── subquery.scala │ │ │ │ ├── thetasketchesExpressions.scala │ │ │ │ ├── timeExpressions.scala │ │ │ │ ├── toFromProtobufSqlFunctions.scala │ │ │ │ ├── url │ │ │ │ │ └── UrlExpressionEvalUtils.scala │ │ │ │ ├── urlExpressions.scala │ │ │ │ ├── variant │ │ │ │ │ ├── VariantExpressionEvalUtils.scala │ │ │ │ │ └── variantExpressions.scala │ │ │ │ ├── windowExpressions.scala │ │ │ │ ├── xml │ │ │ │ │ ├── XmlExpressionEvalUtils.scala │ │ │ │ │ └── xpath.scala │ │ │ │ └── xmlExpressions.scala │ │ │ ├── identifiers.scala │ │ │ ├── json │ │ │ │ ├── CreateJacksonParser.scala │ │ │ │ ├── JSONOptions.scala │ │ │ │ ├── JacksonGenerator.scala │ │ │ │ ├── JacksonParser.scala │ │ │ │ ├── JacksonUtils.scala │ │ │ │ ├── JsonFilters.scala │ │ │ │ └── JsonInferSchema.scala │ │ │ ├── optimizer │ │ │ │ ├── ComplexTypes.scala │ │ │ │ ├── CostBasedJoinReorder.scala │ │ │ │ ├── DecorrelateInnerQuery.scala │ │ │ │ ├── EliminateResolvedHint.scala │ │ │ │ ├── EliminateSQLFunctionNode.scala │ │ │ │ ├── EliminateWindowPartitions.scala │ │ │ │ ├── InferWindowGroupLimit.scala │ │ │ │ ├── InjectRuntimeFilter.scala │ │ │ │ ├── InlineCTE.scala │ │ │ │ ├── InsertMapSortExpression.scala │ │ │ │ ├── LimitPushDownThroughWindow.scala │ │ │ │ ├── MergeSubplans.scala │ │ │ │ ├── NestedColumnAliasing.scala │ │ │ │ ├── NormalizeFloatingNumbers.scala │ │ │ │ ├── OptimizeCsvJsonExprs.scala │ │ │ │ ├── OptimizeJoinCondition.scala │ │ │ │ ├── OptimizeOneRowPlan.scala │ │ │ │ ├── OptimizeRand.scala │ │ │ │ ├── Optimizer.scala │ │ │ │ ├── PlanMerger.scala │ │ │ │ ├── PropagateEmptyRelation.scala │ │ │ │ ├── PullOutGroupingExpressions.scala │ │ │ │ ├── PullOutNestedDataOuterRefExpressions.scala │ │ │ │ ├── PushDownLeftSemiAntiJoin.scala │ │ │ │ ├── PushExtraPredicateThroughJoin.scala │ │ │ │ ├── PushProjectionThroughLimitAndOffset.scala │ │ │ │ ├── PushdownPredicatesAndPruneColumnsForCTEDef.scala │ │ │ │ ├── RemoveRedundantAggregates.scala │ │ │ │ ├── RemoveRedundantSorts.scala │ │ │ │ ├── ReplaceCTERefWithRepartition.scala │ │ │ │ ├── ReplaceExceptWithFilter.scala │ │ │ │ ├── ReplaceNullWithFalseInPredicate.scala │ │ │ │ ├── RewriteAsOfJoin.scala │ │ │ │ ├── RewriteDistinctAggregates.scala │ │ │ │ ├── RewriteWithExpression.scala │ │ │ │ ├── StarSchemaDetection.scala │ │ │ │ ├── UnwrapCastInBinaryComparison.scala │ │ │ │ ├── UpdateFields.scala │ │ │ │ ├── expressions.scala │ │ │ │ ├── finishAnalysis.scala │ │ │ │ ├── joins.scala │ │ │ │ ├── objects.scala │ │ │ │ └── subquery.scala │ │ │ ├── package.scala │ │ │ ├── parser │ │ │ │ ├── AbstractSqlParser.scala │ │ │ │ ├── AstBuilder.scala │ │ │ │ ├── CatalystSqlParser.scala │ │ │ │ ├── ParameterContext.scala │ │ │ │ ├── ParameterHandler.scala │ │ │ │ ├── ParserInterface.scala │ │ │ │ ├── ParserUtils.scala │ │ │ │ ├── SubstituteParamsParser.scala │ │ │ │ └── package.scala │ │ │ ├── planning │ │ │ │ ├── QueryPlanner.scala │ │ │ │ ├── package.scala │ │ │ │ └── patterns.scala │ │ │ ├── plans │ │ │ │ ├── AliasAwareOutputExpression.scala │ │ │ │ ├── DescribeCommandSchema.scala │ │ │ │ ├── NormalizePlan.scala │ │ │ │ ├── QueryPlan.scala │ │ │ │ ├── ReferenceAllColumns.scala │ │ │ │ ├── joinTypes.scala │ │ │ │ ├── logical │ │ │ │ │ ├── AnalysisHelper.scala │ │ │ │ │ ├── ColumnDefinition.scala │ │ │ │ │ ├── Command.scala │ │ │ │ │ ├── DistinctKeyVisitor.scala │ │ │ │ │ ├── EmptyRelation.scala │ │ │ │ │ ├── EventTimeWatermark.scala │ │ │ │ │ ├── ExecutableDuringAnalysis.scala │ │ │ │ │ ├── FunctionBuilderBase.scala │ │ │ │ │ ├── IgnoreCachedData.scala │ │ │ │ │ ├── LocalRelation.scala │ │ │ │ │ ├── LogicalPlan.scala │ │ │ │ │ ├── LogicalPlanDistinctKeys.scala │ │ │ │ │ ├── LogicalPlanVisitor.scala │ │ │ │ │ ├── MergeRows.scala │ │ │ │ │ ├── MultiResult.scala │ │ │ │ │ ├── PlanHelper.scala │ │ │ │ │ ├── QueryPlanConstraints.scala │ │ │ │ │ ├── ScriptTransformation.scala │ │ │ │ │ ├── SqlScriptingLogicalPlans.scala │ │ │ │ │ ├── Statistics.scala │ │ │ │ │ ├── StreamSourceAwareLogicalPlan.scala │ │ │ │ │ ├── basicLogicalOperators.scala │ │ │ │ │ ├── cteOperators.scala │ │ │ │ │ ├── hints.scala │ │ │ │ │ ├── object.scala │ │ │ │ │ ├── pythonLogicalOperators.scala │ │ │ │ │ ├── statements.scala │ │ │ │ │ ├── statsEstimation │ │ │ │ │ │ ├── AggregateEstimation.scala │ │ │ │ │ │ ├── BasicStatsPlanVisitor.scala │ │ │ │ │ │ ├── EstimationUtils.scala │ │ │ │ │ │ ├── FilterEstimation.scala │ │ │ │ │ │ ├── JoinEstimation.scala │ │ │ │ │ │ ├── LogicalPlanStats.scala │ │ │ │ │ │ ├── ProjectEstimation.scala │ │ │ │ │ │ ├── SizeInBytesOnlyStatsPlanVisitor.scala │ │ │ │ │ │ ├── UnionEstimation.scala │ │ │ │ │ │ └── ValueInterval.scala │ │ │ │ │ ├── v2AlterTableCommands.scala │ │ │ │ │ └── v2Commands.scala │ │ │ │ ├── package.scala │ │ │ │ └── physical │ │ │ │ │ ├── broadcastMode.scala │ │ │ │ │ └── partitioning.scala │ │ │ ├── rules │ │ │ │ ├── QueryExecutionMetering.scala │ │ │ │ ├── Rule.scala │ │ │ │ ├── RuleExecutor.scala │ │ │ │ ├── RuleIdCollection.scala │ │ │ │ └── package.scala │ │ │ ├── streaming │ │ │ │ ├── StreamingRelationV2.scala │ │ │ │ ├── WriteToStream.scala │ │ │ │ └── WriteToStreamStatement.scala │ │ │ ├── trees │ │ │ │ ├── TreeNode.scala │ │ │ │ ├── TreePatternBits.scala │ │ │ │ ├── TreePatterns.scala │ │ │ │ └── package.scala │ │ │ ├── types │ │ │ │ ├── DataTypeUtils.scala │ │ │ │ └── PhysicalDataType.scala │ │ │ ├── util │ │ │ │ ├── ArrayBasedMapBuilder.scala │ │ │ │ ├── ArrayBasedMapData.scala │ │ │ │ ├── ArrayData.scala │ │ │ │ ├── BadRecordException.scala │ │ │ │ ├── CharVarcharUtils.scala │ │ │ │ ├── CharsetProvider.scala │ │ │ │ ├── CompressionCodecs.scala │ │ │ │ ├── DateTimeUtils.scala │ │ │ │ ├── EvaluateUnresolvedInlineTable.scala │ │ │ │ ├── FailureSafeParser.scala │ │ │ │ ├── GeneratedColumn.scala │ │ │ │ ├── GenericArrayData.scala │ │ │ │ ├── HyperLogLogPlusPlusHelper.scala │ │ │ │ ├── IdentityColumn.scala │ │ │ │ ├── InternalRowComparableWrapper.scala │ │ │ │ ├── IntervalMathUtils.scala │ │ │ │ ├── IntervalUtils.scala │ │ │ │ ├── MapData.scala │ │ │ │ ├── NumberConverter.scala │ │ │ │ ├── ParseMode.scala │ │ │ │ ├── QuantileSummaries.scala │ │ │ │ ├── RandomIndicesGenerator.scala │ │ │ │ ├── RandomUUIDGenerator.scala │ │ │ │ ├── ReplaceDataProjections.scala │ │ │ │ ├── ResolveDefaultColumnsUtil.scala │ │ │ │ ├── ResolveTableConstraints.scala │ │ │ │ ├── RowDeltaUtils.scala │ │ │ │ ├── SQLKeywordUtils.scala │ │ │ │ ├── SQLOrderingUtil.scala │ │ │ │ ├── StringKeyHashMap.scala │ │ │ │ ├── StringUtils.scala │ │ │ │ ├── ThetaSketchUtils.scala │ │ │ │ ├── ToNumberParser.scala │ │ │ │ ├── TypeUtils.scala │ │ │ │ ├── UDTUtilsImpl.scala │ │ │ │ ├── UTF8StringUtils.scala │ │ │ │ ├── UnsafeRowUtils.scala │ │ │ │ ├── V2ExpressionBuilder.scala │ │ │ │ ├── WriteDeltaProjections.scala │ │ │ │ └── package.scala │ │ │ └── xml │ │ │ │ ├── IndentingXMLStreamWriter.scala │ │ │ │ ├── StaxXMLRecordReader.scala │ │ │ │ ├── StaxXmlGenerator.scala │ │ │ │ ├── StaxXmlParser.scala │ │ │ │ ├── StaxXmlParserUtils.scala │ │ │ │ ├── ValidatorUtil.scala │ │ │ │ ├── XmlInferSchema.scala │ │ │ │ └── XmlOptions.scala │ │ │ ├── connector │ │ │ ├── catalog │ │ │ │ ├── CatalogManager.scala │ │ │ │ ├── CatalogNotFoundException.scala │ │ │ │ ├── CatalogV2Implicits.scala │ │ │ │ ├── CatalogV2Util.scala │ │ │ │ ├── Catalogs.scala │ │ │ │ ├── LookupCatalog.scala │ │ │ │ ├── V1Table.scala │ │ │ │ └── V2TableUtil.scala │ │ │ ├── distributions │ │ │ │ └── distributions.scala │ │ │ ├── expressions │ │ │ │ └── expressions.scala │ │ │ └── write │ │ │ │ ├── LogicalWriteInfoImpl.scala │ │ │ │ ├── MergeSummaryImpl.scala │ │ │ │ ├── PhysicalWriteInfoImpl.scala │ │ │ │ ├── RowLevelOperationInfoImpl.scala │ │ │ │ └── RowLevelOperationTable.scala │ │ │ ├── errors │ │ │ ├── QueryCompilationErrors.scala │ │ │ ├── QueryErrorsBase.scala │ │ │ ├── QueryExecutionErrors.scala │ │ │ └── SqlScriptingErrors.scala │ │ │ ├── exceptions │ │ │ └── SqlScriptingException.scala │ │ │ ├── execution │ │ │ ├── QueryExecutionException.scala │ │ │ ├── RowIterator.scala │ │ │ ├── arrow │ │ │ │ ├── ArrowWriter.scala │ │ │ │ └── ArrowWriterWrapper.scala │ │ │ └── datasources │ │ │ │ └── v2 │ │ │ │ ├── DataSourceV2Implicits.scala │ │ │ │ └── DataSourceV2Relation.scala │ │ │ ├── internal │ │ │ ├── ReadOnlySQLConf.scala │ │ │ ├── SQLConf.scala │ │ │ ├── StaticSQLConf.scala │ │ │ └── connector │ │ │ │ ├── ColumnImpl.scala │ │ │ │ ├── ExpressionWithToString.scala │ │ │ │ ├── PartitionOffsetWithIndex.scala │ │ │ │ ├── PredicateUtils.scala │ │ │ │ ├── ProcedureParameterImpl.scala │ │ │ │ ├── SimpleTableProvider.scala │ │ │ │ ├── SupportsMetadata.scala │ │ │ │ ├── SupportsPushDownCatalystFilters.scala │ │ │ │ ├── SupportsStreamingUpdateAsAppend.scala │ │ │ │ ├── ToStringSQLBuilder.scala │ │ │ │ └── V1Function.scala │ │ │ ├── sources │ │ │ └── filters.scala │ │ │ ├── types │ │ │ ├── DataTypeExpression.scala │ │ │ ├── numerics.scala │ │ │ └── package.scala │ │ │ └── util │ │ │ ├── PartitioningUtils.scala │ │ │ ├── SQLOpenHashSet.scala │ │ │ └── SchemaUtils.scala │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ ├── catalyst │ │ │ ├── JavaTypeInferenceBeans.java │ │ │ └── expressions │ │ │ │ ├── HiveHasherSuite.java │ │ │ │ ├── RowBasedKeyValueBatchSuite.java │ │ │ │ ├── TestThrowExceptionMethod.java │ │ │ │ └── XXH64Suite.java │ │ │ ├── connector │ │ │ └── catalog │ │ │ │ └── CatalogLoadingSuite.java │ │ │ └── streaming │ │ │ ├── JavaGroupStateTimeoutSuite.java │ │ │ └── JavaOutputModeSuite.java │ │ ├── resources │ │ ├── ansi-sql-2016-reserved-keywords.txt │ │ └── log4j2.properties │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ ├── CalendarIntervalBenchmark.scala │ │ ├── HashBenchmark.scala │ │ ├── HashByteArrayBenchmark.scala │ │ ├── RandomDataGenerator.scala │ │ ├── RandomDataGeneratorSuite.scala │ │ ├── RowJsonSuite.scala │ │ ├── RowTest.scala │ │ ├── UnsafeProjectionBenchmark.scala │ │ ├── catalyst │ │ ├── CatalystTypeConvertersSuite.scala │ │ ├── DistributionSuite.scala │ │ ├── EscapePathBenchmark.scala │ │ ├── JavaTypeInferenceSuite.scala │ │ ├── OrderedFiltersSuite.scala │ │ ├── QueryPlanningTrackerSuite.scala │ │ ├── SQLKeywordSuite.scala │ │ ├── ScalaReflectionSuite.scala │ │ ├── SchemaPruningTest.scala │ │ ├── ShuffleSpecSuite.scala │ │ ├── StructFiltersSuite.scala │ │ ├── analysis │ │ │ ├── AnalysisErrorSuite.scala │ │ │ ├── AnalysisExceptionPositionSuite.scala │ │ │ ├── AnalysisExternalCatalogSuite.scala │ │ │ ├── AnalysisSuite.scala │ │ │ ├── AnalysisTest.scala │ │ │ ├── AnsiTypeCoercionSuite.scala │ │ │ ├── CatalogSuite.scala │ │ │ ├── CreateTablePartitioningValidationSuite.scala │ │ │ ├── DSLHintSuite.scala │ │ │ ├── DecimalPrecisionSuite.scala │ │ │ ├── ExpressionTypeCheckingSuite.scala │ │ │ ├── ExtractGeneratorSuite.scala │ │ │ ├── GroupByOrdinalsRepeatedAnalysisSuite.scala │ │ │ ├── LookupFunctionsSuite.scala │ │ │ ├── NamedParameterFunctionSuite.scala │ │ │ ├── PullOutNondeterministicSuite.scala │ │ │ ├── ResolveAliasesSuite.scala │ │ │ ├── ResolveEncodersInUDFSuite.scala │ │ │ ├── ResolveEventTimeWatermarkSuite.scala │ │ │ ├── ResolveGroupingAnalyticsSuite.scala │ │ │ ├── ResolveHintsSuite.scala │ │ │ ├── ResolveInlineTablesSuite.scala │ │ │ ├── ResolveLambdaVariablesSuite.scala │ │ │ ├── ResolveNaturalJoinSuite.scala │ │ │ ├── ResolveRecursiveCTESuite.scala │ │ │ ├── ResolveSubquerySuite.scala │ │ │ ├── ResolveUnionSuite.scala │ │ │ ├── ResolvedUuidExpressionsSuite.scala │ │ │ ├── StreamingJoinHelperSuite.scala │ │ │ ├── TableLookupCacheSuite.scala │ │ │ ├── TestRelations.scala │ │ │ ├── TypeCoercionSuite.scala │ │ │ ├── UnsupportedOperationsSuite.scala │ │ │ ├── V2WriteAnalysisSuite.scala │ │ │ └── resolver │ │ │ │ ├── CoercesExpressionTypesSuite.scala │ │ │ │ ├── LimitLikeExpressionValidatorSuite.scala │ │ │ │ ├── ResolutionValidatorSuite.scala │ │ │ │ └── TimezoneAwareExpressionResolverSuite.scala │ │ ├── catalog │ │ │ ├── ExternalCatalogEventSuite.scala │ │ │ ├── ExternalCatalogSuite.scala │ │ │ ├── ExternalCatalogUtilsSuite.scala │ │ │ ├── InMemoryCatalogSuite.scala │ │ │ └── SessionCatalogSuite.scala │ │ ├── csv │ │ │ ├── CSVExprUtilsSuite.scala │ │ │ ├── CSVInferSchemaSuite.scala │ │ │ └── UnivocityParserSuite.scala │ │ ├── encoders │ │ │ ├── EncoderErrorMessageSuite.scala │ │ │ ├── EncoderResolutionSuite.scala │ │ │ ├── ExpressionEncoderSuite.scala │ │ │ └── RowEncoderSuite.scala │ │ ├── expressions │ │ │ ├── ArithmeticExpressionSuite.scala │ │ │ ├── AttributeMapSuite.scala │ │ │ ├── AttributeResolutionSuite.scala │ │ │ ├── AttributeSetSuite.scala │ │ │ ├── BindReferencesSuite.scala │ │ │ ├── BitmapExpressionUtilsSuite.scala │ │ │ ├── BitwiseExpressionsSuite.scala │ │ │ ├── CallMethodViaReflectionSuite.scala │ │ │ ├── CanonicalizeSuite.scala │ │ │ ├── CastSuiteBase.scala │ │ │ ├── CastWithAnsiOffSuite.scala │ │ │ ├── CastWithAnsiOnSuite.scala │ │ │ ├── CodeGenerationSuite.scala │ │ │ ├── CodeGeneratorWithInterpretedFallbackSuite.scala │ │ │ ├── CollationExpressionSuite.scala │ │ │ ├── CollationRegexpExpressionsSuite.scala │ │ │ ├── CollectionExpressionsSuite.scala │ │ │ ├── ComplexTypeSuite.scala │ │ │ ├── ConditionalExpressionSuite.scala │ │ │ ├── ConstraintExpressionSuite.scala │ │ │ ├── CsvExpressionsSuite.scala │ │ │ ├── DateExpressionsSuite.scala │ │ │ ├── DecimalExpressionSuite.scala │ │ │ ├── DynamicPruningSubquerySuite.scala │ │ │ ├── ExprIdSuite.scala │ │ │ ├── ExpressionEvalHelper.scala │ │ │ ├── ExpressionEvalHelperSuite.scala │ │ │ ├── ExpressionImplUtilsSuite.scala │ │ │ ├── ExpressionSQLBuilderSuite.scala │ │ │ ├── ExpressionSetSuite.scala │ │ │ ├── ExtractPredicatesWithinOutputSetSuite.scala │ │ │ ├── GeneratorExpressionSuite.scala │ │ │ ├── HashExpressionsSuite.scala │ │ │ ├── HexBenchmark.scala │ │ │ ├── HexSuite.scala │ │ │ ├── HigherOrderFunctionsSuite.scala │ │ │ ├── IntegralLiteralTestUtils.scala │ │ │ ├── IntervalExpressionsSuite.scala │ │ │ ├── JsonExpressionsSuite.scala │ │ │ ├── LiteralExpressionSuite.scala │ │ │ ├── LiteralGenerator.scala │ │ │ ├── MathExpressionsSuite.scala │ │ │ ├── MiscExpressionsSuite.scala │ │ │ ├── MutableProjectionSuite.scala │ │ │ ├── NamedExpressionSuite.scala │ │ │ ├── NonFoldableLiteral.scala │ │ │ ├── NondeterministicSuite.scala │ │ │ ├── NullExpressionsSuite.scala │ │ │ ├── ObjectExpressionsSuite.scala │ │ │ ├── OrderingSuite.scala │ │ │ ├── PredicateSuite.scala │ │ │ ├── RandomSuite.scala │ │ │ ├── RegexpExpressionsSuite.scala │ │ │ ├── ScalaUDFSuite.scala │ │ │ ├── SchemaPruningSuite.scala │ │ │ ├── SelectedFieldSuite.scala │ │ │ ├── SortOrderExpressionsSuite.scala │ │ │ ├── StringExpressionsSuite.scala │ │ │ ├── SubExprEvaluationRuntimeSuite.scala │ │ │ ├── SubexpressionEliminationSuite.scala │ │ │ ├── TimeExpressionsSuite.scala │ │ │ ├── TimeWindowSuite.scala │ │ │ ├── ToPrettyStringSuite.scala │ │ │ ├── TryCastSuite.scala │ │ │ ├── TryEvalSuite.scala │ │ │ ├── UnsafeRowConverterSuite.scala │ │ │ ├── UnwrapUDTExpressionSuite.scala │ │ │ ├── V2ExpressionUtilsSuite.scala │ │ │ ├── XmlExpressionsSuite.scala │ │ │ ├── aggregate │ │ │ │ ├── AggregateExpressionSuite.scala │ │ │ │ ├── ApproxCountDistinctForIntervalsSuite.scala │ │ │ │ ├── ApproxTopKSuite.scala │ │ │ │ ├── ApproximatePercentileSuite.scala │ │ │ │ ├── CentralMomentAggSuite.scala │ │ │ │ ├── CountMinSketchAggSuite.scala │ │ │ │ ├── CovarianceAggSuite.scala │ │ │ │ ├── DatasketchesHllSketchSuite.scala │ │ │ │ ├── DeclarativeAggregateEvaluator.scala │ │ │ │ ├── FirstLastTestSuite.scala │ │ │ │ ├── HistogramNumericSuite.scala │ │ │ │ ├── HyperLogLogPlusPlusSuite.scala │ │ │ │ ├── PercentileSuite.scala │ │ │ │ ├── ProductAggSuite.scala │ │ │ │ ├── TestWithAndWithoutCodegen.scala │ │ │ │ └── ThetasketchesAggSuite.scala │ │ │ ├── codegen │ │ │ │ ├── BufferHolderSparkSubmitSuite.scala │ │ │ │ ├── BufferHolderSuite.scala │ │ │ │ ├── CodeBlockSuite.scala │ │ │ │ ├── CodeFormatterSuite.scala │ │ │ │ ├── CodegenExpressionCachingSuite.scala │ │ │ │ ├── CodegenSubexpressionEliminationSuite.scala │ │ │ │ ├── ExprValueSuite.scala │ │ │ │ ├── GenerateUnsafeProjectionSuite.scala │ │ │ │ ├── GenerateUnsafeRowJoinerBitsetSuite.scala │ │ │ │ ├── GenerateUnsafeRowJoinerSuite.scala │ │ │ │ ├── GeneratedProjectionSuite.scala │ │ │ │ ├── UnsafeArrayWriterSuite.scala │ │ │ │ └── UnsafeRowWriterSuite.scala │ │ │ ├── variant │ │ │ │ ├── VariantExpressionEvalUtilsSuite.scala │ │ │ │ └── VariantExpressionSuite.scala │ │ │ └── xml │ │ │ │ ├── ReusableStringReaderSuite.scala │ │ │ │ ├── UDFXPathUtilSuite.scala │ │ │ │ └── XPathExpressionSuite.scala │ │ ├── json │ │ │ ├── JacksonGeneratorSuite.scala │ │ │ ├── JacksonParserSuite.scala │ │ │ ├── JsonFiltersSuite.scala │ │ │ └── JsonInferSchemaSuite.scala │ │ ├── optimizer │ │ │ ├── AggregateOptimizeSuite.scala │ │ │ ├── BinaryComparisonSimplificationSuite.scala │ │ │ ├── BooleanSimplificationSuite.scala │ │ │ ├── CheckCartesianProductsSuite.scala │ │ │ ├── CollapseProjectSuite.scala │ │ │ ├── CollapseRepartitionSuite.scala │ │ │ ├── CollapseWindowSuite.scala │ │ │ ├── ColumnPruningSuite.scala │ │ │ ├── CombineConcatsSuite.scala │ │ │ ├── CombiningLimitsSuite.scala │ │ │ ├── ComputeCurrentTimeSuite.scala │ │ │ ├── ConstantFoldingSuite.scala │ │ │ ├── ConstantPropagationSuite.scala │ │ │ ├── ConvertToLocalRelationSuite.scala │ │ │ ├── DecimalAggregatesSuite.scala │ │ │ ├── DecorrelateInnerQuerySuite.scala │ │ │ ├── EliminateAggregateFilterSuite.scala │ │ │ ├── EliminateDistinctSuite.scala │ │ │ ├── EliminateMapObjectsSuite.scala │ │ │ ├── EliminateOffsetsSuite.scala │ │ │ ├── EliminateSerializationSuite.scala │ │ │ ├── EliminateSortsBeforeRepartitionSuite.scala │ │ │ ├── EliminateSortsSuite.scala │ │ │ ├── EliminateSubqueryAliasesSuite.scala │ │ │ ├── EliminateWindowPartitionsSuite.scala │ │ │ ├── ExtractPythonUDFFromJoinConditionSuite.scala │ │ │ ├── FilterPushdownOnePassSuite.scala │ │ │ ├── FilterPushdownSuite.scala │ │ │ ├── FoldablePropagationSuite.scala │ │ │ ├── GenerateOptimizationSuite.scala │ │ │ ├── InferFiltersFromConstraintsSuite.scala │ │ │ ├── InferFiltersFromGenerateSuite.scala │ │ │ ├── InferWindowGroupLimitSuite.scala │ │ │ ├── InlineCTESuite.scala │ │ │ ├── JoinOptimizationSuite.scala │ │ │ ├── JoinSelectionHelperSuite.scala │ │ │ ├── LeftSemiAntiJoinPushDownSuite.scala │ │ │ ├── LikeSimplificationSuite.scala │ │ │ ├── LimitPushdownSuite.scala │ │ │ ├── LimitPushdownThroughWindowSuite.scala │ │ │ ├── MergeSubplansSuite.scala │ │ │ ├── NestedColumnAliasingSuite.scala │ │ │ ├── NormalizeFloatingPointNumbersSuite.scala │ │ │ ├── NullDownPropagationSuite.scala │ │ │ ├── ObjectSerializerPruningSuite.scala │ │ │ ├── OptimizeCsvExprsSuite.scala │ │ │ ├── OptimizeInSuite.scala │ │ │ ├── OptimizeJoinConditionSuite.scala │ │ │ ├── OptimizeJsonExprsSuite.scala │ │ │ ├── OptimizeLimitZeroSuite.scala │ │ │ ├── OptimizeOneRowPlanSuite.scala │ │ │ ├── OptimizeOneRowRelationSubquerySuite.scala │ │ │ ├── OptimizeRandSuite.scala │ │ │ ├── OptimizeWindowFunctionsSuite.scala │ │ │ ├── OptimizeWithFieldsSuite.scala │ │ │ ├── OptimizerExtendableSuite.scala │ │ │ ├── OptimizerLoggingSuite.scala │ │ │ ├── OptimizerRuleExclusionSuite.scala │ │ │ ├── OptimizerStructuralIntegrityCheckerSuite.scala │ │ │ ├── OptimizerSuite.scala │ │ │ ├── OuterJoinEliminationSuite.scala │ │ │ ├── PropagateEmptyRelationSuite.scala │ │ │ ├── PruneFiltersSuite.scala │ │ │ ├── PullupCorrelatedPredicatesSuite.scala │ │ │ ├── PushFoldableIntoBranchesSuite.scala │ │ │ ├── PushProjectThroughUnionSuite.scala │ │ │ ├── PushProjectionThroughLimitAndOffsetSuite.scala │ │ │ ├── ReassignLambdaVariableIDSuite.scala │ │ │ ├── RemoveNoopOperatorsSuite.scala │ │ │ ├── RemoveNoopUnionSuite.scala │ │ │ ├── RemoveRedundantAggregatesSuite.scala │ │ │ ├── RemoveRedundantAliasAndProjectSuite.scala │ │ │ ├── ReorderAssociativeOperatorSuite.scala │ │ │ ├── ReplaceNullWithFalseInPredicateSuite.scala │ │ │ ├── ReplaceOperatorSuite.scala │ │ │ ├── RewriteAsOfJoinSuite.scala │ │ │ ├── RewriteDistinctAggregatesSuite.scala │ │ │ ├── RewriteSubquerySuite.scala │ │ │ ├── RewriteWithExpressionSuite.scala │ │ │ ├── SetOperationSuite.scala │ │ │ ├── SimpleTestOptimizer.scala │ │ │ ├── SimplifyCastsSuite.scala │ │ │ ├── SimplifyConditionalSuite.scala │ │ │ ├── SimplifyDateTimeConversionsSuite.scala │ │ │ ├── SimplifyStringCaseConversionSuite.scala │ │ │ ├── SpecialDatetimeValuesSuite.scala │ │ │ ├── TransposeWindowSuite.scala │ │ │ ├── TypedFilterOptimizationSuite.scala │ │ │ ├── UnwrapCastInBinaryComparisonSuite.scala │ │ │ ├── complexTypesSuite.scala │ │ │ └── joinReorder │ │ │ │ ├── JoinReorderPlanTestBase.scala │ │ │ │ ├── JoinReorderSuite.scala │ │ │ │ ├── StarJoinCostBasedReorderSuite.scala │ │ │ │ └── StarJoinReorderSuite.scala │ │ ├── parser │ │ │ ├── CastingSyntaxSuite.scala │ │ │ ├── DDLParserSuite.scala │ │ │ ├── DataTypeParserSuite.scala │ │ │ ├── ErrorParserSuite.scala │ │ │ ├── ExpressionParserSuite.scala │ │ │ ├── ParameterSubstitutionSuite.scala │ │ │ ├── ParserUtilsSuite.scala │ │ │ ├── PlanParserSuite.scala │ │ │ ├── SqlScriptingParserSuite.scala │ │ │ ├── StreamRelationParserSuite.scala │ │ │ ├── TableIdentifierParserSuite.scala │ │ │ ├── TableSchemaParserSuite.scala │ │ │ └── UnpivotParserSuite.scala │ │ ├── planning │ │ │ └── PhysicalOperationSuite.scala │ │ ├── plans │ │ │ ├── ConstraintPropagationSuite.scala │ │ │ ├── JoinTypesTest.scala │ │ │ ├── LogicalPlanSuite.scala │ │ │ ├── NormalizePlanSuite.scala │ │ │ ├── PlanTest.scala │ │ │ ├── QueryPlanSuite.scala │ │ │ ├── SQLHelper.scala │ │ │ ├── SameResultSuite.scala │ │ │ └── logical │ │ │ │ ├── AnalysisHelperSuite.scala │ │ │ │ ├── DistinctKeyVisitorSuite.scala │ │ │ │ └── LogicalPlanIntegritySuite.scala │ │ ├── statsEstimation │ │ │ ├── AggregateEstimationSuite.scala │ │ │ ├── BasicStatsEstimationSuite.scala │ │ │ ├── FilterEstimationSuite.scala │ │ │ ├── JoinEstimationSuite.scala │ │ │ ├── ProjectEstimationSuite.scala │ │ │ ├── StatsEstimationTestBase.scala │ │ │ └── UnionEstimationSuite.scala │ │ ├── streaming │ │ │ └── InternalOutputModesSuite.scala │ │ ├── trees │ │ │ ├── RuleExecutorSuite.scala │ │ │ ├── SQLQueryContextSuite.scala │ │ │ └── TreeNodeSuite.scala │ │ └── util │ │ │ ├── ArrayBasedMapBuilderSuite.scala │ │ │ ├── ArrayDataIndexedSeqSuite.scala │ │ │ ├── CaseInsensitiveMapSuite.scala │ │ │ ├── ComplexDataSuite.scala │ │ │ ├── DateFormatterSuite.scala │ │ │ ├── DateTimeFormatterHelperSuite.scala │ │ │ ├── DateTimeTestUtils.scala │ │ │ ├── DateTimeUtilsSuite.scala │ │ │ ├── DatetimeFormatterSuite.scala │ │ │ ├── GenericArrayDataBenchmark.scala │ │ │ ├── GeographyExecutionSuite.java │ │ │ ├── GeometryExecutionSuite.java │ │ │ ├── InternalRowComparableWrapperBenchmark.scala │ │ │ ├── IntervalUtilsSuite.scala │ │ │ ├── MetadataSuite.scala │ │ │ ├── NumberConverterSuite.scala │ │ │ ├── PhysicalAggregationSuite.scala │ │ │ ├── QuantileSummariesSuite.scala │ │ │ ├── QuotingUtilsSuite.scala │ │ │ ├── RandomUUIDGeneratorSuite.scala │ │ │ ├── RebaseDateTimeSuite.scala │ │ │ ├── SQLOrderingUtilSuite.scala │ │ │ ├── StUtilsSuite.java │ │ │ ├── StringUtilsSuite.scala │ │ │ ├── ThetaSketchUtilsSuite.scala │ │ │ ├── TimeFormatterSuite.scala │ │ │ ├── TimestampFormatterSuite.scala │ │ │ ├── TypeUtilsSuite.scala │ │ │ ├── UnsafeArraySuite.scala │ │ │ ├── UnsafeMapSuite.scala │ │ │ └── UnsafeRowUtilsSuite.scala │ │ ├── connector │ │ ├── catalog │ │ │ ├── CatalogManagerSuite.scala │ │ │ ├── CatalogSuite.scala │ │ │ ├── CatalogV2UtilSuite.scala │ │ │ ├── ConstraintSuite.scala │ │ │ ├── EnumTypeSetBenchmark.scala │ │ │ ├── InMemoryAtomicPartitionTable.scala │ │ │ ├── InMemoryBaseTable.scala │ │ │ ├── InMemoryCatalog.scala │ │ │ ├── InMemoryPartitionTable.scala │ │ │ ├── InMemoryPartitionTableCatalog.scala │ │ │ ├── InMemoryRowLevelOperationTable.scala │ │ │ ├── InMemoryRowLevelOperationTableCatalog.scala │ │ │ ├── InMemoryTable.scala │ │ │ ├── InMemoryTableCatalog.scala │ │ │ ├── InMemoryTableWithV2Filter.scala │ │ │ ├── InMemoryTableWithV2FilterCatalog.scala │ │ │ ├── LookupCatalogSuite.scala │ │ │ ├── StagingInMemoryTableCatalog.scala │ │ │ ├── SupportsAtomicPartitionManagementSuite.scala │ │ │ ├── SupportsPartitionManagementSuite.scala │ │ │ ├── V2TableUtilSuite.scala │ │ │ └── functions │ │ │ │ └── AggregateFunctionSuite.scala │ │ └── expressions │ │ │ └── TransformExtractorSuite.scala │ │ ├── sources │ │ └── FakeCommandRunner.scala │ │ ├── types │ │ ├── DataTypeSuite.scala │ │ ├── DataTypeTestUtils.scala │ │ ├── DataTypeWriteCompatibilitySuite.scala │ │ ├── DecimalSuite.scala │ │ ├── MetadataSuite.scala │ │ ├── StructTypeSuite.scala │ │ └── TestUDT.scala │ │ └── util │ │ ├── ArrowUtilsSuite.scala │ │ ├── CaseInsensitiveStringMapSuite.scala │ │ └── SchemaUtilsSuite.scala ├── connect │ ├── README.md │ ├── bin │ │ ├── spark-connect │ │ ├── spark-connect-build │ │ ├── spark-connect-scala-client │ │ ├── spark-connect-scala-client-classpath │ │ └── spark-connect-shell │ ├── client │ │ ├── jdbc │ │ │ ├── pom.xml │ │ │ └── src │ │ │ │ ├── main │ │ │ │ ├── java │ │ │ │ │ └── org │ │ │ │ │ │ └── apache │ │ │ │ │ │ └── spark │ │ │ │ │ │ └── sql │ │ │ │ │ │ └── connect │ │ │ │ │ │ └── client │ │ │ │ │ │ └── jdbc │ │ │ │ │ │ └── SparkConnectDriver.java │ │ │ │ ├── resources │ │ │ │ │ └── META-INF │ │ │ │ │ │ └── services │ │ │ │ │ │ └── java.sql.Driver │ │ │ │ └── scala │ │ │ │ │ └── org │ │ │ │ │ └── apache │ │ │ │ │ └── spark │ │ │ │ │ └── sql │ │ │ │ │ └── connect │ │ │ │ │ └── client │ │ │ │ │ └── jdbc │ │ │ │ │ ├── NonRegisteringSparkConnectDriver.scala │ │ │ │ │ ├── SparkConnectConnection.scala │ │ │ │ │ ├── SparkConnectDatabaseMetaData.scala │ │ │ │ │ ├── SparkConnectResultSet.scala │ │ │ │ │ ├── SparkConnectResultSetMetaData.scala │ │ │ │ │ ├── SparkConnectStatement.scala │ │ │ │ │ └── util │ │ │ │ │ ├── JdbcErrorUtils.scala │ │ │ │ │ └── JdbcTypeUtils.scala │ │ │ │ └── test │ │ │ │ ├── resources │ │ │ │ └── log4j2.properties │ │ │ │ └── scala │ │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── connect │ │ │ │ └── client │ │ │ │ └── jdbc │ │ │ │ ├── SparkConnectDatabaseMetaDataSuite.scala │ │ │ │ ├── SparkConnectDriverSuite.scala │ │ │ │ ├── SparkConnectJdbcDataTypeSuite.scala │ │ │ │ ├── SparkConnectResultSetSuite.scala │ │ │ │ ├── SparkConnectStatementSuite.scala │ │ │ │ └── test │ │ │ │ └── JdbcHelper.scala │ │ └── jvm │ │ │ ├── pom.xml │ │ │ └── src │ │ │ ├── main │ │ │ └── scala │ │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ ├── application │ │ │ │ └── ConnectRepl.scala │ │ │ │ └── connect │ │ │ │ └── client │ │ │ │ └── AmmoniteClassFinder.scala │ │ │ └── test │ │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── JavaEncoderSuite.java │ │ │ ├── resources │ │ │ ├── StubClassDummyUdf.scala │ │ │ ├── TestHelloV2_2.13.jar │ │ │ ├── log4j2.properties │ │ │ ├── udf2.13 │ │ │ └── udf2.13.jar │ │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ ├── DataFrameSubquerySuite.scala │ │ │ ├── DataFrameTableValuedFunctionsSuite.scala │ │ │ ├── GeographyConnectDataFrameSuite.scala │ │ │ ├── GeometryConnectDataFrameSuite.scala │ │ │ ├── PlanGenerationTestSuite.scala │ │ │ ├── SQLExpressionsSuite.scala │ │ │ ├── application │ │ │ └── ReplE2ESuite.scala │ │ │ └── connect │ │ │ ├── CatalogSuite.scala │ │ │ ├── CheckpointSuite.scala │ │ │ ├── ClientDataFrameStatSuite.scala │ │ │ ├── ClientDatasetSuite.scala │ │ │ ├── ClientE2ETestSuite.scala │ │ │ ├── ColumnNodeToProtoConverterSuite.scala │ │ │ ├── ColumnTestSuite.scala │ │ │ ├── DataFrameNaFunctionSuite.scala │ │ │ ├── DataFrameSuite.scala │ │ │ ├── FunctionTestSuite.scala │ │ │ ├── KeyValueGroupedDatasetE2ETestSuite.scala │ │ │ ├── MergeIntoE2ETestSuite.scala │ │ │ ├── SQLImplicitsTestSuite.scala │ │ │ ├── SparkSessionBuilderImplementationBindingSuite.scala │ │ │ ├── SparkSessionCloneSuite.scala │ │ │ ├── SparkSessionE2ESuite.scala │ │ │ ├── SparkSessionSuite.scala │ │ │ ├── StaticProcedureSuite.scala │ │ │ ├── StubbingTestSuite.scala │ │ │ ├── UDFClassLoadingE2ESuite.scala │ │ │ ├── UnsupportedFeaturesSuite.scala │ │ │ ├── UserDefinedFunctionE2ETestSuite.scala │ │ │ ├── UserDefinedFunctionSuite.scala │ │ │ ├── client │ │ │ ├── ArtifactSuite.scala │ │ │ ├── CheckConnectJvmClientCompatibility.scala │ │ │ ├── ClassFinderSuite.scala │ │ │ ├── SparkConnectClientBuilderParseTestSuite.scala │ │ │ ├── SparkConnectClientRetriesSuite.scala │ │ │ ├── SparkConnectClientSuite.scala │ │ │ └── arrow │ │ │ │ └── ArrowEncoderSuite.scala │ │ │ ├── streaming │ │ │ ├── ClientStreamingQuerySuite.scala │ │ │ ├── FlatMapGroupsWithStateStreamingSuite.scala │ │ │ ├── StreamingQueryProgressSuite.scala │ │ │ └── TransformWithStateConnectSuite.scala │ │ │ └── test │ │ │ ├── ConnectFunSuite.scala │ │ │ ├── IntegrationTestUtils.scala │ │ │ ├── QueryTest.scala │ │ │ ├── RemoteSparkSession.scala │ │ │ └── SQLHelper.scala │ ├── common │ │ ├── README.md │ │ ├── pom.xml │ │ └── src │ │ │ ├── main │ │ │ ├── buf.gen.yaml │ │ │ ├── buf.work.yaml │ │ │ ├── protobuf │ │ │ │ ├── buf.yaml │ │ │ │ └── spark │ │ │ │ │ └── connect │ │ │ │ │ ├── base.proto │ │ │ │ │ ├── catalog.proto │ │ │ │ │ ├── commands.proto │ │ │ │ │ ├── common.proto │ │ │ │ │ ├── example_plugins.proto │ │ │ │ │ ├── expressions.proto │ │ │ │ │ ├── ml.proto │ │ │ │ │ ├── ml_common.proto │ │ │ │ │ ├── pipelines.proto │ │ │ │ │ ├── relations.proto │ │ │ │ │ └── types.proto │ │ │ └── scala │ │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── connect │ │ │ │ ├── Catalog.scala │ │ │ │ ├── ConnectClientUnsupportedErrors.scala │ │ │ │ ├── ConnectConversions.scala │ │ │ │ ├── ConnectProtoUtils.scala │ │ │ │ ├── DataFrameNaFunctions.scala │ │ │ │ ├── DataFrameReader.scala │ │ │ │ ├── DataFrameStatFunctions.scala │ │ │ │ ├── DataFrameWriter.scala │ │ │ │ ├── DataFrameWriterV2.scala │ │ │ │ ├── DataStreamReader.scala │ │ │ │ ├── DataStreamWriter.scala │ │ │ │ ├── Dataset.scala │ │ │ │ ├── KeyValueGroupedDataset.scala │ │ │ │ ├── MergeIntoWriter.scala │ │ │ │ ├── RelationalGroupedDataset.scala │ │ │ │ ├── RuntimeConfig.scala │ │ │ │ ├── SQLContext.scala │ │ │ │ ├── SQLImplicits.scala │ │ │ │ ├── SessionCleaner.scala │ │ │ │ ├── SparkSession.scala │ │ │ │ ├── StreamingQuery.scala │ │ │ │ ├── StreamingQueryListenerBus.scala │ │ │ │ ├── StreamingQueryManager.scala │ │ │ │ ├── TableValuedFunction.scala │ │ │ │ ├── UDFRegistration.scala │ │ │ │ ├── UdfToProtoUtils.scala │ │ │ │ ├── UserDefinedAggregateFunctionWrapper.scala │ │ │ │ ├── client │ │ │ │ ├── ArtifactManager.scala │ │ │ │ ├── ClassFinder.scala │ │ │ │ ├── CloseableIterator.scala │ │ │ │ ├── CustomSparkConnectBlockingStub.scala │ │ │ │ ├── CustomSparkConnectStub.scala │ │ │ │ ├── ExecutePlanResponseReattachableIterator.scala │ │ │ │ ├── GrpcExceptionConverter.scala │ │ │ │ ├── GrpcRetryHandler.scala │ │ │ │ ├── ResponseValidator.scala │ │ │ │ ├── RetryPolicy.scala │ │ │ │ ├── SparkConnectClient.scala │ │ │ │ ├── SparkConnectClientParser.scala │ │ │ │ ├── SparkConnectStubState.scala │ │ │ │ ├── SparkResult.scala │ │ │ │ ├── ToStub.scala │ │ │ │ ├── arrow │ │ │ │ │ ├── ArrowDeserializer.scala │ │ │ │ │ ├── ArrowEncoderUtils.scala │ │ │ │ │ ├── ArrowSerializer.scala │ │ │ │ │ ├── ArrowVectorReader.scala │ │ │ │ │ ├── ConcatenatingArrowStreamReader.scala │ │ │ │ │ ├── GeospatialArrowSerDe.scala │ │ │ │ │ └── ScalaCollectionUtils.scala │ │ │ │ └── package.scala │ │ │ │ ├── columnNodeSupport.scala │ │ │ │ ├── common │ │ │ │ ├── Abbreviator.scala │ │ │ │ ├── DataTypeProtoConverter.scala │ │ │ │ ├── ForeachWriterPacket.scala │ │ │ │ ├── InvalidPlanInput.scala │ │ │ │ ├── LiteralValueProtoConverter.scala │ │ │ │ ├── ProtoDataTypes.scala │ │ │ │ ├── ProtoSpecializedArray.scala │ │ │ │ ├── ProtoUtils.scala │ │ │ │ ├── StorageLevelProtoConverter.scala │ │ │ │ ├── StreamingListenerPacket.scala │ │ │ │ ├── UdfPacket.scala │ │ │ │ ├── UdfUtils.scala │ │ │ │ └── config │ │ │ │ │ └── ConnectCommon.scala │ │ │ │ └── package.scala │ │ │ └── test │ │ │ ├── resources │ │ │ ├── artifact-tests │ │ │ │ ├── Hello.class │ │ │ │ ├── crc │ │ │ │ │ ├── Hello.txt │ │ │ │ │ ├── README.md │ │ │ │ │ ├── junitLargeJar.txt │ │ │ │ │ ├── smallClassFile.txt │ │ │ │ │ ├── smallClassFileDup.txt │ │ │ │ │ └── smallJar.txt │ │ │ │ ├── junitLargeJar.jar │ │ │ │ ├── smallClassFile.class │ │ │ │ ├── smallClassFileDup.class │ │ │ │ └── smallJar.jar │ │ │ ├── protobuf-tests │ │ │ │ └── common.desc │ │ │ └── query-tests │ │ │ │ ├── explain-results │ │ │ │ ├── alias_string.explain │ │ │ │ ├── alias_symbol.explain │ │ │ │ ├── apply.explain │ │ │ │ ├── as_string.explain │ │ │ │ ├── as_symbol.explain │ │ │ │ ├── between_expr.explain │ │ │ │ ├── coalesce.explain │ │ │ │ ├── col.explain │ │ │ │ ├── colRegex.explain │ │ │ │ ├── column_add.explain │ │ │ │ ├── column_alias.explain │ │ │ │ ├── column_and.explain │ │ │ │ ├── column_apply.explain │ │ │ │ ├── column_as_multi.explain │ │ │ │ ├── column_as_with_metadata.explain │ │ │ │ ├── column_asc.explain │ │ │ │ ├── column_asc_nulls_first.explain │ │ │ │ ├── column_asc_nulls_last.explain │ │ │ │ ├── column_between.explain │ │ │ │ ├── column_bitwiseAND.explain │ │ │ │ ├── column_bitwiseOR.explain │ │ │ │ ├── column_bitwiseXOR.explain │ │ │ │ ├── column_cast.explain │ │ │ │ ├── column_contains.explain │ │ │ │ ├── column_desc.explain │ │ │ │ ├── column_desc_nulls_first.explain │ │ │ │ ├── column_desc_nulls_last.explain │ │ │ │ ├── column_divide.explain │ │ │ │ ├── column_dropFields.explain │ │ │ │ ├── column_endsWith.explain │ │ │ │ ├── column_eqNullSafe.explain │ │ │ │ ├── column_equals.explain │ │ │ │ ├── column_geq.explain │ │ │ │ ├── column_getField.explain │ │ │ │ ├── column_getItem.explain │ │ │ │ ├── column_gt.explain │ │ │ │ ├── column_ilike.explain │ │ │ │ ├── column_isNaN.explain │ │ │ │ ├── column_isNotNull.explain │ │ │ │ ├── column_isNull.explain │ │ │ │ ├── column_isin.explain │ │ │ │ ├── column_leq.explain │ │ │ │ ├── column_like.explain │ │ │ │ ├── column_lt.explain │ │ │ │ ├── column_modulo.explain │ │ │ │ ├── column_multiply.explain │ │ │ │ ├── column_not.explain │ │ │ │ ├── column_not_equals.explain │ │ │ │ ├── column_or.explain │ │ │ │ ├── column_rlike.explain │ │ │ │ ├── column_star.explain │ │ │ │ ├── column_star_with_target.explain │ │ │ │ ├── column_startsWith.explain │ │ │ │ ├── column_substr.explain │ │ │ │ ├── column_subtract.explain │ │ │ │ ├── column_try_cast.explain │ │ │ │ ├── column_unary_minus.explain │ │ │ │ ├── column_when_otherwise.explain │ │ │ │ ├── column_withField.explain │ │ │ │ ├── crossJoin.explain │ │ │ │ ├── crosstab.explain │ │ │ │ ├── csv_from_dataset.explain │ │ │ │ ├── cube_column.explain │ │ │ │ ├── cube_string.explain │ │ │ │ ├── describe.explain │ │ │ │ ├── distinct.explain │ │ │ │ ├── drop.explain │ │ │ │ ├── dropDuplicates.explain │ │ │ │ ├── dropDuplicates_names_array.explain │ │ │ │ ├── dropDuplicates_names_seq.explain │ │ │ │ ├── dropDuplicates_varargs.explain │ │ │ │ ├── drop_multiple_column.explain │ │ │ │ ├── drop_multiple_strings.explain │ │ │ │ ├── drop_single_column.explain │ │ │ │ ├── drop_single_string.explain │ │ │ │ ├── except.explain │ │ │ │ ├── exceptAll.explain │ │ │ │ ├── expression_extension.explain │ │ │ │ ├── expression_extension_deprecated.explain │ │ │ │ ├── fill.explain │ │ │ │ ├── filter.explain │ │ │ │ ├── filter_expr.explain │ │ │ │ ├── freqItems.explain │ │ │ │ ├── from_avro_with_options.explain │ │ │ │ ├── from_avro_without_options.explain │ │ │ │ ├── from_protobuf_messageClassName_descFilePath.explain │ │ │ │ ├── from_protobuf_messageClassName_descFilePath_options.explain │ │ │ │ ├── function_abs.explain │ │ │ │ ├── function_acos.explain │ │ │ │ ├── function_acosh.explain │ │ │ │ ├── function_add_months.explain │ │ │ │ ├── function_aes_decrypt.explain │ │ │ │ ├── function_aes_decrypt_with_mode.explain │ │ │ │ ├── function_aes_decrypt_with_mode_padding.explain │ │ │ │ ├── function_aes_decrypt_with_mode_padding_aad.explain │ │ │ │ ├── function_aes_encrypt.explain │ │ │ │ ├── function_aes_encrypt_with_mode.explain │ │ │ │ ├── function_aes_encrypt_with_mode_padding.explain │ │ │ │ ├── function_aes_encrypt_with_mode_padding_iv.explain │ │ │ │ ├── function_aes_encrypt_with_mode_padding_iv_aad.explain │ │ │ │ ├── function_aggregate.explain │ │ │ │ ├── function_aggregate_with_finish_lambda.explain │ │ │ │ ├── function_any.explain │ │ │ │ ├── function_any_value_with_ignore_nulls.explain │ │ │ │ ├── function_any_value_with_respect_nulls.explain │ │ │ │ ├── function_approx_count_distinct.explain │ │ │ │ ├── function_approx_count_distinct_rsd.explain │ │ │ │ ├── function_approx_percentile.explain │ │ │ │ ├── function_array.explain │ │ │ │ ├── function_array_agg.explain │ │ │ │ ├── function_array_append.explain │ │ │ │ ├── function_array_compact.explain │ │ │ │ ├── function_array_contains.explain │ │ │ │ ├── function_array_distinct.explain │ │ │ │ ├── function_array_except.explain │ │ │ │ ├── function_array_insert.explain │ │ │ │ ├── function_array_intersect.explain │ │ │ │ ├── function_array_join.explain │ │ │ │ ├── function_array_join_with_null_replacement.explain │ │ │ │ ├── function_array_max.explain │ │ │ │ ├── function_array_min.explain │ │ │ │ ├── function_array_position.explain │ │ │ │ ├── function_array_prepend.explain │ │ │ │ ├── function_array_remove.explain │ │ │ │ ├── function_array_repeat.explain │ │ │ │ ├── function_array_size.explain │ │ │ │ ├── function_array_sort.explain │ │ │ │ ├── function_array_sort_with_comparator.explain │ │ │ │ ├── function_array_union.explain │ │ │ │ ├── function_arrays_overlap.explain │ │ │ │ ├── function_arrays_zip.explain │ │ │ │ ├── function_asc.explain │ │ │ │ ├── function_asc_nulls_first.explain │ │ │ │ ├── function_asc_nulls_last.explain │ │ │ │ ├── function_ascii.explain │ │ │ │ ├── function_asin.explain │ │ │ │ ├── function_asinh.explain │ │ │ │ ├── function_assert_true_with_message.explain │ │ │ │ ├── function_atan.explain │ │ │ │ ├── function_atan2.explain │ │ │ │ ├── function_atanh.explain │ │ │ │ ├── function_avg.explain │ │ │ │ ├── function_base64.explain │ │ │ │ ├── function_bin.explain │ │ │ │ ├── function_bit_and.explain │ │ │ │ ├── function_bit_count.explain │ │ │ │ ├── function_bit_get.explain │ │ │ │ ├── function_bit_length.explain │ │ │ │ ├── function_bit_or.explain │ │ │ │ ├── function_bit_xor.explain │ │ │ │ ├── function_bitmap_bit_position.explain │ │ │ │ ├── function_bitmap_bucket_number.explain │ │ │ │ ├── function_bitmap_construct_agg.explain │ │ │ │ ├── function_bitmap_count.explain │ │ │ │ ├── function_bitmap_or_agg.explain │ │ │ │ ├── function_bitwise_not.explain │ │ │ │ ├── function_bool_and.explain │ │ │ │ ├── function_bool_or.explain │ │ │ │ ├── function_bround.explain │ │ │ │ ├── function_btrim.explain │ │ │ │ ├── function_btrim_with_specified_trim_string.explain │ │ │ │ ├── function_bucket.explain │ │ │ │ ├── function_call_function.explain │ │ │ │ ├── function_call_function_orphaned.explain │ │ │ │ ├── function_cardinality.explain │ │ │ │ ├── function_ceil.explain │ │ │ │ ├── function_ceil_scale.explain │ │ │ │ ├── function_ceiling.explain │ │ │ │ ├── function_ceiling_scale.explain │ │ │ │ ├── function_char.explain │ │ │ │ ├── function_char_length.explain │ │ │ │ ├── function_character_length.explain │ │ │ │ ├── function_chr.explain │ │ │ │ ├── function_coalesce.explain │ │ │ │ ├── function_col.explain │ │ │ │ ├── function_collate.explain │ │ │ │ ├── function_collation.explain │ │ │ │ ├── function_collect_list.explain │ │ │ │ ├── function_collect_set.explain │ │ │ │ ├── function_concat.explain │ │ │ │ ├── function_concat_ws.explain │ │ │ │ ├── function_contains.explain │ │ │ │ ├── function_conv.explain │ │ │ │ ├── function_convert_timezone_with_source_time_zone.explain │ │ │ │ ├── function_convert_timezone_without_source_time_zone.explain │ │ │ │ ├── function_corr.explain │ │ │ │ ├── function_cos.explain │ │ │ │ ├── function_cosh.explain │ │ │ │ ├── function_cot.explain │ │ │ │ ├── function_count.explain │ │ │ │ ├── function_countDistinct.explain │ │ │ │ ├── function_count_if.explain │ │ │ │ ├── function_count_min_sketch.explain │ │ │ │ ├── function_count_typed.explain │ │ │ │ ├── function_covar_pop.explain │ │ │ │ ├── function_covar_samp.explain │ │ │ │ ├── function_crc32.explain │ │ │ │ ├── function_csc.explain │ │ │ │ ├── function_cume_dist.explain │ │ │ │ ├── function_curdate.explain │ │ │ │ ├── function_current_catalog.explain │ │ │ │ ├── function_current_database.explain │ │ │ │ ├── function_current_date.explain │ │ │ │ ├── function_current_schema.explain │ │ │ │ ├── function_current_timestamp.explain │ │ │ │ ├── function_current_timezone.explain │ │ │ │ ├── function_current_user.explain │ │ │ │ ├── function_date_add.explain │ │ │ │ ├── function_date_diff.explain │ │ │ │ ├── function_date_format.explain │ │ │ │ ├── function_date_from_unix_date.explain │ │ │ │ ├── function_date_part.explain │ │ │ │ ├── function_date_sub.explain │ │ │ │ ├── function_date_trunc.explain │ │ │ │ ├── function_dateadd.explain │ │ │ │ ├── function_datediff.explain │ │ │ │ ├── function_datepart.explain │ │ │ │ ├── function_day.explain │ │ │ │ ├── function_dayname.explain │ │ │ │ ├── function_dayofmonth.explain │ │ │ │ ├── function_dayofweek.explain │ │ │ │ ├── function_dayofyear.explain │ │ │ │ ├── function_days.explain │ │ │ │ ├── function_decode.explain │ │ │ │ ├── function_degrees.explain │ │ │ │ ├── function_dense_rank.explain │ │ │ │ ├── function_desc.explain │ │ │ │ ├── function_desc_nulls_first.explain │ │ │ │ ├── function_desc_nulls_last.explain │ │ │ │ ├── function_e.explain │ │ │ │ ├── function_element_at.explain │ │ │ │ ├── function_elt.explain │ │ │ │ ├── function_encode.explain │ │ │ │ ├── function_endswith.explain │ │ │ │ ├── function_equal_null.explain │ │ │ │ ├── function_every.explain │ │ │ │ ├── function_exists.explain │ │ │ │ ├── function_exp.explain │ │ │ │ ├── function_explode.explain │ │ │ │ ├── function_explode_outer.explain │ │ │ │ ├── function_expm1.explain │ │ │ │ ├── function_expr.explain │ │ │ │ ├── function_extract.explain │ │ │ │ ├── function_factorial.explain │ │ │ │ ├── function_filter.explain │ │ │ │ ├── function_filter_with_pair_input.explain │ │ │ │ ├── function_find_in_set.explain │ │ │ │ ├── function_first_value_with_ignore_nulls.explain │ │ │ │ ├── function_first_value_with_respect_nulls.explain │ │ │ │ ├── function_first_with_ignore_nulls.explain │ │ │ │ ├── function_first_with_respect_nulls.explain │ │ │ │ ├── function_flatten.explain │ │ │ │ ├── function_floor.explain │ │ │ │ ├── function_floor_scale.explain │ │ │ │ ├── function_forall.explain │ │ │ │ ├── function_format_number.explain │ │ │ │ ├── function_from_csv.explain │ │ │ │ ├── function_from_json.explain │ │ │ │ ├── function_from_json_orphaned.explain │ │ │ │ ├── function_from_json_with_json_schema.explain │ │ │ │ ├── function_from_unixtime.explain │ │ │ │ ├── function_from_utc_timestamp.explain │ │ │ │ ├── function_from_xml.explain │ │ │ │ ├── function_from_xml_with_json_schema.explain │ │ │ │ ├── function_get.explain │ │ │ │ ├── function_get_json_object.explain │ │ │ │ ├── function_getbit.explain │ │ │ │ ├── function_greatest.explain │ │ │ │ ├── function_hash.explain │ │ │ │ ├── function_hex.explain │ │ │ │ ├── function_histogram_numeric.explain │ │ │ │ ├── function_hour.explain │ │ │ │ ├── function_hours.explain │ │ │ │ ├── function_hypot.explain │ │ │ │ ├── function_ifnull.explain │ │ │ │ ├── function_ilike.explain │ │ │ │ ├── function_ilike_with_escape.explain │ │ │ │ ├── function_initcap.explain │ │ │ │ ├── function_inline.explain │ │ │ │ ├── function_inline_outer.explain │ │ │ │ ├── function_input_file_block_length.explain │ │ │ │ ├── function_input_file_block_start.explain │ │ │ │ ├── function_input_file_name.explain │ │ │ │ ├── function_is_variant_null.explain │ │ │ │ ├── function_isnan.explain │ │ │ │ ├── function_isnotnull.explain │ │ │ │ ├── function_isnull.explain │ │ │ │ ├── function_java_method.explain │ │ │ │ ├── function_json_array_length.explain │ │ │ │ ├── function_json_object_keys.explain │ │ │ │ ├── function_json_tuple.explain │ │ │ │ ├── function_kurtosis.explain │ │ │ │ ├── function_lag.explain │ │ │ │ ├── function_last_day.explain │ │ │ │ ├── function_last_value_with_ignore_nulls.explain │ │ │ │ ├── function_last_value_with_respect_nulls.explain │ │ │ │ ├── function_last_with_ignore_nulls.explain │ │ │ │ ├── function_last_with_respect_nulls.explain │ │ │ │ ├── function_lcase.explain │ │ │ │ ├── function_lead.explain │ │ │ │ ├── function_least.explain │ │ │ │ ├── function_left.explain │ │ │ │ ├── function_len.explain │ │ │ │ ├── function_length.explain │ │ │ │ ├── function_levenshtein.explain │ │ │ │ ├── function_levenshtein_with_threshold.explain │ │ │ │ ├── function_like.explain │ │ │ │ ├── function_like_with_escape.explain │ │ │ │ ├── function_lit.explain │ │ │ │ ├── function_lit_array.explain │ │ │ │ ├── function_ln.explain │ │ │ │ ├── function_localtimestamp.explain │ │ │ │ ├── function_locate.explain │ │ │ │ ├── function_locate_with_pos.explain │ │ │ │ ├── function_log.explain │ │ │ │ ├── function_log10.explain │ │ │ │ ├── function_log1p.explain │ │ │ │ ├── function_log2.explain │ │ │ │ ├── function_log_with_base.explain │ │ │ │ ├── function_lower.explain │ │ │ │ ├── function_lpad.explain │ │ │ │ ├── function_lpad_binary.explain │ │ │ │ ├── function_ltrim.explain │ │ │ │ ├── function_ltrim_with_pattern.explain │ │ │ │ ├── function_make_date.explain │ │ │ │ ├── function_make_dt_interval.explain │ │ │ │ ├── function_make_dt_interval_days.explain │ │ │ │ ├── function_make_dt_interval_days_hours.explain │ │ │ │ ├── function_make_dt_interval_days_hours_mins.explain │ │ │ │ ├── function_make_dt_interval_days_hours_mins_secs.explain │ │ │ │ ├── function_make_interval.explain │ │ │ │ ├── function_make_interval_years.explain │ │ │ │ ├── function_make_interval_years_months.explain │ │ │ │ ├── function_make_interval_years_months_weeks.explain │ │ │ │ ├── function_make_interval_years_months_weeks_days.explain │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours.explain │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours_mins.explain │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours_mins_secs.explain │ │ │ │ ├── function_make_timestamp_ltz_with_timezone.explain │ │ │ │ ├── function_make_timestamp_ltz_without_timezone.explain │ │ │ │ ├── function_make_timestamp_ntz.explain │ │ │ │ ├── function_make_timestamp_with_timezone.explain │ │ │ │ ├── function_make_timestamp_without_timezone.explain │ │ │ │ ├── function_make_ym_interval.explain │ │ │ │ ├── function_make_ym_interval_years.explain │ │ │ │ ├── function_make_ym_interval_years_months.explain │ │ │ │ ├── function_map.explain │ │ │ │ ├── function_map_concat.explain │ │ │ │ ├── function_map_contains_key.explain │ │ │ │ ├── function_map_entries.explain │ │ │ │ ├── function_map_filter.explain │ │ │ │ ├── function_map_from_arrays.explain │ │ │ │ ├── function_map_from_entries.explain │ │ │ │ ├── function_map_keys.explain │ │ │ │ ├── function_map_values.explain │ │ │ │ ├── function_map_zip_with.explain │ │ │ │ ├── function_mask.explain │ │ │ │ ├── function_mask_with_specific_upperChar.explain │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar.explain │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar_digitChar.explain │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar_digitChar_otherChar.explain │ │ │ │ ├── function_max.explain │ │ │ │ ├── function_max_by.explain │ │ │ │ ├── function_md5.explain │ │ │ │ ├── function_median.explain │ │ │ │ ├── function_min.explain │ │ │ │ ├── function_min_by.explain │ │ │ │ ├── function_minute.explain │ │ │ │ ├── function_mode.explain │ │ │ │ ├── function_mode_orphaned.explain │ │ │ │ ├── function_monotonically_increasing_id.explain │ │ │ │ ├── function_month.explain │ │ │ │ ├── function_monthname.explain │ │ │ │ ├── function_months.explain │ │ │ │ ├── function_months_between.explain │ │ │ │ ├── function_months_between_with_roundoff.explain │ │ │ │ ├── function_named_struct.explain │ │ │ │ ├── function_nanvl.explain │ │ │ │ ├── function_negate.explain │ │ │ │ ├── function_negative.explain │ │ │ │ ├── function_next_day.explain │ │ │ │ ├── function_now.explain │ │ │ │ ├── function_nth_value.explain │ │ │ │ ├── function_ntile.explain │ │ │ │ ├── function_nullif.explain │ │ │ │ ├── function_nvl.explain │ │ │ │ ├── function_nvl2.explain │ │ │ │ ├── function_octet_length.explain │ │ │ │ ├── function_overlay.explain │ │ │ │ ├── function_overlay_with_len.explain │ │ │ │ ├── function_parse_json.explain │ │ │ │ ├── function_parse_url.explain │ │ │ │ ├── function_parse_url_with_key.explain │ │ │ │ ├── function_percent_rank.explain │ │ │ │ ├── function_percentile_approx.explain │ │ │ │ ├── function_percentile_with_frequency.explain │ │ │ │ ├── function_percentile_without_frequency.explain │ │ │ │ ├── function_pi.explain │ │ │ │ ├── function_pmod.explain │ │ │ │ ├── function_posexplode.explain │ │ │ │ ├── function_posexplode_outer.explain │ │ │ │ ├── function_position.explain │ │ │ │ ├── function_position_with_start.explain │ │ │ │ ├── function_positive.explain │ │ │ │ ├── function_pow.explain │ │ │ │ ├── function_power.explain │ │ │ │ ├── function_printf.explain │ │ │ │ ├── function_product.explain │ │ │ │ ├── function_quarter.explain │ │ │ │ ├── function_radians.explain │ │ │ │ ├── function_raise_error.explain │ │ │ │ ├── function_rand_with_seed.explain │ │ │ │ ├── function_randn_with_seed.explain │ │ │ │ ├── function_random_with_seed.explain │ │ │ │ ├── function_rank.explain │ │ │ │ ├── function_reduce.explain │ │ │ │ ├── function_reflect.explain │ │ │ │ ├── function_regexp.explain │ │ │ │ ├── function_regexp_count.explain │ │ │ │ ├── function_regexp_extract.explain │ │ │ │ ├── function_regexp_extract_all_with_regex_group_index.explain │ │ │ │ ├── function_regexp_extract_all_without_regex_group_index.explain │ │ │ │ ├── function_regexp_instr_with_regex_group_index.explain │ │ │ │ ├── function_regexp_instr_without_regex_group_index.explain │ │ │ │ ├── function_regexp_like.explain │ │ │ │ ├── function_regexp_replace.explain │ │ │ │ ├── function_regexp_substr.explain │ │ │ │ ├── function_regr_avgx.explain │ │ │ │ ├── function_regr_avgy.explain │ │ │ │ ├── function_regr_count.explain │ │ │ │ ├── function_regr_intercept.explain │ │ │ │ ├── function_regr_r2.explain │ │ │ │ ├── function_regr_slope.explain │ │ │ │ ├── function_regr_sxx.explain │ │ │ │ ├── function_regr_sxy.explain │ │ │ │ ├── function_regr_syy.explain │ │ │ │ ├── function_replace.explain │ │ │ │ ├── function_replace_with_specified_string.explain │ │ │ │ ├── function_reverse.explain │ │ │ │ ├── function_right.explain │ │ │ │ ├── function_rint.explain │ │ │ │ ├── function_rlike.explain │ │ │ │ ├── function_round.explain │ │ │ │ ├── function_row_number.explain │ │ │ │ ├── function_rpad.explain │ │ │ │ ├── function_rpad_binary.explain │ │ │ │ ├── function_rtrim.explain │ │ │ │ ├── function_rtrim_with_pattern.explain │ │ │ │ ├── function_schema_of_csv.explain │ │ │ │ ├── function_schema_of_json.explain │ │ │ │ ├── function_schema_of_json_with_options.explain │ │ │ │ ├── function_schema_of_variant.explain │ │ │ │ ├── function_schema_of_variant_agg.explain │ │ │ │ ├── function_sec.explain │ │ │ │ ├── function_second.explain │ │ │ │ ├── function_sentences.explain │ │ │ │ ├── function_sentences_with_language.explain │ │ │ │ ├── function_sentences_with_language_and_country.explain │ │ │ │ ├── function_sequence.explain │ │ │ │ ├── function_session_user.explain │ │ │ │ ├── function_session_window.explain │ │ │ │ ├── function_session_window_orphaned.explain │ │ │ │ ├── function_sha.explain │ │ │ │ ├── function_sha1.explain │ │ │ │ ├── function_sha2.explain │ │ │ │ ├── function_shiftleft.explain │ │ │ │ ├── function_shiftright.explain │ │ │ │ ├── function_shiftrightunsigned.explain │ │ │ │ ├── function_sign.explain │ │ │ │ ├── function_signum.explain │ │ │ │ ├── function_sin.explain │ │ │ │ ├── function_sinh.explain │ │ │ │ ├── function_size.explain │ │ │ │ ├── function_skewness.explain │ │ │ │ ├── function_slice.explain │ │ │ │ ├── function_some.explain │ │ │ │ ├── function_sort_array.explain │ │ │ │ ├── function_spark_partition_id.explain │ │ │ │ ├── function_split.explain │ │ │ │ ├── function_split_part.explain │ │ │ │ ├── function_split_using_columns.explain │ │ │ │ ├── function_split_with_limit.explain │ │ │ │ ├── function_split_with_limit_using_columns.explain │ │ │ │ ├── function_sqrt.explain │ │ │ │ ├── function_stack.explain │ │ │ │ ├── function_startswith.explain │ │ │ │ ├── function_std.explain │ │ │ │ ├── function_stddev.explain │ │ │ │ ├── function_stddev_pop.explain │ │ │ │ ├── function_stddev_samp.explain │ │ │ │ ├── function_str_to_map.explain │ │ │ │ ├── function_str_to_map_with_pair_and_keyValue_delimiter.explain │ │ │ │ ├── function_str_to_map_with_pair_delimiter.explain │ │ │ │ ├── function_struct.explain │ │ │ │ ├── function_substr.explain │ │ │ │ ├── function_substr_with_len.explain │ │ │ │ ├── function_substring.explain │ │ │ │ ├── function_substring_index.explain │ │ │ │ ├── function_substring_using_columns.explain │ │ │ │ ├── function_substring_with_columns.explain │ │ │ │ ├── function_sum.explain │ │ │ │ ├── function_sum_distinct.explain │ │ │ │ ├── function_tan.explain │ │ │ │ ├── function_tanh.explain │ │ │ │ ├── function_timestamp_add.explain │ │ │ │ ├── function_timestamp_diff.explain │ │ │ │ ├── function_timestamp_micros.explain │ │ │ │ ├── function_timestamp_millis.explain │ │ │ │ ├── function_timestamp_seconds.explain │ │ │ │ ├── function_to_binary.explain │ │ │ │ ├── function_to_binary_with_format.explain │ │ │ │ ├── function_to_char.explain │ │ │ │ ├── function_to_csv.explain │ │ │ │ ├── function_to_date.explain │ │ │ │ ├── function_to_date_with_format.explain │ │ │ │ ├── function_to_json.explain │ │ │ │ ├── function_to_number.explain │ │ │ │ ├── function_to_timestamp.explain │ │ │ │ ├── function_to_timestamp_ltz.explain │ │ │ │ ├── function_to_timestamp_ltz_with_format.explain │ │ │ │ ├── function_to_timestamp_ntz.explain │ │ │ │ ├── function_to_timestamp_ntz_with_format.explain │ │ │ │ ├── function_to_timestamp_with_format.explain │ │ │ │ ├── function_to_unix_timestamp.explain │ │ │ │ ├── function_to_unix_timestamp_with_format.explain │ │ │ │ ├── function_to_utc_timestamp.explain │ │ │ │ ├── function_to_varchar.explain │ │ │ │ ├── function_transform.explain │ │ │ │ ├── function_transform_keys.explain │ │ │ │ ├── function_transform_values.explain │ │ │ │ ├── function_transform_with_index.explain │ │ │ │ ├── function_translate.explain │ │ │ │ ├── function_trim.explain │ │ │ │ ├── function_trim_with_pattern.explain │ │ │ │ ├── function_trunc.explain │ │ │ │ ├── function_try_add.explain │ │ │ │ ├── function_try_aes_decrypt.explain │ │ │ │ ├── function_try_aes_decrypt_with_mode.explain │ │ │ │ ├── function_try_aes_decrypt_with_mode_padding.explain │ │ │ │ ├── function_try_aes_decrypt_with_mode_padding_aad.explain │ │ │ │ ├── function_try_avg.explain │ │ │ │ ├── function_try_divide.explain │ │ │ │ ├── function_try_element_at_array.explain │ │ │ │ ├── function_try_element_at_map.explain │ │ │ │ ├── function_try_make_interval_years.explain │ │ │ │ ├── function_try_make_interval_years_months.explain │ │ │ │ ├── function_try_make_interval_years_months_weeks.explain │ │ │ │ ├── function_try_make_interval_years_months_weeks_days.explain │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours.explain │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours_mins.explain │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours_mins_secs.explain │ │ │ │ ├── function_try_make_timestamp_ltz_with_timezone.explain │ │ │ │ ├── function_try_make_timestamp_ltz_without_timezone.explain │ │ │ │ ├── function_try_make_timestamp_ntz.explain │ │ │ │ ├── function_try_make_timestamp_with_timezone.explain │ │ │ │ ├── function_try_make_timestamp_without_timezone.explain │ │ │ │ ├── function_try_multiply.explain │ │ │ │ ├── function_try_parse_json.explain │ │ │ │ ├── function_try_parse_url.explain │ │ │ │ ├── function_try_parse_url_with_key.explain │ │ │ │ ├── function_try_reflect.explain │ │ │ │ ├── function_try_subtract.explain │ │ │ │ ├── function_try_sum.explain │ │ │ │ ├── function_try_to_binary.explain │ │ │ │ ├── function_try_to_binary_without_format.explain │ │ │ │ ├── function_try_to_date.explain │ │ │ │ ├── function_try_to_date_with_format.explain │ │ │ │ ├── function_try_to_number.explain │ │ │ │ ├── function_try_to_timestamp.explain │ │ │ │ ├── function_try_to_timestamp_without_format.explain │ │ │ │ ├── function_try_url_decode.explain │ │ │ │ ├── function_try_variant_get.explain │ │ │ │ ├── function_typedLit.explain │ │ │ │ ├── function_typeof.explain │ │ │ │ ├── function_ucase.explain │ │ │ │ ├── function_unbase64.explain │ │ │ │ ├── function_unhex.explain │ │ │ │ ├── function_unix_date.explain │ │ │ │ ├── function_unix_micros.explain │ │ │ │ ├── function_unix_millis.explain │ │ │ │ ├── function_unix_seconds.explain │ │ │ │ ├── function_unix_timestamp.explain │ │ │ │ ├── function_unix_timestamp_with_format.explain │ │ │ │ ├── function_upper.explain │ │ │ │ ├── function_url_decode.explain │ │ │ │ ├── function_url_encode.explain │ │ │ │ ├── function_user.explain │ │ │ │ ├── function_var_pop.explain │ │ │ │ ├── function_var_samp.explain │ │ │ │ ├── function_variance.explain │ │ │ │ ├── function_variant_get.explain │ │ │ │ ├── function_weekday.explain │ │ │ │ ├── function_weekofyear.explain │ │ │ │ ├── function_window.explain │ │ │ │ ├── function_window_time.explain │ │ │ │ ├── function_xpath.explain │ │ │ │ ├── function_xpath_boolean.explain │ │ │ │ ├── function_xpath_double.explain │ │ │ │ ├── function_xpath_float.explain │ │ │ │ ├── function_xpath_int.explain │ │ │ │ ├── function_xpath_long.explain │ │ │ │ ├── function_xpath_number.explain │ │ │ │ ├── function_xpath_short.explain │ │ │ │ ├── function_xpath_string.explain │ │ │ │ ├── function_xxhash64.explain │ │ │ │ ├── function_year.explain │ │ │ │ ├── function_years.explain │ │ │ │ ├── function_zip_with.explain │ │ │ │ ├── groupby_agg.explain │ │ │ │ ├── groupby_agg_columns.explain │ │ │ │ ├── groupby_agg_orphaned.explain │ │ │ │ ├── groupby_agg_string.explain │ │ │ │ ├── groupby_avg.explain │ │ │ │ ├── groupby_count.explain │ │ │ │ ├── groupby_max.explain │ │ │ │ ├── groupby_mean.explain │ │ │ │ ├── groupby_min.explain │ │ │ │ ├── groupby_sum.explain │ │ │ │ ├── groupingSets.explain │ │ │ │ ├── grouping_and_grouping_id.explain │ │ │ │ ├── hint.explain │ │ │ │ ├── hll_sketch_agg.explain │ │ │ │ ├── hll_sketch_agg_with_columnName.explain │ │ │ │ ├── hll_sketch_agg_with_columnName_lgConfigK_int.explain │ │ │ │ ├── hll_sketch_agg_with_column_lgConfigK.explain │ │ │ │ ├── hll_sketch_agg_with_column_lgConfigK_int.explain │ │ │ │ ├── hll_union_agg.explain │ │ │ │ ├── hll_union_agg_with_columnName.explain │ │ │ │ ├── hll_union_agg_with_columnName_allowDifferentLgConfigK_boolean.explain │ │ │ │ ├── hll_union_agg_with_column_allowDifferentLgConfigK.explain │ │ │ │ ├── hll_union_agg_with_column_allowDifferentLgConfigK_boolean.explain │ │ │ │ ├── intersect.explain │ │ │ │ ├── intersectAll.explain │ │ │ │ ├── join_condition.explain │ │ │ │ ├── join_inner_condition.explain │ │ │ │ ├── join_inner_no_condition.explain │ │ │ │ ├── join_inner_using_multiple_col_array.explain │ │ │ │ ├── join_inner_using_multiple_col_seq.explain │ │ │ │ ├── join_inner_using_single_col.explain │ │ │ │ ├── join_using_multiple_col_array.explain │ │ │ │ ├── join_using_multiple_col_seq.explain │ │ │ │ ├── join_using_single_col.explain │ │ │ │ ├── json_from_dataset.explain │ │ │ │ ├── limit.explain │ │ │ │ ├── melt_no_values.explain │ │ │ │ ├── melt_values.explain │ │ │ │ ├── offset.explain │ │ │ │ ├── orderBy_columns.explain │ │ │ │ ├── orderBy_strings.explain │ │ │ │ ├── pivot.explain │ │ │ │ ├── pivot_without_column_values.explain │ │ │ │ ├── range.explain │ │ │ │ ├── read.explain │ │ │ │ ├── read_csv.explain │ │ │ │ ├── read_jdbc.explain │ │ │ │ ├── read_jdbc_with_partition.explain │ │ │ │ ├── read_jdbc_with_predicates.explain │ │ │ │ ├── read_json.explain │ │ │ │ ├── read_orc.explain │ │ │ │ ├── read_parquet.explain │ │ │ │ ├── read_table.explain │ │ │ │ ├── read_text.explain │ │ │ │ ├── relation_extension.explain │ │ │ │ ├── relation_extension_deprecated.explain │ │ │ │ ├── repartition.explain │ │ │ │ ├── repartitionById.explain │ │ │ │ ├── repartitionByRange_expressions.explain │ │ │ │ ├── repartitionByRange_num_partitions_expressions.explain │ │ │ │ ├── repartition_expressions.explain │ │ │ │ ├── repartition_num_partitions_expressions.explain │ │ │ │ ├── replace.explain │ │ │ │ ├── rollup_column.explain │ │ │ │ ├── rollup_string.explain │ │ │ │ ├── sampleBy.explain │ │ │ │ ├── sample_fraction_seed.explain │ │ │ │ ├── sample_withReplacement_fraction_seed.explain │ │ │ │ ├── select.explain │ │ │ │ ├── selectExpr.explain │ │ │ │ ├── select_collated_string.explain │ │ │ │ ├── select_strings.explain │ │ │ │ ├── select_typed_1-arg.explain │ │ │ │ ├── select_typed_2-arg.explain │ │ │ │ ├── select_typed_3-arg.explain │ │ │ │ ├── select_typed_4-arg.explain │ │ │ │ ├── select_typed_5-arg.explain │ │ │ │ ├── sortWithinPartitions_columns.explain │ │ │ │ ├── sortWithinPartitions_strings.explain │ │ │ │ ├── sort_columns.explain │ │ │ │ ├── sort_strings.explain │ │ │ │ ├── streaming_table_API_with_options.explain │ │ │ │ ├── summary.explain │ │ │ │ ├── table.explain │ │ │ │ ├── table_API_with_options.explain │ │ │ │ ├── test_broadcast.explain │ │ │ │ ├── to.explain │ │ │ │ ├── toDF.explain │ │ │ │ ├── toJSON.explain │ │ │ │ ├── to_avro_with_schema.explain │ │ │ │ ├── to_avro_without_schema.explain │ │ │ │ ├── to_protobuf_messageClassName.explain │ │ │ │ ├── to_protobuf_messageClassName_descFilePath.explain │ │ │ │ ├── to_protobuf_messageClassName_descFilePath_options.explain │ │ │ │ ├── to_protobuf_messageClassName_options.explain │ │ │ │ ├── union.explain │ │ │ │ ├── unionAll.explain │ │ │ │ ├── unionByName.explain │ │ │ │ ├── unionByName_allowMissingColumns.explain │ │ │ │ ├── unpivot_no_values.explain │ │ │ │ ├── unpivot_values.explain │ │ │ │ ├── where_column.explain │ │ │ │ ├── where_expr.explain │ │ │ │ ├── width_bucket.explain │ │ │ │ ├── window.explain │ │ │ │ ├── withColumnRenamed_java_map.explain │ │ │ │ ├── withColumnRenamed_scala_map.explain │ │ │ │ ├── withColumnRenamed_single.explain │ │ │ │ ├── withColumn_single.explain │ │ │ │ ├── withColumns_java_map.explain │ │ │ │ ├── withColumns_scala_map.explain │ │ │ │ └── withMetadata.explain │ │ │ │ ├── queries │ │ │ │ ├── alias_string.json │ │ │ │ ├── alias_string.proto.bin │ │ │ │ ├── alias_symbol.json │ │ │ │ ├── alias_symbol.proto.bin │ │ │ │ ├── apply.json │ │ │ │ ├── apply.proto.bin │ │ │ │ ├── as_string.json │ │ │ │ ├── as_string.proto.bin │ │ │ │ ├── as_symbol.json │ │ │ │ ├── as_symbol.proto.bin │ │ │ │ ├── between_expr.json │ │ │ │ ├── between_expr.proto.bin │ │ │ │ ├── coalesce.json │ │ │ │ ├── coalesce.proto.bin │ │ │ │ ├── col.json │ │ │ │ ├── col.proto.bin │ │ │ │ ├── colRegex.json │ │ │ │ ├── colRegex.proto.bin │ │ │ │ ├── column_add.json │ │ │ │ ├── column_add.proto.bin │ │ │ │ ├── column_alias.json │ │ │ │ ├── column_alias.proto.bin │ │ │ │ ├── column_and.json │ │ │ │ ├── column_and.proto.bin │ │ │ │ ├── column_apply.json │ │ │ │ ├── column_apply.proto.bin │ │ │ │ ├── column_as_multi.json │ │ │ │ ├── column_as_multi.proto.bin │ │ │ │ ├── column_as_with_metadata.json │ │ │ │ ├── column_as_with_metadata.proto.bin │ │ │ │ ├── column_asc.json │ │ │ │ ├── column_asc.proto.bin │ │ │ │ ├── column_asc_nulls_first.json │ │ │ │ ├── column_asc_nulls_first.proto.bin │ │ │ │ ├── column_asc_nulls_last.json │ │ │ │ ├── column_asc_nulls_last.proto.bin │ │ │ │ ├── column_between.json │ │ │ │ ├── column_between.proto.bin │ │ │ │ ├── column_bitwiseAND.json │ │ │ │ ├── column_bitwiseAND.proto.bin │ │ │ │ ├── column_bitwiseOR.json │ │ │ │ ├── column_bitwiseOR.proto.bin │ │ │ │ ├── column_bitwiseXOR.json │ │ │ │ ├── column_bitwiseXOR.proto.bin │ │ │ │ ├── column_cast.json │ │ │ │ ├── column_cast.proto.bin │ │ │ │ ├── column_contains.json │ │ │ │ ├── column_contains.proto.bin │ │ │ │ ├── column_desc.json │ │ │ │ ├── column_desc.proto.bin │ │ │ │ ├── column_desc_nulls_first.json │ │ │ │ ├── column_desc_nulls_first.proto.bin │ │ │ │ ├── column_desc_nulls_last.json │ │ │ │ ├── column_desc_nulls_last.proto.bin │ │ │ │ ├── column_divide.json │ │ │ │ ├── column_divide.proto.bin │ │ │ │ ├── column_dropFields.json │ │ │ │ ├── column_dropFields.proto.bin │ │ │ │ ├── column_endsWith.json │ │ │ │ ├── column_endsWith.proto.bin │ │ │ │ ├── column_eqNullSafe.json │ │ │ │ ├── column_eqNullSafe.proto.bin │ │ │ │ ├── column_equals.json │ │ │ │ ├── column_equals.proto.bin │ │ │ │ ├── column_geq.json │ │ │ │ ├── column_geq.proto.bin │ │ │ │ ├── column_getField.json │ │ │ │ ├── column_getField.proto.bin │ │ │ │ ├── column_getItem.json │ │ │ │ ├── column_getItem.proto.bin │ │ │ │ ├── column_gt.json │ │ │ │ ├── column_gt.proto.bin │ │ │ │ ├── column_ilike.json │ │ │ │ ├── column_ilike.proto.bin │ │ │ │ ├── column_isNaN.json │ │ │ │ ├── column_isNaN.proto.bin │ │ │ │ ├── column_isNotNull.json │ │ │ │ ├── column_isNotNull.proto.bin │ │ │ │ ├── column_isNull.json │ │ │ │ ├── column_isNull.proto.bin │ │ │ │ ├── column_isin.json │ │ │ │ ├── column_isin.proto.bin │ │ │ │ ├── column_leq.json │ │ │ │ ├── column_leq.proto.bin │ │ │ │ ├── column_like.json │ │ │ │ ├── column_like.proto.bin │ │ │ │ ├── column_lt.json │ │ │ │ ├── column_lt.proto.bin │ │ │ │ ├── column_modulo.json │ │ │ │ ├── column_modulo.proto.bin │ │ │ │ ├── column_multiply.json │ │ │ │ ├── column_multiply.proto.bin │ │ │ │ ├── column_not.json │ │ │ │ ├── column_not.proto.bin │ │ │ │ ├── column_not_equals.json │ │ │ │ ├── column_not_equals.proto.bin │ │ │ │ ├── column_or.json │ │ │ │ ├── column_or.proto.bin │ │ │ │ ├── column_rlike.json │ │ │ │ ├── column_rlike.proto.bin │ │ │ │ ├── column_star.json │ │ │ │ ├── column_star.proto.bin │ │ │ │ ├── column_star_with_target.json │ │ │ │ ├── column_star_with_target.proto.bin │ │ │ │ ├── column_startsWith.json │ │ │ │ ├── column_startsWith.proto.bin │ │ │ │ ├── column_substr.json │ │ │ │ ├── column_substr.proto.bin │ │ │ │ ├── column_subtract.json │ │ │ │ ├── column_subtract.proto.bin │ │ │ │ ├── column_try_cast.json │ │ │ │ ├── column_try_cast.proto.bin │ │ │ │ ├── column_unary_minus.json │ │ │ │ ├── column_unary_minus.proto.bin │ │ │ │ ├── column_when_otherwise.json │ │ │ │ ├── column_when_otherwise.proto.bin │ │ │ │ ├── column_withField.json │ │ │ │ ├── column_withField.proto.bin │ │ │ │ ├── crossJoin.json │ │ │ │ ├── crossJoin.proto.bin │ │ │ │ ├── crosstab.json │ │ │ │ ├── crosstab.proto.bin │ │ │ │ ├── csv_from_dataset.json │ │ │ │ ├── csv_from_dataset.proto.bin │ │ │ │ ├── cube_column.json │ │ │ │ ├── cube_column.proto.bin │ │ │ │ ├── cube_string.json │ │ │ │ ├── cube_string.proto.bin │ │ │ │ ├── describe.json │ │ │ │ ├── describe.proto.bin │ │ │ │ ├── distinct.json │ │ │ │ ├── distinct.proto.bin │ │ │ │ ├── drop.json │ │ │ │ ├── drop.proto.bin │ │ │ │ ├── dropDuplicates.json │ │ │ │ ├── dropDuplicates.proto.bin │ │ │ │ ├── dropDuplicates_names_array.json │ │ │ │ ├── dropDuplicates_names_array.proto.bin │ │ │ │ ├── dropDuplicates_names_seq.json │ │ │ │ ├── dropDuplicates_names_seq.proto.bin │ │ │ │ ├── dropDuplicates_varargs.json │ │ │ │ ├── dropDuplicates_varargs.proto.bin │ │ │ │ ├── drop_multiple_column.json │ │ │ │ ├── drop_multiple_column.proto.bin │ │ │ │ ├── drop_multiple_strings.json │ │ │ │ ├── drop_multiple_strings.proto.bin │ │ │ │ ├── drop_single_column.json │ │ │ │ ├── drop_single_column.proto.bin │ │ │ │ ├── drop_single_string.json │ │ │ │ ├── drop_single_string.proto.bin │ │ │ │ ├── except.json │ │ │ │ ├── except.proto.bin │ │ │ │ ├── exceptAll.json │ │ │ │ ├── exceptAll.proto.bin │ │ │ │ ├── expression_extension.json │ │ │ │ ├── expression_extension.proto.bin │ │ │ │ ├── expression_extension_deprecated.json │ │ │ │ ├── expression_extension_deprecated.proto.bin │ │ │ │ ├── fill.json │ │ │ │ ├── fill.proto.bin │ │ │ │ ├── filter.json │ │ │ │ ├── filter.proto.bin │ │ │ │ ├── filter_expr.json │ │ │ │ ├── filter_expr.proto.bin │ │ │ │ ├── freqItems.json │ │ │ │ ├── freqItems.proto.bin │ │ │ │ ├── from_avro_with_options.json │ │ │ │ ├── from_avro_with_options.proto.bin │ │ │ │ ├── from_avro_without_options.json │ │ │ │ ├── from_avro_without_options.proto.bin │ │ │ │ ├── from_protobuf_messageClassName_descFilePath.json │ │ │ │ ├── from_protobuf_messageClassName_descFilePath.proto.bin │ │ │ │ ├── from_protobuf_messageClassName_descFilePath_options.json │ │ │ │ ├── from_protobuf_messageClassName_descFilePath_options.proto.bin │ │ │ │ ├── function_abs.json │ │ │ │ ├── function_abs.proto.bin │ │ │ │ ├── function_acos.json │ │ │ │ ├── function_acos.proto.bin │ │ │ │ ├── function_acosh.json │ │ │ │ ├── function_acosh.proto.bin │ │ │ │ ├── function_add_months.json │ │ │ │ ├── function_add_months.proto.bin │ │ │ │ ├── function_aes_decrypt.json │ │ │ │ ├── function_aes_decrypt.proto.bin │ │ │ │ ├── function_aes_decrypt_with_mode.json │ │ │ │ ├── function_aes_decrypt_with_mode.proto.bin │ │ │ │ ├── function_aes_decrypt_with_mode_padding.json │ │ │ │ ├── function_aes_decrypt_with_mode_padding.proto.bin │ │ │ │ ├── function_aes_decrypt_with_mode_padding_aad.json │ │ │ │ ├── function_aes_decrypt_with_mode_padding_aad.proto.bin │ │ │ │ ├── function_aes_encrypt.json │ │ │ │ ├── function_aes_encrypt.proto.bin │ │ │ │ ├── function_aes_encrypt_with_mode.json │ │ │ │ ├── function_aes_encrypt_with_mode.proto.bin │ │ │ │ ├── function_aes_encrypt_with_mode_padding.json │ │ │ │ ├── function_aes_encrypt_with_mode_padding.proto.bin │ │ │ │ ├── function_aes_encrypt_with_mode_padding_iv.json │ │ │ │ ├── function_aes_encrypt_with_mode_padding_iv.proto.bin │ │ │ │ ├── function_aes_encrypt_with_mode_padding_iv_aad.json │ │ │ │ ├── function_aes_encrypt_with_mode_padding_iv_aad.proto.bin │ │ │ │ ├── function_aggregate.json │ │ │ │ ├── function_aggregate.proto.bin │ │ │ │ ├── function_aggregate_with_finish_lambda.json │ │ │ │ ├── function_aggregate_with_finish_lambda.proto.bin │ │ │ │ ├── function_any.json │ │ │ │ ├── function_any.proto.bin │ │ │ │ ├── function_any_value_with_ignore_nulls.json │ │ │ │ ├── function_any_value_with_ignore_nulls.proto.bin │ │ │ │ ├── function_any_value_with_respect_nulls.json │ │ │ │ ├── function_any_value_with_respect_nulls.proto.bin │ │ │ │ ├── function_approx_count_distinct.json │ │ │ │ ├── function_approx_count_distinct.proto.bin │ │ │ │ ├── function_approx_count_distinct_rsd.json │ │ │ │ ├── function_approx_count_distinct_rsd.proto.bin │ │ │ │ ├── function_approx_percentile.json │ │ │ │ ├── function_approx_percentile.proto.bin │ │ │ │ ├── function_array.json │ │ │ │ ├── function_array.proto.bin │ │ │ │ ├── function_array_agg.json │ │ │ │ ├── function_array_agg.proto.bin │ │ │ │ ├── function_array_append.json │ │ │ │ ├── function_array_append.proto.bin │ │ │ │ ├── function_array_compact.json │ │ │ │ ├── function_array_compact.proto.bin │ │ │ │ ├── function_array_contains.json │ │ │ │ ├── function_array_contains.proto.bin │ │ │ │ ├── function_array_distinct.json │ │ │ │ ├── function_array_distinct.proto.bin │ │ │ │ ├── function_array_except.json │ │ │ │ ├── function_array_except.proto.bin │ │ │ │ ├── function_array_insert.json │ │ │ │ ├── function_array_insert.proto.bin │ │ │ │ ├── function_array_intersect.json │ │ │ │ ├── function_array_intersect.proto.bin │ │ │ │ ├── function_array_join.json │ │ │ │ ├── function_array_join.proto.bin │ │ │ │ ├── function_array_join_with_null_replacement.json │ │ │ │ ├── function_array_join_with_null_replacement.proto.bin │ │ │ │ ├── function_array_max.json │ │ │ │ ├── function_array_max.proto.bin │ │ │ │ ├── function_array_min.json │ │ │ │ ├── function_array_min.proto.bin │ │ │ │ ├── function_array_position.json │ │ │ │ ├── function_array_position.proto.bin │ │ │ │ ├── function_array_prepend.json │ │ │ │ ├── function_array_prepend.proto.bin │ │ │ │ ├── function_array_remove.json │ │ │ │ ├── function_array_remove.proto.bin │ │ │ │ ├── function_array_repeat.json │ │ │ │ ├── function_array_repeat.proto.bin │ │ │ │ ├── function_array_size.json │ │ │ │ ├── function_array_size.proto.bin │ │ │ │ ├── function_array_sort.json │ │ │ │ ├── function_array_sort.proto.bin │ │ │ │ ├── function_array_sort_with_comparator.json │ │ │ │ ├── function_array_sort_with_comparator.proto.bin │ │ │ │ ├── function_array_union.json │ │ │ │ ├── function_array_union.proto.bin │ │ │ │ ├── function_arrays_overlap.json │ │ │ │ ├── function_arrays_overlap.proto.bin │ │ │ │ ├── function_arrays_zip.json │ │ │ │ ├── function_arrays_zip.proto.bin │ │ │ │ ├── function_asc.json │ │ │ │ ├── function_asc.proto.bin │ │ │ │ ├── function_asc_nulls_first.json │ │ │ │ ├── function_asc_nulls_first.proto.bin │ │ │ │ ├── function_asc_nulls_last.json │ │ │ │ ├── function_asc_nulls_last.proto.bin │ │ │ │ ├── function_ascii.json │ │ │ │ ├── function_ascii.proto.bin │ │ │ │ ├── function_asin.json │ │ │ │ ├── function_asin.proto.bin │ │ │ │ ├── function_asinh.json │ │ │ │ ├── function_asinh.proto.bin │ │ │ │ ├── function_assert_true_with_message.json │ │ │ │ ├── function_assert_true_with_message.proto.bin │ │ │ │ ├── function_atan.json │ │ │ │ ├── function_atan.proto.bin │ │ │ │ ├── function_atan2.json │ │ │ │ ├── function_atan2.proto.bin │ │ │ │ ├── function_atanh.json │ │ │ │ ├── function_atanh.proto.bin │ │ │ │ ├── function_avg.json │ │ │ │ ├── function_avg.proto.bin │ │ │ │ ├── function_base64.json │ │ │ │ ├── function_base64.proto.bin │ │ │ │ ├── function_bin.json │ │ │ │ ├── function_bin.proto.bin │ │ │ │ ├── function_bit_and.json │ │ │ │ ├── function_bit_and.proto.bin │ │ │ │ ├── function_bit_count.json │ │ │ │ ├── function_bit_count.proto.bin │ │ │ │ ├── function_bit_get.json │ │ │ │ ├── function_bit_get.proto.bin │ │ │ │ ├── function_bit_length.json │ │ │ │ ├── function_bit_length.proto.bin │ │ │ │ ├── function_bit_or.json │ │ │ │ ├── function_bit_or.proto.bin │ │ │ │ ├── function_bit_xor.json │ │ │ │ ├── function_bit_xor.proto.bin │ │ │ │ ├── function_bitmap_bit_position.json │ │ │ │ ├── function_bitmap_bit_position.proto.bin │ │ │ │ ├── function_bitmap_bucket_number.json │ │ │ │ ├── function_bitmap_bucket_number.proto.bin │ │ │ │ ├── function_bitmap_construct_agg.json │ │ │ │ ├── function_bitmap_construct_agg.proto.bin │ │ │ │ ├── function_bitmap_count.json │ │ │ │ ├── function_bitmap_count.proto.bin │ │ │ │ ├── function_bitmap_or_agg.json │ │ │ │ ├── function_bitmap_or_agg.proto.bin │ │ │ │ ├── function_bitwise_not.json │ │ │ │ ├── function_bitwise_not.proto.bin │ │ │ │ ├── function_bool_and.json │ │ │ │ ├── function_bool_and.proto.bin │ │ │ │ ├── function_bool_or.json │ │ │ │ ├── function_bool_or.proto.bin │ │ │ │ ├── function_bround.json │ │ │ │ ├── function_bround.proto.bin │ │ │ │ ├── function_btrim.json │ │ │ │ ├── function_btrim.proto.bin │ │ │ │ ├── function_btrim_with_specified_trim_string.json │ │ │ │ ├── function_btrim_with_specified_trim_string.proto.bin │ │ │ │ ├── function_bucket.json │ │ │ │ ├── function_bucket.proto.bin │ │ │ │ ├── function_call_function.json │ │ │ │ ├── function_call_function.proto.bin │ │ │ │ ├── function_call_function_orphaned.json │ │ │ │ ├── function_call_function_orphaned.proto.bin │ │ │ │ ├── function_cardinality.json │ │ │ │ ├── function_cardinality.proto.bin │ │ │ │ ├── function_ceil.json │ │ │ │ ├── function_ceil.proto.bin │ │ │ │ ├── function_ceil_scale.json │ │ │ │ ├── function_ceil_scale.proto.bin │ │ │ │ ├── function_ceiling.json │ │ │ │ ├── function_ceiling.proto.bin │ │ │ │ ├── function_ceiling_scale.json │ │ │ │ ├── function_ceiling_scale.proto.bin │ │ │ │ ├── function_char.json │ │ │ │ ├── function_char.proto.bin │ │ │ │ ├── function_char_length.json │ │ │ │ ├── function_char_length.proto.bin │ │ │ │ ├── function_character_length.json │ │ │ │ ├── function_character_length.proto.bin │ │ │ │ ├── function_chr.json │ │ │ │ ├── function_chr.proto.bin │ │ │ │ ├── function_coalesce.json │ │ │ │ ├── function_coalesce.proto.bin │ │ │ │ ├── function_col.json │ │ │ │ ├── function_col.proto.bin │ │ │ │ ├── function_collate.json │ │ │ │ ├── function_collate.proto.bin │ │ │ │ ├── function_collation.json │ │ │ │ ├── function_collation.proto.bin │ │ │ │ ├── function_collect_list.json │ │ │ │ ├── function_collect_list.proto.bin │ │ │ │ ├── function_collect_set.json │ │ │ │ ├── function_collect_set.proto.bin │ │ │ │ ├── function_concat.json │ │ │ │ ├── function_concat.proto.bin │ │ │ │ ├── function_concat_ws.json │ │ │ │ ├── function_concat_ws.proto.bin │ │ │ │ ├── function_contains.json │ │ │ │ ├── function_contains.proto.bin │ │ │ │ ├── function_conv.json │ │ │ │ ├── function_conv.proto.bin │ │ │ │ ├── function_convert_timezone_with_source_time_zone.json │ │ │ │ ├── function_convert_timezone_with_source_time_zone.proto.bin │ │ │ │ ├── function_convert_timezone_without_source_time_zone.json │ │ │ │ ├── function_convert_timezone_without_source_time_zone.proto.bin │ │ │ │ ├── function_corr.json │ │ │ │ ├── function_corr.proto.bin │ │ │ │ ├── function_cos.json │ │ │ │ ├── function_cos.proto.bin │ │ │ │ ├── function_cosh.json │ │ │ │ ├── function_cosh.proto.bin │ │ │ │ ├── function_cot.json │ │ │ │ ├── function_cot.proto.bin │ │ │ │ ├── function_count.json │ │ │ │ ├── function_count.proto.bin │ │ │ │ ├── function_countDistinct.json │ │ │ │ ├── function_countDistinct.proto.bin │ │ │ │ ├── function_count_if.json │ │ │ │ ├── function_count_if.proto.bin │ │ │ │ ├── function_count_min_sketch.json │ │ │ │ ├── function_count_min_sketch.proto.bin │ │ │ │ ├── function_count_typed.json │ │ │ │ ├── function_count_typed.proto.bin │ │ │ │ ├── function_covar_pop.json │ │ │ │ ├── function_covar_pop.proto.bin │ │ │ │ ├── function_covar_samp.json │ │ │ │ ├── function_covar_samp.proto.bin │ │ │ │ ├── function_crc32.json │ │ │ │ ├── function_crc32.proto.bin │ │ │ │ ├── function_csc.json │ │ │ │ ├── function_csc.proto.bin │ │ │ │ ├── function_cume_dist.json │ │ │ │ ├── function_cume_dist.proto.bin │ │ │ │ ├── function_curdate.json │ │ │ │ ├── function_curdate.proto.bin │ │ │ │ ├── function_current_catalog.json │ │ │ │ ├── function_current_catalog.proto.bin │ │ │ │ ├── function_current_database.json │ │ │ │ ├── function_current_database.proto.bin │ │ │ │ ├── function_current_date.json │ │ │ │ ├── function_current_date.proto.bin │ │ │ │ ├── function_current_schema.json │ │ │ │ ├── function_current_schema.proto.bin │ │ │ │ ├── function_current_timestamp.json │ │ │ │ ├── function_current_timestamp.proto.bin │ │ │ │ ├── function_current_timezone.json │ │ │ │ ├── function_current_timezone.proto.bin │ │ │ │ ├── function_current_user.json │ │ │ │ ├── function_current_user.proto.bin │ │ │ │ ├── function_date_add.json │ │ │ │ ├── function_date_add.proto.bin │ │ │ │ ├── function_date_diff.json │ │ │ │ ├── function_date_diff.proto.bin │ │ │ │ ├── function_date_format.json │ │ │ │ ├── function_date_format.proto.bin │ │ │ │ ├── function_date_from_unix_date.json │ │ │ │ ├── function_date_from_unix_date.proto.bin │ │ │ │ ├── function_date_part.json │ │ │ │ ├── function_date_part.proto.bin │ │ │ │ ├── function_date_sub.json │ │ │ │ ├── function_date_sub.proto.bin │ │ │ │ ├── function_date_trunc.json │ │ │ │ ├── function_date_trunc.proto.bin │ │ │ │ ├── function_dateadd.json │ │ │ │ ├── function_dateadd.proto.bin │ │ │ │ ├── function_datediff.json │ │ │ │ ├── function_datediff.proto.bin │ │ │ │ ├── function_datepart.json │ │ │ │ ├── function_datepart.proto.bin │ │ │ │ ├── function_day.json │ │ │ │ ├── function_day.proto.bin │ │ │ │ ├── function_dayname.json │ │ │ │ ├── function_dayname.proto.bin │ │ │ │ ├── function_dayofmonth.json │ │ │ │ ├── function_dayofmonth.proto.bin │ │ │ │ ├── function_dayofweek.json │ │ │ │ ├── function_dayofweek.proto.bin │ │ │ │ ├── function_dayofyear.json │ │ │ │ ├── function_dayofyear.proto.bin │ │ │ │ ├── function_days.json │ │ │ │ ├── function_days.proto.bin │ │ │ │ ├── function_decode.json │ │ │ │ ├── function_decode.proto.bin │ │ │ │ ├── function_degrees.json │ │ │ │ ├── function_degrees.proto.bin │ │ │ │ ├── function_dense_rank.json │ │ │ │ ├── function_dense_rank.proto.bin │ │ │ │ ├── function_desc.json │ │ │ │ ├── function_desc.proto.bin │ │ │ │ ├── function_desc_nulls_first.json │ │ │ │ ├── function_desc_nulls_first.proto.bin │ │ │ │ ├── function_desc_nulls_last.json │ │ │ │ ├── function_desc_nulls_last.proto.bin │ │ │ │ ├── function_e.json │ │ │ │ ├── function_e.proto.bin │ │ │ │ ├── function_element_at.json │ │ │ │ ├── function_element_at.proto.bin │ │ │ │ ├── function_elt.json │ │ │ │ ├── function_elt.proto.bin │ │ │ │ ├── function_encode.json │ │ │ │ ├── function_encode.proto.bin │ │ │ │ ├── function_endswith.json │ │ │ │ ├── function_endswith.proto.bin │ │ │ │ ├── function_equal_null.json │ │ │ │ ├── function_equal_null.proto.bin │ │ │ │ ├── function_every.json │ │ │ │ ├── function_every.proto.bin │ │ │ │ ├── function_exists.json │ │ │ │ ├── function_exists.proto.bin │ │ │ │ ├── function_exp.json │ │ │ │ ├── function_exp.proto.bin │ │ │ │ ├── function_explode.json │ │ │ │ ├── function_explode.proto.bin │ │ │ │ ├── function_explode_outer.json │ │ │ │ ├── function_explode_outer.proto.bin │ │ │ │ ├── function_expm1.json │ │ │ │ ├── function_expm1.proto.bin │ │ │ │ ├── function_expr.json │ │ │ │ ├── function_expr.proto.bin │ │ │ │ ├── function_extract.json │ │ │ │ ├── function_extract.proto.bin │ │ │ │ ├── function_factorial.json │ │ │ │ ├── function_factorial.proto.bin │ │ │ │ ├── function_filter.json │ │ │ │ ├── function_filter.proto.bin │ │ │ │ ├── function_filter_with_pair_input.json │ │ │ │ ├── function_filter_with_pair_input.proto.bin │ │ │ │ ├── function_find_in_set.json │ │ │ │ ├── function_find_in_set.proto.bin │ │ │ │ ├── function_first_value_with_ignore_nulls.json │ │ │ │ ├── function_first_value_with_ignore_nulls.proto.bin │ │ │ │ ├── function_first_value_with_respect_nulls.json │ │ │ │ ├── function_first_value_with_respect_nulls.proto.bin │ │ │ │ ├── function_first_with_ignore_nulls.json │ │ │ │ ├── function_first_with_ignore_nulls.proto.bin │ │ │ │ ├── function_first_with_respect_nulls.json │ │ │ │ ├── function_first_with_respect_nulls.proto.bin │ │ │ │ ├── function_flatten.json │ │ │ │ ├── function_flatten.proto.bin │ │ │ │ ├── function_floor.json │ │ │ │ ├── function_floor.proto.bin │ │ │ │ ├── function_floor_scale.json │ │ │ │ ├── function_floor_scale.proto.bin │ │ │ │ ├── function_forall.json │ │ │ │ ├── function_forall.proto.bin │ │ │ │ ├── function_format_number.json │ │ │ │ ├── function_format_number.proto.bin │ │ │ │ ├── function_from_csv.json │ │ │ │ ├── function_from_csv.proto.bin │ │ │ │ ├── function_from_json.json │ │ │ │ ├── function_from_json.proto.bin │ │ │ │ ├── function_from_json_orphaned.json │ │ │ │ ├── function_from_json_orphaned.proto.bin │ │ │ │ ├── function_from_json_with_json_schema.json │ │ │ │ ├── function_from_json_with_json_schema.proto.bin │ │ │ │ ├── function_from_unixtime.json │ │ │ │ ├── function_from_unixtime.proto.bin │ │ │ │ ├── function_from_utc_timestamp.json │ │ │ │ ├── function_from_utc_timestamp.proto.bin │ │ │ │ ├── function_from_xml.json │ │ │ │ ├── function_from_xml.proto.bin │ │ │ │ ├── function_from_xml_with_json_schema.json │ │ │ │ ├── function_from_xml_with_json_schema.proto.bin │ │ │ │ ├── function_get.json │ │ │ │ ├── function_get.proto.bin │ │ │ │ ├── function_get_json_object.json │ │ │ │ ├── function_get_json_object.proto.bin │ │ │ │ ├── function_getbit.json │ │ │ │ ├── function_getbit.proto.bin │ │ │ │ ├── function_greatest.json │ │ │ │ ├── function_greatest.proto.bin │ │ │ │ ├── function_hash.json │ │ │ │ ├── function_hash.proto.bin │ │ │ │ ├── function_hex.json │ │ │ │ ├── function_hex.proto.bin │ │ │ │ ├── function_histogram_numeric.json │ │ │ │ ├── function_histogram_numeric.proto.bin │ │ │ │ ├── function_hour.json │ │ │ │ ├── function_hour.proto.bin │ │ │ │ ├── function_hours.json │ │ │ │ ├── function_hours.proto.bin │ │ │ │ ├── function_hypot.json │ │ │ │ ├── function_hypot.proto.bin │ │ │ │ ├── function_ifnull.json │ │ │ │ ├── function_ifnull.proto.bin │ │ │ │ ├── function_ilike.json │ │ │ │ ├── function_ilike.proto.bin │ │ │ │ ├── function_ilike_with_escape.json │ │ │ │ ├── function_ilike_with_escape.proto.bin │ │ │ │ ├── function_initcap.json │ │ │ │ ├── function_initcap.proto.bin │ │ │ │ ├── function_inline.json │ │ │ │ ├── function_inline.proto.bin │ │ │ │ ├── function_inline_outer.json │ │ │ │ ├── function_inline_outer.proto.bin │ │ │ │ ├── function_input_file_block_length.json │ │ │ │ ├── function_input_file_block_length.proto.bin │ │ │ │ ├── function_input_file_block_start.json │ │ │ │ ├── function_input_file_block_start.proto.bin │ │ │ │ ├── function_input_file_name.json │ │ │ │ ├── function_input_file_name.proto.bin │ │ │ │ ├── function_is_variant_null.json │ │ │ │ ├── function_is_variant_null.proto.bin │ │ │ │ ├── function_isnan.json │ │ │ │ ├── function_isnan.proto.bin │ │ │ │ ├── function_isnotnull.json │ │ │ │ ├── function_isnotnull.proto.bin │ │ │ │ ├── function_isnull.json │ │ │ │ ├── function_isnull.proto.bin │ │ │ │ ├── function_java_method.json │ │ │ │ ├── function_java_method.proto.bin │ │ │ │ ├── function_json_array_length.json │ │ │ │ ├── function_json_array_length.proto.bin │ │ │ │ ├── function_json_object_keys.json │ │ │ │ ├── function_json_object_keys.proto.bin │ │ │ │ ├── function_json_tuple.json │ │ │ │ ├── function_json_tuple.proto.bin │ │ │ │ ├── function_kurtosis.json │ │ │ │ ├── function_kurtosis.proto.bin │ │ │ │ ├── function_lag.json │ │ │ │ ├── function_lag.proto.bin │ │ │ │ ├── function_last_day.json │ │ │ │ ├── function_last_day.proto.bin │ │ │ │ ├── function_last_value_with_ignore_nulls.json │ │ │ │ ├── function_last_value_with_ignore_nulls.proto.bin │ │ │ │ ├── function_last_value_with_respect_nulls.json │ │ │ │ ├── function_last_value_with_respect_nulls.proto.bin │ │ │ │ ├── function_last_with_ignore_nulls.json │ │ │ │ ├── function_last_with_ignore_nulls.proto.bin │ │ │ │ ├── function_last_with_respect_nulls.json │ │ │ │ ├── function_last_with_respect_nulls.proto.bin │ │ │ │ ├── function_lcase.json │ │ │ │ ├── function_lcase.proto.bin │ │ │ │ ├── function_lead.json │ │ │ │ ├── function_lead.proto.bin │ │ │ │ ├── function_least.json │ │ │ │ ├── function_least.proto.bin │ │ │ │ ├── function_left.json │ │ │ │ ├── function_left.proto.bin │ │ │ │ ├── function_len.json │ │ │ │ ├── function_len.proto.bin │ │ │ │ ├── function_length.json │ │ │ │ ├── function_length.proto.bin │ │ │ │ ├── function_levenshtein.json │ │ │ │ ├── function_levenshtein.proto.bin │ │ │ │ ├── function_levenshtein_with_threshold.json │ │ │ │ ├── function_levenshtein_with_threshold.proto.bin │ │ │ │ ├── function_like.json │ │ │ │ ├── function_like.proto.bin │ │ │ │ ├── function_like_with_escape.json │ │ │ │ ├── function_like_with_escape.proto.bin │ │ │ │ ├── function_lit.json │ │ │ │ ├── function_lit.proto.bin │ │ │ │ ├── function_lit_array.json │ │ │ │ ├── function_lit_array.proto.bin │ │ │ │ ├── function_ln.json │ │ │ │ ├── function_ln.proto.bin │ │ │ │ ├── function_localtimestamp.json │ │ │ │ ├── function_localtimestamp.proto.bin │ │ │ │ ├── function_locate.json │ │ │ │ ├── function_locate.proto.bin │ │ │ │ ├── function_locate_with_pos.json │ │ │ │ ├── function_locate_with_pos.proto.bin │ │ │ │ ├── function_log.json │ │ │ │ ├── function_log.proto.bin │ │ │ │ ├── function_log10.json │ │ │ │ ├── function_log10.proto.bin │ │ │ │ ├── function_log1p.json │ │ │ │ ├── function_log1p.proto.bin │ │ │ │ ├── function_log2.json │ │ │ │ ├── function_log2.proto.bin │ │ │ │ ├── function_log_with_base.json │ │ │ │ ├── function_log_with_base.proto.bin │ │ │ │ ├── function_lower.json │ │ │ │ ├── function_lower.proto.bin │ │ │ │ ├── function_lpad.json │ │ │ │ ├── function_lpad.proto.bin │ │ │ │ ├── function_lpad_binary.json │ │ │ │ ├── function_lpad_binary.proto.bin │ │ │ │ ├── function_ltrim.json │ │ │ │ ├── function_ltrim.proto.bin │ │ │ │ ├── function_ltrim_with_pattern.json │ │ │ │ ├── function_ltrim_with_pattern.proto.bin │ │ │ │ ├── function_make_date.json │ │ │ │ ├── function_make_date.proto.bin │ │ │ │ ├── function_make_dt_interval.json │ │ │ │ ├── function_make_dt_interval.proto.bin │ │ │ │ ├── function_make_dt_interval_days.json │ │ │ │ ├── function_make_dt_interval_days.proto.bin │ │ │ │ ├── function_make_dt_interval_days_hours.json │ │ │ │ ├── function_make_dt_interval_days_hours.proto.bin │ │ │ │ ├── function_make_dt_interval_days_hours_mins.json │ │ │ │ ├── function_make_dt_interval_days_hours_mins.proto.bin │ │ │ │ ├── function_make_dt_interval_days_hours_mins_secs.json │ │ │ │ ├── function_make_dt_interval_days_hours_mins_secs.proto.bin │ │ │ │ ├── function_make_interval.json │ │ │ │ ├── function_make_interval.proto.bin │ │ │ │ ├── function_make_interval_years.json │ │ │ │ ├── function_make_interval_years.proto.bin │ │ │ │ ├── function_make_interval_years_months.json │ │ │ │ ├── function_make_interval_years_months.proto.bin │ │ │ │ ├── function_make_interval_years_months_weeks.json │ │ │ │ ├── function_make_interval_years_months_weeks.proto.bin │ │ │ │ ├── function_make_interval_years_months_weeks_days.json │ │ │ │ ├── function_make_interval_years_months_weeks_days.proto.bin │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours.json │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours.proto.bin │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours_mins.json │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours_mins.proto.bin │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours_mins_secs.json │ │ │ │ ├── function_make_interval_years_months_weeks_days_hours_mins_secs.proto.bin │ │ │ │ ├── function_make_timestamp_ltz_with_timezone.json │ │ │ │ ├── function_make_timestamp_ltz_with_timezone.proto.bin │ │ │ │ ├── function_make_timestamp_ltz_without_timezone.json │ │ │ │ ├── function_make_timestamp_ltz_without_timezone.proto.bin │ │ │ │ ├── function_make_timestamp_ntz.json │ │ │ │ ├── function_make_timestamp_ntz.proto.bin │ │ │ │ ├── function_make_timestamp_with_timezone.json │ │ │ │ ├── function_make_timestamp_with_timezone.proto.bin │ │ │ │ ├── function_make_timestamp_without_timezone.json │ │ │ │ ├── function_make_timestamp_without_timezone.proto.bin │ │ │ │ ├── function_make_ym_interval.json │ │ │ │ ├── function_make_ym_interval.proto.bin │ │ │ │ ├── function_make_ym_interval_years.json │ │ │ │ ├── function_make_ym_interval_years.proto.bin │ │ │ │ ├── function_make_ym_interval_years_months.json │ │ │ │ ├── function_make_ym_interval_years_months.proto.bin │ │ │ │ ├── function_map.json │ │ │ │ ├── function_map.proto.bin │ │ │ │ ├── function_map_concat.json │ │ │ │ ├── function_map_concat.proto.bin │ │ │ │ ├── function_map_contains_key.json │ │ │ │ ├── function_map_contains_key.proto.bin │ │ │ │ ├── function_map_entries.json │ │ │ │ ├── function_map_entries.proto.bin │ │ │ │ ├── function_map_filter.json │ │ │ │ ├── function_map_filter.proto.bin │ │ │ │ ├── function_map_from_arrays.json │ │ │ │ ├── function_map_from_arrays.proto.bin │ │ │ │ ├── function_map_from_entries.json │ │ │ │ ├── function_map_from_entries.proto.bin │ │ │ │ ├── function_map_keys.json │ │ │ │ ├── function_map_keys.proto.bin │ │ │ │ ├── function_map_values.json │ │ │ │ ├── function_map_values.proto.bin │ │ │ │ ├── function_map_zip_with.json │ │ │ │ ├── function_map_zip_with.proto.bin │ │ │ │ ├── function_mask.json │ │ │ │ ├── function_mask.proto.bin │ │ │ │ ├── function_mask_with_specific_upperChar.json │ │ │ │ ├── function_mask_with_specific_upperChar.proto.bin │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar.json │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar.proto.bin │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar_digitChar.json │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar_digitChar.proto.bin │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar_digitChar_otherChar.json │ │ │ │ ├── function_mask_with_specific_upperChar_lowerChar_digitChar_otherChar.proto.bin │ │ │ │ ├── function_max.json │ │ │ │ ├── function_max.proto.bin │ │ │ │ ├── function_max_by.json │ │ │ │ ├── function_max_by.proto.bin │ │ │ │ ├── function_md5.json │ │ │ │ ├── function_md5.proto.bin │ │ │ │ ├── function_median.json │ │ │ │ ├── function_median.proto.bin │ │ │ │ ├── function_min.json │ │ │ │ ├── function_min.proto.bin │ │ │ │ ├── function_min_by.json │ │ │ │ ├── function_min_by.proto.bin │ │ │ │ ├── function_minute.json │ │ │ │ ├── function_minute.proto.bin │ │ │ │ ├── function_mode.json │ │ │ │ ├── function_mode.proto.bin │ │ │ │ ├── function_mode_orphaned.json │ │ │ │ ├── function_mode_orphaned.proto.bin │ │ │ │ ├── function_monotonically_increasing_id.json │ │ │ │ ├── function_monotonically_increasing_id.proto.bin │ │ │ │ ├── function_month.json │ │ │ │ ├── function_month.proto.bin │ │ │ │ ├── function_monthname.json │ │ │ │ ├── function_monthname.proto.bin │ │ │ │ ├── function_months.json │ │ │ │ ├── function_months.proto.bin │ │ │ │ ├── function_months_between.json │ │ │ │ ├── function_months_between.proto.bin │ │ │ │ ├── function_months_between_with_roundoff.json │ │ │ │ ├── function_months_between_with_roundoff.proto.bin │ │ │ │ ├── function_named_struct.json │ │ │ │ ├── function_named_struct.proto.bin │ │ │ │ ├── function_nanvl.json │ │ │ │ ├── function_nanvl.proto.bin │ │ │ │ ├── function_negate.json │ │ │ │ ├── function_negate.proto.bin │ │ │ │ ├── function_negative.json │ │ │ │ ├── function_negative.proto.bin │ │ │ │ ├── function_next_day.json │ │ │ │ ├── function_next_day.proto.bin │ │ │ │ ├── function_now.json │ │ │ │ ├── function_now.proto.bin │ │ │ │ ├── function_nth_value.json │ │ │ │ ├── function_nth_value.proto.bin │ │ │ │ ├── function_ntile.json │ │ │ │ ├── function_ntile.proto.bin │ │ │ │ ├── function_nullif.json │ │ │ │ ├── function_nullif.proto.bin │ │ │ │ ├── function_nvl.json │ │ │ │ ├── function_nvl.proto.bin │ │ │ │ ├── function_nvl2.json │ │ │ │ ├── function_nvl2.proto.bin │ │ │ │ ├── function_octet_length.json │ │ │ │ ├── function_octet_length.proto.bin │ │ │ │ ├── function_overlay.json │ │ │ │ ├── function_overlay.proto.bin │ │ │ │ ├── function_overlay_with_len.json │ │ │ │ ├── function_overlay_with_len.proto.bin │ │ │ │ ├── function_parse_json.json │ │ │ │ ├── function_parse_json.proto.bin │ │ │ │ ├── function_parse_url.json │ │ │ │ ├── function_parse_url.proto.bin │ │ │ │ ├── function_parse_url_with_key.json │ │ │ │ ├── function_parse_url_with_key.proto.bin │ │ │ │ ├── function_percent_rank.json │ │ │ │ ├── function_percent_rank.proto.bin │ │ │ │ ├── function_percentile_approx.json │ │ │ │ ├── function_percentile_approx.proto.bin │ │ │ │ ├── function_percentile_with_frequency.json │ │ │ │ ├── function_percentile_with_frequency.proto.bin │ │ │ │ ├── function_percentile_without_frequency.json │ │ │ │ ├── function_percentile_without_frequency.proto.bin │ │ │ │ ├── function_pi.json │ │ │ │ ├── function_pi.proto.bin │ │ │ │ ├── function_pmod.json │ │ │ │ ├── function_pmod.proto.bin │ │ │ │ ├── function_posexplode.json │ │ │ │ ├── function_posexplode.proto.bin │ │ │ │ ├── function_posexplode_outer.json │ │ │ │ ├── function_posexplode_outer.proto.bin │ │ │ │ ├── function_position.json │ │ │ │ ├── function_position.proto.bin │ │ │ │ ├── function_position_with_start.json │ │ │ │ ├── function_position_with_start.proto.bin │ │ │ │ ├── function_positive.json │ │ │ │ ├── function_positive.proto.bin │ │ │ │ ├── function_pow.json │ │ │ │ ├── function_pow.proto.bin │ │ │ │ ├── function_power.json │ │ │ │ ├── function_power.proto.bin │ │ │ │ ├── function_printf.json │ │ │ │ ├── function_printf.proto.bin │ │ │ │ ├── function_product.json │ │ │ │ ├── function_product.proto.bin │ │ │ │ ├── function_quarter.json │ │ │ │ ├── function_quarter.proto.bin │ │ │ │ ├── function_radians.json │ │ │ │ ├── function_radians.proto.bin │ │ │ │ ├── function_raise_error.json │ │ │ │ ├── function_raise_error.proto.bin │ │ │ │ ├── function_rand_with_seed.json │ │ │ │ ├── function_rand_with_seed.proto.bin │ │ │ │ ├── function_randn_with_seed.json │ │ │ │ ├── function_randn_with_seed.proto.bin │ │ │ │ ├── function_random_with_seed.json │ │ │ │ ├── function_random_with_seed.proto.bin │ │ │ │ ├── function_rank.json │ │ │ │ ├── function_rank.proto.bin │ │ │ │ ├── function_reduce.json │ │ │ │ ├── function_reduce.proto.bin │ │ │ │ ├── function_reflect.json │ │ │ │ ├── function_reflect.proto.bin │ │ │ │ ├── function_regexp.json │ │ │ │ ├── function_regexp.proto.bin │ │ │ │ ├── function_regexp_count.json │ │ │ │ ├── function_regexp_count.proto.bin │ │ │ │ ├── function_regexp_extract.json │ │ │ │ ├── function_regexp_extract.proto.bin │ │ │ │ ├── function_regexp_extract_all_with_regex_group_index.json │ │ │ │ ├── function_regexp_extract_all_with_regex_group_index.proto.bin │ │ │ │ ├── function_regexp_extract_all_without_regex_group_index.json │ │ │ │ ├── function_regexp_extract_all_without_regex_group_index.proto.bin │ │ │ │ ├── function_regexp_instr_with_regex_group_index.json │ │ │ │ ├── function_regexp_instr_with_regex_group_index.proto.bin │ │ │ │ ├── function_regexp_instr_without_regex_group_index.json │ │ │ │ ├── function_regexp_instr_without_regex_group_index.proto.bin │ │ │ │ ├── function_regexp_like.json │ │ │ │ ├── function_regexp_like.proto.bin │ │ │ │ ├── function_regexp_replace.json │ │ │ │ ├── function_regexp_replace.proto.bin │ │ │ │ ├── function_regexp_substr.json │ │ │ │ ├── function_regexp_substr.proto.bin │ │ │ │ ├── function_regr_avgx.json │ │ │ │ ├── function_regr_avgx.proto.bin │ │ │ │ ├── function_regr_avgy.json │ │ │ │ ├── function_regr_avgy.proto.bin │ │ │ │ ├── function_regr_count.json │ │ │ │ ├── function_regr_count.proto.bin │ │ │ │ ├── function_regr_intercept.json │ │ │ │ ├── function_regr_intercept.proto.bin │ │ │ │ ├── function_regr_r2.json │ │ │ │ ├── function_regr_r2.proto.bin │ │ │ │ ├── function_regr_slope.json │ │ │ │ ├── function_regr_slope.proto.bin │ │ │ │ ├── function_regr_sxx.json │ │ │ │ ├── function_regr_sxx.proto.bin │ │ │ │ ├── function_regr_sxy.json │ │ │ │ ├── function_regr_sxy.proto.bin │ │ │ │ ├── function_regr_syy.json │ │ │ │ ├── function_regr_syy.proto.bin │ │ │ │ ├── function_replace.json │ │ │ │ ├── function_replace.proto.bin │ │ │ │ ├── function_replace_with_specified_string.json │ │ │ │ ├── function_replace_with_specified_string.proto.bin │ │ │ │ ├── function_reverse.json │ │ │ │ ├── function_reverse.proto.bin │ │ │ │ ├── function_right.json │ │ │ │ ├── function_right.proto.bin │ │ │ │ ├── function_rint.json │ │ │ │ ├── function_rint.proto.bin │ │ │ │ ├── function_rlike.json │ │ │ │ ├── function_rlike.proto.bin │ │ │ │ ├── function_round.json │ │ │ │ ├── function_round.proto.bin │ │ │ │ ├── function_row_number.json │ │ │ │ ├── function_row_number.proto.bin │ │ │ │ ├── function_rpad.json │ │ │ │ ├── function_rpad.proto.bin │ │ │ │ ├── function_rpad_binary.json │ │ │ │ ├── function_rpad_binary.proto.bin │ │ │ │ ├── function_rtrim.json │ │ │ │ ├── function_rtrim.proto.bin │ │ │ │ ├── function_rtrim_with_pattern.json │ │ │ │ ├── function_rtrim_with_pattern.proto.bin │ │ │ │ ├── function_schema_of_csv.json │ │ │ │ ├── function_schema_of_csv.proto.bin │ │ │ │ ├── function_schema_of_json.json │ │ │ │ ├── function_schema_of_json.proto.bin │ │ │ │ ├── function_schema_of_json_with_options.json │ │ │ │ ├── function_schema_of_json_with_options.proto.bin │ │ │ │ ├── function_schema_of_variant.json │ │ │ │ ├── function_schema_of_variant.proto.bin │ │ │ │ ├── function_schema_of_variant_agg.json │ │ │ │ ├── function_schema_of_variant_agg.proto.bin │ │ │ │ ├── function_sec.json │ │ │ │ ├── function_sec.proto.bin │ │ │ │ ├── function_second.json │ │ │ │ ├── function_second.proto.bin │ │ │ │ ├── function_sentences.json │ │ │ │ ├── function_sentences.proto.bin │ │ │ │ ├── function_sentences_with_language.json │ │ │ │ ├── function_sentences_with_language.proto.bin │ │ │ │ ├── function_sentences_with_language_and_country.json │ │ │ │ ├── function_sentences_with_language_and_country.proto.bin │ │ │ │ ├── function_sequence.json │ │ │ │ ├── function_sequence.proto.bin │ │ │ │ ├── function_session_user.json │ │ │ │ ├── function_session_user.proto.bin │ │ │ │ ├── function_session_window.json │ │ │ │ ├── function_session_window.proto.bin │ │ │ │ ├── function_session_window_orphaned.json │ │ │ │ ├── function_session_window_orphaned.proto.bin │ │ │ │ ├── function_sha.json │ │ │ │ ├── function_sha.proto.bin │ │ │ │ ├── function_sha1.json │ │ │ │ ├── function_sha1.proto.bin │ │ │ │ ├── function_sha2.json │ │ │ │ ├── function_sha2.proto.bin │ │ │ │ ├── function_shiftleft.json │ │ │ │ ├── function_shiftleft.proto.bin │ │ │ │ ├── function_shiftright.json │ │ │ │ ├── function_shiftright.proto.bin │ │ │ │ ├── function_shiftrightunsigned.json │ │ │ │ ├── function_shiftrightunsigned.proto.bin │ │ │ │ ├── function_sign.json │ │ │ │ ├── function_sign.proto.bin │ │ │ │ ├── function_signum.json │ │ │ │ ├── function_signum.proto.bin │ │ │ │ ├── function_sin.json │ │ │ │ ├── function_sin.proto.bin │ │ │ │ ├── function_sinh.json │ │ │ │ ├── function_sinh.proto.bin │ │ │ │ ├── function_size.json │ │ │ │ ├── function_size.proto.bin │ │ │ │ ├── function_skewness.json │ │ │ │ ├── function_skewness.proto.bin │ │ │ │ ├── function_slice.json │ │ │ │ ├── function_slice.proto.bin │ │ │ │ ├── function_some.json │ │ │ │ ├── function_some.proto.bin │ │ │ │ ├── function_sort_array.json │ │ │ │ ├── function_sort_array.proto.bin │ │ │ │ ├── function_spark_partition_id.json │ │ │ │ ├── function_spark_partition_id.proto.bin │ │ │ │ ├── function_split.json │ │ │ │ ├── function_split.proto.bin │ │ │ │ ├── function_split_part.json │ │ │ │ ├── function_split_part.proto.bin │ │ │ │ ├── function_split_using_columns.json │ │ │ │ ├── function_split_using_columns.proto.bin │ │ │ │ ├── function_split_with_limit.json │ │ │ │ ├── function_split_with_limit.proto.bin │ │ │ │ ├── function_split_with_limit_using_columns.json │ │ │ │ ├── function_split_with_limit_using_columns.proto.bin │ │ │ │ ├── function_sqrt.json │ │ │ │ ├── function_sqrt.proto.bin │ │ │ │ ├── function_stack.json │ │ │ │ ├── function_stack.proto.bin │ │ │ │ ├── function_startswith.json │ │ │ │ ├── function_startswith.proto.bin │ │ │ │ ├── function_std.json │ │ │ │ ├── function_std.proto.bin │ │ │ │ ├── function_stddev.json │ │ │ │ ├── function_stddev.proto.bin │ │ │ │ ├── function_stddev_pop.json │ │ │ │ ├── function_stddev_pop.proto.bin │ │ │ │ ├── function_stddev_samp.json │ │ │ │ ├── function_stddev_samp.proto.bin │ │ │ │ ├── function_str_to_map.json │ │ │ │ ├── function_str_to_map.proto.bin │ │ │ │ ├── function_str_to_map_with_pair_and_keyValue_delimiter.json │ │ │ │ ├── function_str_to_map_with_pair_and_keyValue_delimiter.proto.bin │ │ │ │ ├── function_str_to_map_with_pair_delimiter.json │ │ │ │ ├── function_str_to_map_with_pair_delimiter.proto.bin │ │ │ │ ├── function_struct.json │ │ │ │ ├── function_struct.proto.bin │ │ │ │ ├── function_substr.json │ │ │ │ ├── function_substr.proto.bin │ │ │ │ ├── function_substr_with_len.json │ │ │ │ ├── function_substr_with_len.proto.bin │ │ │ │ ├── function_substring.json │ │ │ │ ├── function_substring.proto.bin │ │ │ │ ├── function_substring_index.json │ │ │ │ ├── function_substring_index.proto.bin │ │ │ │ ├── function_substring_using_columns.json │ │ │ │ ├── function_substring_using_columns.proto.bin │ │ │ │ ├── function_sum.json │ │ │ │ ├── function_sum.proto.bin │ │ │ │ ├── function_sum_distinct.json │ │ │ │ ├── function_sum_distinct.proto.bin │ │ │ │ ├── function_tan.json │ │ │ │ ├── function_tan.proto.bin │ │ │ │ ├── function_tanh.json │ │ │ │ ├── function_tanh.proto.bin │ │ │ │ ├── function_timestamp_add.json │ │ │ │ ├── function_timestamp_add.proto.bin │ │ │ │ ├── function_timestamp_diff.json │ │ │ │ ├── function_timestamp_diff.proto.bin │ │ │ │ ├── function_timestamp_micros.json │ │ │ │ ├── function_timestamp_micros.proto.bin │ │ │ │ ├── function_timestamp_millis.json │ │ │ │ ├── function_timestamp_millis.proto.bin │ │ │ │ ├── function_timestamp_seconds.json │ │ │ │ ├── function_timestamp_seconds.proto.bin │ │ │ │ ├── function_to_binary.json │ │ │ │ ├── function_to_binary.proto.bin │ │ │ │ ├── function_to_binary_with_format.json │ │ │ │ ├── function_to_binary_with_format.proto.bin │ │ │ │ ├── function_to_char.json │ │ │ │ ├── function_to_char.proto.bin │ │ │ │ ├── function_to_csv.json │ │ │ │ ├── function_to_csv.proto.bin │ │ │ │ ├── function_to_date.json │ │ │ │ ├── function_to_date.proto.bin │ │ │ │ ├── function_to_date_with_format.json │ │ │ │ ├── function_to_date_with_format.proto.bin │ │ │ │ ├── function_to_json.json │ │ │ │ ├── function_to_json.proto.bin │ │ │ │ ├── function_to_number.json │ │ │ │ ├── function_to_number.proto.bin │ │ │ │ ├── function_to_timestamp.json │ │ │ │ ├── function_to_timestamp.proto.bin │ │ │ │ ├── function_to_timestamp_ltz.json │ │ │ │ ├── function_to_timestamp_ltz.proto.bin │ │ │ │ ├── function_to_timestamp_ltz_with_format.json │ │ │ │ ├── function_to_timestamp_ltz_with_format.proto.bin │ │ │ │ ├── function_to_timestamp_ntz.json │ │ │ │ ├── function_to_timestamp_ntz.proto.bin │ │ │ │ ├── function_to_timestamp_ntz_with_format.json │ │ │ │ ├── function_to_timestamp_ntz_with_format.proto.bin │ │ │ │ ├── function_to_timestamp_with_format.json │ │ │ │ ├── function_to_timestamp_with_format.proto.bin │ │ │ │ ├── function_to_unix_timestamp.json │ │ │ │ ├── function_to_unix_timestamp.proto.bin │ │ │ │ ├── function_to_unix_timestamp_with_format.json │ │ │ │ ├── function_to_unix_timestamp_with_format.proto.bin │ │ │ │ ├── function_to_utc_timestamp.json │ │ │ │ ├── function_to_utc_timestamp.proto.bin │ │ │ │ ├── function_to_varchar.json │ │ │ │ ├── function_to_varchar.proto.bin │ │ │ │ ├── function_transform.json │ │ │ │ ├── function_transform.proto.bin │ │ │ │ ├── function_transform_keys.json │ │ │ │ ├── function_transform_keys.proto.bin │ │ │ │ ├── function_transform_values.json │ │ │ │ ├── function_transform_values.proto.bin │ │ │ │ ├── function_transform_with_index.json │ │ │ │ ├── function_transform_with_index.proto.bin │ │ │ │ ├── function_translate.json │ │ │ │ ├── function_translate.proto.bin │ │ │ │ ├── function_trim.json │ │ │ │ ├── function_trim.proto.bin │ │ │ │ ├── function_trim_with_pattern.json │ │ │ │ ├── function_trim_with_pattern.proto.bin │ │ │ │ ├── function_trunc.json │ │ │ │ ├── function_trunc.proto.bin │ │ │ │ ├── function_try_add.json │ │ │ │ ├── function_try_add.proto.bin │ │ │ │ ├── function_try_aes_decrypt.json │ │ │ │ ├── function_try_aes_decrypt.proto.bin │ │ │ │ ├── function_try_aes_decrypt_with_mode.json │ │ │ │ ├── function_try_aes_decrypt_with_mode.proto.bin │ │ │ │ ├── function_try_aes_decrypt_with_mode_padding.json │ │ │ │ ├── function_try_aes_decrypt_with_mode_padding.proto.bin │ │ │ │ ├── function_try_aes_decrypt_with_mode_padding_aad.json │ │ │ │ ├── function_try_aes_decrypt_with_mode_padding_aad.proto.bin │ │ │ │ ├── function_try_avg.json │ │ │ │ ├── function_try_avg.proto.bin │ │ │ │ ├── function_try_divide.json │ │ │ │ ├── function_try_divide.proto.bin │ │ │ │ ├── function_try_element_at_array.json │ │ │ │ ├── function_try_element_at_array.proto.bin │ │ │ │ ├── function_try_element_at_map.json │ │ │ │ ├── function_try_element_at_map.proto.bin │ │ │ │ ├── function_try_make_interval_years.json │ │ │ │ ├── function_try_make_interval_years.proto.bin │ │ │ │ ├── function_try_make_interval_years_months.json │ │ │ │ ├── function_try_make_interval_years_months.proto.bin │ │ │ │ ├── function_try_make_interval_years_months_weeks.json │ │ │ │ ├── function_try_make_interval_years_months_weeks.proto.bin │ │ │ │ ├── function_try_make_interval_years_months_weeks_days.json │ │ │ │ ├── function_try_make_interval_years_months_weeks_days.proto.bin │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours.json │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours.proto.bin │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours_mins.json │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours_mins.proto.bin │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours_mins_secs.json │ │ │ │ ├── function_try_make_interval_years_months_weeks_days_hours_mins_secs.proto.bin │ │ │ │ ├── function_try_make_timestamp_ltz_with_timezone.json │ │ │ │ ├── function_try_make_timestamp_ltz_with_timezone.proto.bin │ │ │ │ ├── function_try_make_timestamp_ltz_without_timezone.json │ │ │ │ ├── function_try_make_timestamp_ltz_without_timezone.proto.bin │ │ │ │ ├── function_try_make_timestamp_ntz.json │ │ │ │ ├── function_try_make_timestamp_ntz.proto.bin │ │ │ │ ├── function_try_make_timestamp_with_timezone.json │ │ │ │ ├── function_try_make_timestamp_with_timezone.proto.bin │ │ │ │ ├── function_try_make_timestamp_without_timezone.json │ │ │ │ ├── function_try_make_timestamp_without_timezone.proto.bin │ │ │ │ ├── function_try_multiply.json │ │ │ │ ├── function_try_multiply.proto.bin │ │ │ │ ├── function_try_parse_json.json │ │ │ │ ├── function_try_parse_json.proto.bin │ │ │ │ ├── function_try_parse_url.json │ │ │ │ ├── function_try_parse_url.proto.bin │ │ │ │ ├── function_try_parse_url_with_key.json │ │ │ │ ├── function_try_parse_url_with_key.proto.bin │ │ │ │ ├── function_try_reflect.json │ │ │ │ ├── function_try_reflect.proto.bin │ │ │ │ ├── function_try_subtract.json │ │ │ │ ├── function_try_subtract.proto.bin │ │ │ │ ├── function_try_sum.json │ │ │ │ ├── function_try_sum.proto.bin │ │ │ │ ├── function_try_to_binary.json │ │ │ │ ├── function_try_to_binary.proto.bin │ │ │ │ ├── function_try_to_binary_without_format.json │ │ │ │ ├── function_try_to_binary_without_format.proto.bin │ │ │ │ ├── function_try_to_date.json │ │ │ │ ├── function_try_to_date.proto.bin │ │ │ │ ├── function_try_to_date_with_format.json │ │ │ │ ├── function_try_to_date_with_format.proto.bin │ │ │ │ ├── function_try_to_number.json │ │ │ │ ├── function_try_to_number.proto.bin │ │ │ │ ├── function_try_to_timestamp.json │ │ │ │ ├── function_try_to_timestamp.proto.bin │ │ │ │ ├── function_try_to_timestamp_without_format.json │ │ │ │ ├── function_try_to_timestamp_without_format.proto.bin │ │ │ │ ├── function_try_url_decode.json │ │ │ │ ├── function_try_url_decode.proto.bin │ │ │ │ ├── function_try_variant_get.json │ │ │ │ ├── function_try_variant_get.proto.bin │ │ │ │ ├── function_typedLit.json │ │ │ │ ├── function_typedLit.proto.bin │ │ │ │ ├── function_typeof.json │ │ │ │ ├── function_typeof.proto.bin │ │ │ │ ├── function_ucase.json │ │ │ │ ├── function_ucase.proto.bin │ │ │ │ ├── function_unbase64.json │ │ │ │ ├── function_unbase64.proto.bin │ │ │ │ ├── function_unhex.json │ │ │ │ ├── function_unhex.proto.bin │ │ │ │ ├── function_unix_date.json │ │ │ │ ├── function_unix_date.proto.bin │ │ │ │ ├── function_unix_micros.json │ │ │ │ ├── function_unix_micros.proto.bin │ │ │ │ ├── function_unix_millis.json │ │ │ │ ├── function_unix_millis.proto.bin │ │ │ │ ├── function_unix_seconds.json │ │ │ │ ├── function_unix_seconds.proto.bin │ │ │ │ ├── function_unix_timestamp.json │ │ │ │ ├── function_unix_timestamp.proto.bin │ │ │ │ ├── function_unix_timestamp_with_format.json │ │ │ │ ├── function_unix_timestamp_with_format.proto.bin │ │ │ │ ├── function_upper.json │ │ │ │ ├── function_upper.proto.bin │ │ │ │ ├── function_url_decode.json │ │ │ │ ├── function_url_decode.proto.bin │ │ │ │ ├── function_url_encode.json │ │ │ │ ├── function_url_encode.proto.bin │ │ │ │ ├── function_user.json │ │ │ │ ├── function_user.proto.bin │ │ │ │ ├── function_var_pop.json │ │ │ │ ├── function_var_pop.proto.bin │ │ │ │ ├── function_var_samp.json │ │ │ │ ├── function_var_samp.proto.bin │ │ │ │ ├── function_variance.json │ │ │ │ ├── function_variance.proto.bin │ │ │ │ ├── function_variant_get.json │ │ │ │ ├── function_variant_get.proto.bin │ │ │ │ ├── function_weekday.json │ │ │ │ ├── function_weekday.proto.bin │ │ │ │ ├── function_weekofyear.json │ │ │ │ ├── function_weekofyear.proto.bin │ │ │ │ ├── function_window.json │ │ │ │ ├── function_window.proto.bin │ │ │ │ ├── function_window_time.json │ │ │ │ ├── function_window_time.proto.bin │ │ │ │ ├── function_xpath.json │ │ │ │ ├── function_xpath.proto.bin │ │ │ │ ├── function_xpath_boolean.json │ │ │ │ ├── function_xpath_boolean.proto.bin │ │ │ │ ├── function_xpath_double.json │ │ │ │ ├── function_xpath_double.proto.bin │ │ │ │ ├── function_xpath_float.json │ │ │ │ ├── function_xpath_float.proto.bin │ │ │ │ ├── function_xpath_int.json │ │ │ │ ├── function_xpath_int.proto.bin │ │ │ │ ├── function_xpath_long.json │ │ │ │ ├── function_xpath_long.proto.bin │ │ │ │ ├── function_xpath_number.json │ │ │ │ ├── function_xpath_number.proto.bin │ │ │ │ ├── function_xpath_short.json │ │ │ │ ├── function_xpath_short.proto.bin │ │ │ │ ├── function_xpath_string.json │ │ │ │ ├── function_xpath_string.proto.bin │ │ │ │ ├── function_xxhash64.json │ │ │ │ ├── function_xxhash64.proto.bin │ │ │ │ ├── function_year.json │ │ │ │ ├── function_year.proto.bin │ │ │ │ ├── function_years.json │ │ │ │ ├── function_years.proto.bin │ │ │ │ ├── function_zip_with.json │ │ │ │ ├── function_zip_with.proto.bin │ │ │ │ ├── groupby_agg.json │ │ │ │ ├── groupby_agg.proto.bin │ │ │ │ ├── groupby_agg_columns.json │ │ │ │ ├── groupby_agg_columns.proto.bin │ │ │ │ ├── groupby_agg_orphaned.json │ │ │ │ ├── groupby_agg_orphaned.proto.bin │ │ │ │ ├── groupby_agg_string.json │ │ │ │ ├── groupby_agg_string.proto.bin │ │ │ │ ├── groupby_avg.json │ │ │ │ ├── groupby_avg.proto.bin │ │ │ │ ├── groupby_count.json │ │ │ │ ├── groupby_count.proto.bin │ │ │ │ ├── groupby_max.json │ │ │ │ ├── groupby_max.proto.bin │ │ │ │ ├── groupby_mean.json │ │ │ │ ├── groupby_mean.proto.bin │ │ │ │ ├── groupby_min.json │ │ │ │ ├── groupby_min.proto.bin │ │ │ │ ├── groupby_sum.json │ │ │ │ ├── groupby_sum.proto.bin │ │ │ │ ├── groupingSets.json │ │ │ │ ├── groupingSets.proto.bin │ │ │ │ ├── grouping_and_grouping_id.json │ │ │ │ ├── grouping_and_grouping_id.proto.bin │ │ │ │ ├── hint.json │ │ │ │ ├── hint.proto.bin │ │ │ │ ├── hll_sketch_agg.json │ │ │ │ ├── hll_sketch_agg.proto.bin │ │ │ │ ├── hll_sketch_agg_with_columnName.json │ │ │ │ ├── hll_sketch_agg_with_columnName.proto.bin │ │ │ │ ├── hll_sketch_agg_with_columnName_lgConfigK_int.json │ │ │ │ ├── hll_sketch_agg_with_columnName_lgConfigK_int.proto.bin │ │ │ │ ├── hll_sketch_agg_with_column_lgConfigK.json │ │ │ │ ├── hll_sketch_agg_with_column_lgConfigK.proto.bin │ │ │ │ ├── hll_sketch_agg_with_column_lgConfigK_int.json │ │ │ │ ├── hll_sketch_agg_with_column_lgConfigK_int.proto.bin │ │ │ │ ├── hll_union_agg.json │ │ │ │ ├── hll_union_agg.proto.bin │ │ │ │ ├── hll_union_agg_with_columnName.json │ │ │ │ ├── hll_union_agg_with_columnName.proto.bin │ │ │ │ ├── hll_union_agg_with_columnName_allowDifferentLgConfigK_boolean.json │ │ │ │ ├── hll_union_agg_with_columnName_allowDifferentLgConfigK_boolean.proto.bin │ │ │ │ ├── hll_union_agg_with_column_allowDifferentLgConfigK.json │ │ │ │ ├── hll_union_agg_with_column_allowDifferentLgConfigK.proto.bin │ │ │ │ ├── hll_union_agg_with_column_allowDifferentLgConfigK_boolean.json │ │ │ │ ├── hll_union_agg_with_column_allowDifferentLgConfigK_boolean.proto.bin │ │ │ │ ├── intersect.json │ │ │ │ ├── intersect.proto.bin │ │ │ │ ├── intersectAll.json │ │ │ │ ├── intersectAll.proto.bin │ │ │ │ ├── join_condition.json │ │ │ │ ├── join_condition.proto.bin │ │ │ │ ├── join_inner_condition.json │ │ │ │ ├── join_inner_condition.proto.bin │ │ │ │ ├── join_inner_no_condition.json │ │ │ │ ├── join_inner_no_condition.proto.bin │ │ │ │ ├── join_inner_using_multiple_col_array.json │ │ │ │ ├── join_inner_using_multiple_col_array.proto.bin │ │ │ │ ├── join_inner_using_multiple_col_seq.json │ │ │ │ ├── join_inner_using_multiple_col_seq.proto.bin │ │ │ │ ├── join_inner_using_single_col.json │ │ │ │ ├── join_inner_using_single_col.proto.bin │ │ │ │ ├── join_using_multiple_col_array.json │ │ │ │ ├── join_using_multiple_col_array.proto.bin │ │ │ │ ├── join_using_multiple_col_seq.json │ │ │ │ ├── join_using_multiple_col_seq.proto.bin │ │ │ │ ├── join_using_single_col.json │ │ │ │ ├── join_using_single_col.proto.bin │ │ │ │ ├── json_from_dataset.json │ │ │ │ ├── json_from_dataset.proto.bin │ │ │ │ ├── limit.json │ │ │ │ ├── limit.proto.bin │ │ │ │ ├── melt_no_values.json │ │ │ │ ├── melt_no_values.proto.bin │ │ │ │ ├── melt_values.json │ │ │ │ ├── melt_values.proto.bin │ │ │ │ ├── offset.json │ │ │ │ ├── offset.proto.bin │ │ │ │ ├── orderBy_columns.json │ │ │ │ ├── orderBy_columns.proto.bin │ │ │ │ ├── orderBy_strings.json │ │ │ │ ├── orderBy_strings.proto.bin │ │ │ │ ├── pivot.json │ │ │ │ ├── pivot.proto.bin │ │ │ │ ├── pivot_without_column_values.json │ │ │ │ ├── pivot_without_column_values.proto.bin │ │ │ │ ├── range.json │ │ │ │ ├── range.proto.bin │ │ │ │ ├── read.json │ │ │ │ ├── read.proto.bin │ │ │ │ ├── read_csv.json │ │ │ │ ├── read_csv.proto.bin │ │ │ │ ├── read_jdbc.json │ │ │ │ ├── read_jdbc.proto.bin │ │ │ │ ├── read_jdbc_with_partition.json │ │ │ │ ├── read_jdbc_with_partition.proto.bin │ │ │ │ ├── read_jdbc_with_predicates.json │ │ │ │ ├── read_jdbc_with_predicates.proto.bin │ │ │ │ ├── read_json.json │ │ │ │ ├── read_json.proto.bin │ │ │ │ ├── read_orc.json │ │ │ │ ├── read_orc.proto.bin │ │ │ │ ├── read_parquet.json │ │ │ │ ├── read_parquet.proto.bin │ │ │ │ ├── read_table.json │ │ │ │ ├── read_table.proto.bin │ │ │ │ ├── read_text.json │ │ │ │ ├── read_text.proto.bin │ │ │ │ ├── relation_extension.json │ │ │ │ ├── relation_extension.proto.bin │ │ │ │ ├── relation_extension_deprecated.json │ │ │ │ ├── relation_extension_deprecated.proto.bin │ │ │ │ ├── repartition.json │ │ │ │ ├── repartition.proto.bin │ │ │ │ ├── repartitionById.json │ │ │ │ ├── repartitionById.proto.bin │ │ │ │ ├── repartitionByRange_expressions.json │ │ │ │ ├── repartitionByRange_expressions.proto.bin │ │ │ │ ├── repartitionByRange_num_partitions_expressions.json │ │ │ │ ├── repartitionByRange_num_partitions_expressions.proto.bin │ │ │ │ ├── repartition_expressions.json │ │ │ │ ├── repartition_expressions.proto.bin │ │ │ │ ├── repartition_num_partitions_expressions.json │ │ │ │ ├── repartition_num_partitions_expressions.proto.bin │ │ │ │ ├── replace.json │ │ │ │ ├── replace.proto.bin │ │ │ │ ├── rollup_column.json │ │ │ │ ├── rollup_column.proto.bin │ │ │ │ ├── rollup_string.json │ │ │ │ ├── rollup_string.proto.bin │ │ │ │ ├── sampleBy.json │ │ │ │ ├── sampleBy.proto.bin │ │ │ │ ├── sample_fraction_seed.json │ │ │ │ ├── sample_fraction_seed.proto.bin │ │ │ │ ├── sample_withReplacement_fraction_seed.json │ │ │ │ ├── sample_withReplacement_fraction_seed.proto.bin │ │ │ │ ├── select.json │ │ │ │ ├── select.proto.bin │ │ │ │ ├── selectExpr.json │ │ │ │ ├── selectExpr.proto.bin │ │ │ │ ├── select_collated_string.json │ │ │ │ ├── select_collated_string.proto.bin │ │ │ │ ├── select_strings.json │ │ │ │ ├── select_strings.proto.bin │ │ │ │ ├── select_typed_1-arg.json │ │ │ │ ├── select_typed_1-arg.proto.bin │ │ │ │ ├── select_typed_2-arg.json │ │ │ │ ├── select_typed_2-arg.proto.bin │ │ │ │ ├── select_typed_3-arg.json │ │ │ │ ├── select_typed_3-arg.proto.bin │ │ │ │ ├── select_typed_4-arg.json │ │ │ │ ├── select_typed_4-arg.proto.bin │ │ │ │ ├── select_typed_5-arg.json │ │ │ │ ├── select_typed_5-arg.proto.bin │ │ │ │ ├── sortWithinPartitions_columns.json │ │ │ │ ├── sortWithinPartitions_columns.proto.bin │ │ │ │ ├── sortWithinPartitions_strings.json │ │ │ │ ├── sortWithinPartitions_strings.proto.bin │ │ │ │ ├── sort_columns.json │ │ │ │ ├── sort_columns.proto.bin │ │ │ │ ├── sort_strings.json │ │ │ │ ├── sort_strings.proto.bin │ │ │ │ ├── streaming_table_API_with_options.json │ │ │ │ ├── streaming_table_API_with_options.proto.bin │ │ │ │ ├── summary.json │ │ │ │ ├── summary.proto.bin │ │ │ │ ├── table.json │ │ │ │ ├── table.proto.bin │ │ │ │ ├── table_API_with_options.json │ │ │ │ ├── table_API_with_options.proto.bin │ │ │ │ ├── test_broadcast.json │ │ │ │ ├── test_broadcast.proto.bin │ │ │ │ ├── to.json │ │ │ │ ├── to.proto.bin │ │ │ │ ├── toDF.json │ │ │ │ ├── toDF.proto.bin │ │ │ │ ├── toJSON.json │ │ │ │ ├── toJSON.proto.bin │ │ │ │ ├── to_avro_with_schema.json │ │ │ │ ├── to_avro_with_schema.proto.bin │ │ │ │ ├── to_avro_without_schema.json │ │ │ │ ├── to_avro_without_schema.proto.bin │ │ │ │ ├── to_protobuf_messageClassName.json │ │ │ │ ├── to_protobuf_messageClassName.proto.bin │ │ │ │ ├── to_protobuf_messageClassName_descFilePath.json │ │ │ │ ├── to_protobuf_messageClassName_descFilePath.proto.bin │ │ │ │ ├── to_protobuf_messageClassName_descFilePath_options.json │ │ │ │ ├── to_protobuf_messageClassName_descFilePath_options.proto.bin │ │ │ │ ├── to_protobuf_messageClassName_options.json │ │ │ │ ├── to_protobuf_messageClassName_options.proto.bin │ │ │ │ ├── transpose_index_column.json │ │ │ │ ├── transpose_index_column.proto.bin │ │ │ │ ├── transpose_no_index_column.json │ │ │ │ ├── transpose_no_index_column.proto.bin │ │ │ │ ├── union.json │ │ │ │ ├── union.proto.bin │ │ │ │ ├── unionAll.json │ │ │ │ ├── unionAll.proto.bin │ │ │ │ ├── unionByName.json │ │ │ │ ├── unionByName.proto.bin │ │ │ │ ├── unionByName_allowMissingColumns.json │ │ │ │ ├── unionByName_allowMissingColumns.proto.bin │ │ │ │ ├── unpivot_no_values.json │ │ │ │ ├── unpivot_no_values.proto.bin │ │ │ │ ├── unpivot_values.json │ │ │ │ ├── unpivot_values.proto.bin │ │ │ │ ├── where_column.json │ │ │ │ ├── where_column.proto.bin │ │ │ │ ├── where_expr.json │ │ │ │ ├── where_expr.proto.bin │ │ │ │ ├── width_bucket.json │ │ │ │ ├── width_bucket.proto.bin │ │ │ │ ├── window.json │ │ │ │ ├── window.proto.bin │ │ │ │ ├── withColumnRenamed_java_map.json │ │ │ │ ├── withColumnRenamed_java_map.proto.bin │ │ │ │ ├── withColumnRenamed_scala_map.json │ │ │ │ ├── withColumnRenamed_scala_map.proto.bin │ │ │ │ ├── withColumnRenamed_single.json │ │ │ │ ├── withColumnRenamed_single.proto.bin │ │ │ │ ├── withColumn_single.json │ │ │ │ ├── withColumn_single.proto.bin │ │ │ │ ├── withColumns_java_map.json │ │ │ │ ├── withColumns_java_map.proto.bin │ │ │ │ ├── withColumns_scala_map.json │ │ │ │ ├── withColumns_scala_map.proto.bin │ │ │ │ ├── withMetadata.json │ │ │ │ └── withMetadata.proto.bin │ │ │ │ └── test-data │ │ │ │ ├── people.csv │ │ │ │ ├── people.json │ │ │ │ ├── people.txt │ │ │ │ ├── streaming │ │ │ │ ├── csv │ │ │ │ │ └── people.csv │ │ │ │ └── txt │ │ │ │ │ └── people.txt │ │ │ │ ├── users.orc │ │ │ │ └── users.parquet │ │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── TestUDFs.scala │ ├── docs │ │ ├── adding-proto-messages.md │ │ └── client-connection-string.md │ ├── server │ │ ├── README.md │ │ ├── pom.xml │ │ └── src │ │ │ ├── main │ │ │ ├── java │ │ │ │ └── org │ │ │ │ │ └── apache │ │ │ │ │ └── spark │ │ │ │ │ └── sql │ │ │ │ │ └── connect │ │ │ │ │ └── plugin │ │ │ │ │ ├── CommandPlugin.java │ │ │ │ │ ├── ExpressionPlugin.java │ │ │ │ │ ├── MLBackendPlugin.java │ │ │ │ │ └── RelationPlugin.java │ │ │ └── scala │ │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── connect │ │ │ │ ├── SimpleSparkConnectService.scala │ │ │ │ ├── SparkConnectPlugin.scala │ │ │ │ ├── config │ │ │ │ ├── Connect.scala │ │ │ │ └── ConnectPlanCompressionAlgorithm.scala │ │ │ │ ├── execution │ │ │ │ ├── CachedStreamResponse.scala │ │ │ │ ├── ConnectProgressExecutionListener.scala │ │ │ │ ├── ExecuteGrpcResponseSender.scala │ │ │ │ ├── ExecuteResponseObserver.scala │ │ │ │ ├── ExecuteThreadRunner.scala │ │ │ │ └── SparkConnectPlanExecution.scala │ │ │ │ ├── ml │ │ │ │ ├── MLCache.scala │ │ │ │ ├── MLException.scala │ │ │ │ ├── MLHandler.scala │ │ │ │ ├── MLUtils.scala │ │ │ │ └── Serializer.scala │ │ │ │ ├── pipelines │ │ │ │ ├── DataflowGraphRegistry.scala │ │ │ │ ├── PipelineEventSender.scala │ │ │ │ └── PipelinesHandler.scala │ │ │ │ ├── planner │ │ │ │ ├── InvalidInputErrors.scala │ │ │ │ ├── LiteralExpressionProtoConverter.scala │ │ │ │ ├── MockObserver.scala │ │ │ │ ├── SaveModeConverter.scala │ │ │ │ ├── SparkConnectPlanner.scala │ │ │ │ ├── SparkConnectStreamingQueryListenerHandler.scala │ │ │ │ ├── StreamingForeachBatchHelper.scala │ │ │ │ ├── StreamingQueryListenerHelper.scala │ │ │ │ └── TableSaveMethodConverter.scala │ │ │ │ ├── plugin │ │ │ │ └── SparkConnectPluginRegistry.scala │ │ │ │ ├── service │ │ │ │ ├── ExecuteEventsManager.scala │ │ │ │ ├── ExecuteHolder.scala │ │ │ │ ├── LocalPropertiesCleanupInterceptor.scala │ │ │ │ ├── LoggingInterceptor.scala │ │ │ │ ├── PreSharedKeyAuthenticationInterceptor.scala │ │ │ │ ├── SessionEventsManager.scala │ │ │ │ ├── SessionHolder.scala │ │ │ │ ├── SparkConnectAddArtifactsHandler.scala │ │ │ │ ├── SparkConnectAnalyzeHandler.scala │ │ │ │ ├── SparkConnectArtifactStatusesHandler.scala │ │ │ │ ├── SparkConnectCloneSessionHandler.scala │ │ │ │ ├── SparkConnectConfigHandler.scala │ │ │ │ ├── SparkConnectExecutePlanHandler.scala │ │ │ │ ├── SparkConnectExecutionManager.scala │ │ │ │ ├── SparkConnectFetchErrorDetailsHandler.scala │ │ │ │ ├── SparkConnectInterceptorRegistry.scala │ │ │ │ ├── SparkConnectInterruptHandler.scala │ │ │ │ ├── SparkConnectListenerBusListener.scala │ │ │ │ ├── SparkConnectReattachExecuteHandler.scala │ │ │ │ ├── SparkConnectReleaseExecuteHandler.scala │ │ │ │ ├── SparkConnectReleaseSessionHandler.scala │ │ │ │ ├── SparkConnectServer.scala │ │ │ │ ├── SparkConnectService.scala │ │ │ │ ├── SparkConnectSessionManager.scala │ │ │ │ └── SparkConnectStreamingQueryCache.scala │ │ │ │ ├── ui │ │ │ │ ├── SparkConnectServerAppStatusStore.scala │ │ │ │ ├── SparkConnectServerHistoryServerPlugin.scala │ │ │ │ ├── SparkConnectServerListener.scala │ │ │ │ ├── SparkConnectServerPage.scala │ │ │ │ ├── SparkConnectServerSessionPage.scala │ │ │ │ ├── SparkConnectServerTab.scala │ │ │ │ └── ToolTips.scala │ │ │ │ └── utils │ │ │ │ ├── ErrorUtils.scala │ │ │ │ ├── MetricGenerator.scala │ │ │ │ ├── PipelineAnalysisContextUtils.scala │ │ │ │ └── PlanCompressionUtils.scala │ │ │ └── test │ │ │ ├── resources │ │ │ ├── META-INF │ │ │ │ └── services │ │ │ │ │ ├── org.apache.spark.ml.Estimator │ │ │ │ │ ├── org.apache.spark.ml.Transformer │ │ │ │ │ └── org.apache.spark.ml.evaluation.Evaluator │ │ │ ├── log4j2.properties │ │ │ └── udf │ │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── connect │ │ │ ├── ProtoToParsedPlanTestSuite.scala │ │ │ ├── PythonTestDepsChecker.scala │ │ │ ├── ResourceHelper.scala │ │ │ ├── SparkConnectServerTest.scala │ │ │ ├── SparkConnectTestUtils.scala │ │ │ ├── dsl │ │ │ └── package.scala │ │ │ ├── execution │ │ │ ├── ConnectProgressExecutionListenerSuite.scala │ │ │ └── ReattachableExecuteSuite.scala │ │ │ ├── messages │ │ │ ├── AbbreviateSuite.scala │ │ │ └── ConnectProtoMessagesSuite.scala │ │ │ ├── ml │ │ │ ├── MLBackendSuite.scala │ │ │ ├── MLHelper.scala │ │ │ └── MLSuite.scala │ │ │ ├── pipelines │ │ │ ├── EndToEndAPISuite.scala │ │ │ ├── PipelineEventSenderSuite.scala │ │ │ ├── PipelineEventStreamSuite.scala │ │ │ ├── PipelineRefreshFunctionalSuite.scala │ │ │ ├── PythonPipelineSuite.scala │ │ │ ├── SparkDeclarativePipelinesServerSuite.scala │ │ │ ├── SparkDeclarativePipelinesServerTest.scala │ │ │ └── TestPipelineDefinition.scala │ │ │ ├── planner │ │ │ ├── InvalidInputErrorsSuite.scala │ │ │ ├── LiteralExpressionProtoConverterSuite.scala │ │ │ ├── SparkConnectPlannerSuite.scala │ │ │ ├── SparkConnectPlannerTestUtils.scala │ │ │ ├── SparkConnectProtoSuite.scala │ │ │ ├── SparkConnectServiceSuite.scala │ │ │ ├── SparkConnectWithSessionExtensionSuite.scala │ │ │ └── StreamingForeachBatchHelperSuite.scala │ │ │ ├── plugin │ │ │ └── SparkConnectPluginRegistrySuite.scala │ │ │ ├── service │ │ │ ├── AddArtifactsHandlerSuite.scala │ │ │ ├── ArtifactStatusesHandlerSuite.scala │ │ │ ├── ExecuteEventsManagerSuite.scala │ │ │ ├── FetchErrorDetailsHandlerSuite.scala │ │ │ ├── InterceptorRegistrySuite.scala │ │ │ ├── SessionEventsManagerSuite.scala │ │ │ ├── SparkConnectAuthSuite.scala │ │ │ ├── SparkConnectCloneSessionSuite.scala │ │ │ ├── SparkConnectListenerBusListenerSuite.scala │ │ │ ├── SparkConnectServiceE2ESuite.scala │ │ │ ├── SparkConnectServiceInternalServerSuite.scala │ │ │ ├── SparkConnectSessionHolderSuite.scala │ │ │ ├── SparkConnectSessionManagerSuite.scala │ │ │ └── SparkConnectStreamingQueryCacheSuite.scala │ │ │ └── ui │ │ │ ├── SparkConnectServerListenerSuite.scala │ │ │ └── SparkConnectServerPageSuite.scala │ └── shims │ │ ├── README.md │ │ ├── pom.xml │ │ └── src │ │ └── main │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── shims.scala ├── core │ ├── benchmarks │ │ ├── AggregateBenchmark-jdk21-results.txt │ │ ├── AggregateBenchmark-results.txt │ │ ├── AnsiIntervalSortBenchmark-jdk21-results.txt │ │ ├── AnsiIntervalSortBenchmark-results.txt │ │ ├── Base64Benchmark-jdk21-results.txt │ │ ├── Base64Benchmark-results.txt │ │ ├── BloomFilterBenchmark-jdk21-results.txt │ │ ├── BloomFilterBenchmark-results.txt │ │ ├── BuiltInDataSourceWriteBenchmark-jdk21-results.txt │ │ ├── BuiltInDataSourceWriteBenchmark-results.txt │ │ ├── ByteArrayBenchmark-jdk21-results.txt │ │ ├── ByteArrayBenchmark-results.txt │ │ ├── CSVBenchmark-jdk21-results.txt │ │ ├── CSVBenchmark-results.txt │ │ ├── CharVarcharBenchmark-jdk21-results.txt │ │ ├── CharVarcharBenchmark-results.txt │ │ ├── CollationBenchmark-jdk21-results.txt │ │ ├── CollationBenchmark-results.txt │ │ ├── CollationNonASCIIBenchmark-jdk21-results.txt │ │ ├── CollationNonASCIIBenchmark-results.txt │ │ ├── ColumnarBatchBenchmark-jdk21-results.txt │ │ ├── ColumnarBatchBenchmark-results.txt │ │ ├── CompressionSchemeBenchmark-jdk21-results.txt │ │ ├── CompressionSchemeBenchmark-results.txt │ │ ├── ConstantColumnVectorBenchmark-jdk21-results.txt │ │ ├── ConstantColumnVectorBenchmark-results.txt │ │ ├── DataSourceReadBenchmark-jdk21-results.txt │ │ ├── DataSourceReadBenchmark-results.txt │ │ ├── DatasetBenchmark-jdk21-results.txt │ │ ├── DatasetBenchmark-results.txt │ │ ├── DateTimeBenchmark-jdk21-results.txt │ │ ├── DateTimeBenchmark-results.txt │ │ ├── DateTimeRebaseBenchmark-jdk21-results.txt │ │ ├── DateTimeRebaseBenchmark-results.txt │ │ ├── EncodeBenchmark-jdk21-results.txt │ │ ├── EncodeBenchmark-results.txt │ │ ├── ExternalAppendOnlyUnsafeRowArrayBenchmark-jdk21-results.txt │ │ ├── ExternalAppendOnlyUnsafeRowArrayBenchmark-results.txt │ │ ├── ExtractBenchmark-jdk21-results.txt │ │ ├── ExtractBenchmark-results.txt │ │ ├── FilterPushdownBenchmark-jdk21-results.txt │ │ ├── FilterPushdownBenchmark-results.txt │ │ ├── GenerateExecBenchmark-jdk21-results.txt │ │ ├── GenerateExecBenchmark-results.txt │ │ ├── HashedRelationMetricsBenchmark-jdk21-results.txt │ │ ├── HashedRelationMetricsBenchmark-results.txt │ │ ├── InExpressionBenchmark-jdk21-results.txt │ │ ├── InExpressionBenchmark-results.txt │ │ ├── InMemoryColumnarBenchmark-jdk21-results.txt │ │ ├── InMemoryColumnarBenchmark-results.txt │ │ ├── InsertTableWithDynamicPartitionsBenchmark-jdk21-results.txt │ │ ├── InsertTableWithDynamicPartitionsBenchmark-results.txt │ │ ├── IntervalBenchmark-jdk21-results.txt │ │ ├── IntervalBenchmark-results.txt │ │ ├── JoinBenchmark-jdk21-results.txt │ │ ├── JoinBenchmark-results.txt │ │ ├── JsonBenchmark-jdk21-results.txt │ │ ├── JsonBenchmark-results.txt │ │ ├── LargeRowBenchmark-jdk21-results.txt │ │ ├── LargeRowBenchmark-results.txt │ │ ├── MakeDateTimeBenchmark-jdk21-results.txt │ │ ├── MakeDateTimeBenchmark-results.txt │ │ ├── MetadataStructBenchmark-jdk21-results.txt │ │ ├── MetadataStructBenchmark-results.txt │ │ ├── MetricsAggregationBenchmark-jdk21-results.txt │ │ ├── MetricsAggregationBenchmark-results.txt │ │ ├── MiscBenchmark-jdk21-results.txt │ │ ├── MiscBenchmark-results.txt │ │ ├── OrcNestedSchemaPruningBenchmark-jdk21-results.txt │ │ ├── OrcNestedSchemaPruningBenchmark-results.txt │ │ ├── OrcV2NestedSchemaPruningBenchmark-jdk21-results.txt │ │ ├── OrcV2NestedSchemaPruningBenchmark-results.txt │ │ ├── ParquetNestedPredicatePushDownBenchmark-jdk21-results.txt │ │ ├── ParquetNestedPredicatePushDownBenchmark-results.txt │ │ ├── ParquetNestedSchemaPruningBenchmark-jdk21-results.txt │ │ ├── ParquetNestedSchemaPruningBenchmark-results.txt │ │ ├── PrimitiveArrayBenchmark-jdk21-results.txt │ │ ├── PrimitiveArrayBenchmark-results.txt │ │ ├── RangeBenchmark-jdk21-results.txt │ │ ├── RangeBenchmark-results.txt │ │ ├── RecursiveCTEBenchmark-jdk21-results.txt │ │ ├── RecursiveCTEBenchmark-results.txt │ │ ├── SetOperationsBenchmark-jdk21-results.txt │ │ ├── SetOperationsBenchmark-results.txt │ │ ├── SortBenchmark-jdk21-results.txt │ │ ├── SortBenchmark-results.txt │ │ ├── StateStoreBasicOperationsBenchmark-jdk21-results.txt │ │ ├── StateStoreBasicOperationsBenchmark-results.txt │ │ ├── StringFunctionsBenchmark-jdk21-results.txt │ │ ├── StringFunctionsBenchmark-results.txt │ │ ├── SubExprEliminationBenchmark-jdk21-results.txt │ │ ├── SubExprEliminationBenchmark-results.txt │ │ ├── TPCDSQueryBenchmark-jdk21-results.txt │ │ ├── TPCDSQueryBenchmark-results.txt │ │ ├── TakeOrderedAndProjectBenchmark-jdk21-results.txt │ │ ├── TakeOrderedAndProjectBenchmark-results.txt │ │ ├── TopKBenchmark-jdk21-results.txt │ │ ├── TopKBenchmark-results.txt │ │ ├── UDFBenchmark-jdk21-results.txt │ │ ├── UDFBenchmark-results.txt │ │ ├── UnsafeArrayDataBenchmark-jdk21-results.txt │ │ ├── UnsafeArrayDataBenchmark-results.txt │ │ ├── UpdateFieldsBenchmark-jdk21-results.txt │ │ ├── UpdateFieldsBenchmark-results.txt │ │ ├── V2FunctionBenchmark-jdk21-results.txt │ │ ├── V2FunctionBenchmark-results.txt │ │ ├── WideSchemaBenchmark-jdk21-results.txt │ │ ├── WideSchemaBenchmark-results.txt │ │ ├── WideTableBenchmark-jdk21-results.txt │ │ └── WideTableBenchmark-results.txt │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── buf.gen.yaml │ │ ├── buf.work.yaml │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ ├── parquet │ │ │ │ └── filter2 │ │ │ │ │ └── predicate │ │ │ │ │ └── SparkFilterApi.java │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ ├── avro │ │ │ │ ├── AvroCompressionCodec.java │ │ │ │ └── SparkAvroKeyOutputFormat.java │ │ │ │ ├── connector │ │ │ │ ├── read │ │ │ │ │ └── V1Scan.java │ │ │ │ └── write │ │ │ │ │ └── V1Write.java │ │ │ │ ├── execution │ │ │ │ ├── BufferedRowIterator.java │ │ │ │ ├── RecordBinaryComparator.java │ │ │ │ ├── UnsafeExternalRowSorter.java │ │ │ │ ├── UnsafeFixedWidthAggregationMap.java │ │ │ │ ├── UnsafeKVExternalSorter.java │ │ │ │ ├── columnar │ │ │ │ │ └── ColumnDictionary.java │ │ │ │ ├── datasources │ │ │ │ │ ├── HadoopLineRecordReader.java │ │ │ │ │ ├── SchemaColumnConvertNotSupportedException.java │ │ │ │ │ ├── orc │ │ │ │ │ │ ├── OrcArrayColumnVector.java │ │ │ │ │ │ ├── OrcAtomicColumnVector.java │ │ │ │ │ │ ├── OrcColumnStatistics.java │ │ │ │ │ │ ├── OrcColumnVector.java │ │ │ │ │ │ ├── OrcColumnVectorUtils.java │ │ │ │ │ │ ├── OrcColumnarBatchReader.java │ │ │ │ │ │ ├── OrcCompressionCodec.java │ │ │ │ │ │ ├── OrcFooterReader.java │ │ │ │ │ │ ├── OrcMapColumnVector.java │ │ │ │ │ │ └── OrcStructColumnVector.java │ │ │ │ │ └── parquet │ │ │ │ │ │ ├── OpenedParquetFooter.java │ │ │ │ │ │ ├── ParquetColumnVector.java │ │ │ │ │ │ ├── ParquetCompressionCodec.java │ │ │ │ │ │ ├── ParquetDictionary.java │ │ │ │ │ │ ├── ParquetFooterReader.java │ │ │ │ │ │ ├── ParquetReadState.java │ │ │ │ │ │ ├── ParquetVectorUpdater.java │ │ │ │ │ │ ├── ParquetVectorUpdaterFactory.java │ │ │ │ │ │ ├── SpecificParquetRecordReaderBase.java │ │ │ │ │ │ ├── VectorizedColumnReader.java │ │ │ │ │ │ ├── VectorizedDeltaBinaryPackedReader.java │ │ │ │ │ │ ├── VectorizedDeltaByteArrayReader.java │ │ │ │ │ │ ├── VectorizedDeltaLengthByteArrayReader.java │ │ │ │ │ │ ├── VectorizedParquetRecordReader.java │ │ │ │ │ │ ├── VectorizedPlainValuesReader.java │ │ │ │ │ │ ├── VectorizedReaderBase.java │ │ │ │ │ │ ├── VectorizedRleValuesReader.java │ │ │ │ │ │ └── VectorizedValuesReader.java │ │ │ │ ├── streaming │ │ │ │ │ └── Offset.java │ │ │ │ └── vectorized │ │ │ │ │ ├── AggregateHashMap.java │ │ │ │ │ ├── ColumnVectorUtils.java │ │ │ │ │ ├── ConstantColumnVector.java │ │ │ │ │ ├── Dictionary.java │ │ │ │ │ ├── MutableColumnarRow.java │ │ │ │ │ ├── OffHeapColumnVector.java │ │ │ │ │ ├── OnHeapColumnVector.java │ │ │ │ │ └── WritableColumnVector.java │ │ │ │ └── internal │ │ │ │ └── NonClosableMutableURLClassLoader.java │ │ ├── protobuf │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── execution │ │ │ │ └── streaming │ │ │ │ └── StateMessage.proto │ │ ├── resources │ │ │ ├── META-INF │ │ │ │ └── services │ │ │ │ │ ├── org.apache.spark.deploy.history.EventFilterBuilder │ │ │ │ │ ├── org.apache.spark.sql.jdbc.JdbcConnectionProvider │ │ │ │ │ ├── org.apache.spark.sql.jdbc.JdbcDialect │ │ │ │ │ ├── org.apache.spark.sql.sources.DataSourceRegister │ │ │ │ │ ├── org.apache.spark.status.AppHistoryServerPlugin │ │ │ │ │ └── org.apache.spark.status.protobuf.ProtobufSerDe │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ └── execution │ │ │ │ └── ui │ │ │ │ └── static │ │ │ │ ├── spark-sql-viz.css │ │ │ │ └── spark-sql-viz.js │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── sql │ │ │ ├── DataSourceRegistration.scala │ │ │ ├── ExperimentalMethods.scala │ │ │ ├── ExtendedExplainGenerator.scala │ │ │ ├── SparkSessionExtensions.scala │ │ │ ├── SparkSessionExtensionsProvider.scala │ │ │ ├── TableArg.scala │ │ │ ├── UDTFRegistration.scala │ │ │ ├── api │ │ │ │ ├── package.scala │ │ │ │ ├── python │ │ │ │ │ └── PythonSQLUtils.scala │ │ │ │ └── r │ │ │ │ │ └── SQLUtils.scala │ │ │ ├── artifact │ │ │ │ └── ArtifactManager.scala │ │ │ ├── avro │ │ │ │ ├── AvroDeserializer.scala │ │ │ │ ├── AvroFileFormat.scala │ │ │ │ ├── AvroOptions.scala │ │ │ │ ├── AvroOutputWriter.scala │ │ │ │ ├── AvroOutputWriterFactory.scala │ │ │ │ ├── AvroSerializer.scala │ │ │ │ ├── AvroUtils.scala │ │ │ │ ├── CustomDecimal.scala │ │ │ │ └── SchemaConverters.scala │ │ │ ├── catalyst │ │ │ │ ├── analysis │ │ │ │ │ ├── EvalSubqueriesForTimeTravel.scala │ │ │ │ │ ├── InvokeProcedures.scala │ │ │ │ │ ├── ReplaceCharWithVarchar.scala │ │ │ │ │ ├── ResolveDataSource.scala │ │ │ │ │ ├── ResolveExecuteImmediate.scala │ │ │ │ │ ├── ResolveSessionCatalog.scala │ │ │ │ │ └── ResolveTranspose.scala │ │ │ │ └── plans │ │ │ │ │ └── logical │ │ │ │ │ ├── CommandResult.scala │ │ │ │ │ ├── SQLFunctionNode.scala │ │ │ │ │ └── UnresolvedDataSource.scala │ │ │ ├── classic │ │ │ │ ├── Catalog.scala │ │ │ │ ├── DataFrameNaFunctions.scala │ │ │ │ ├── DataFrameReader.scala │ │ │ │ ├── DataFrameStatFunctions.scala │ │ │ │ ├── DataFrameWriter.scala │ │ │ │ ├── DataFrameWriterV2.scala │ │ │ │ ├── DataStreamReader.scala │ │ │ │ ├── DataStreamWriter.scala │ │ │ │ ├── Dataset.scala │ │ │ │ ├── KeyValueGroupedDataset.scala │ │ │ │ ├── MergeIntoWriter.scala │ │ │ │ ├── ObservationManager.scala │ │ │ │ ├── RelationalGroupedDataset.scala │ │ │ │ ├── RuntimeConfig.scala │ │ │ │ ├── SQLContext.scala │ │ │ │ ├── SQLImplicits.scala │ │ │ │ ├── SparkSession.scala │ │ │ │ ├── StreamingCheckpointManager.scala │ │ │ │ ├── StreamingQuery.scala │ │ │ │ ├── StreamingQueryManager.scala │ │ │ │ ├── TableValuedFunction.scala │ │ │ │ ├── TypedAggUtils.scala │ │ │ │ ├── UDFRegistration.scala │ │ │ │ ├── UserDefinedFunctionUtils.scala │ │ │ │ ├── columnNodeSupport.scala │ │ │ │ ├── conversions.scala │ │ │ │ └── package.scala │ │ │ ├── columnar │ │ │ │ └── CachedBatchSerializer.scala │ │ │ ├── execution │ │ │ │ ├── AggregatingAccumulator.scala │ │ │ │ ├── AliasAwareOutputExpression.scala │ │ │ │ ├── BaseScriptTransformationExec.scala │ │ │ │ ├── CacheManager.scala │ │ │ │ ├── CoGroupedIterator.scala │ │ │ │ ├── CollectMetricsExec.scala │ │ │ │ ├── Columnar.scala │ │ │ │ ├── ColumnarEvaluatorFactory.scala │ │ │ │ ├── CommandResultExec.scala │ │ │ │ ├── DataSourceScanExec.scala │ │ │ │ ├── EmptyRelationExec.scala │ │ │ │ ├── ExistingRDD.scala │ │ │ │ ├── ExpandExec.scala │ │ │ │ ├── ExplainMode.scala │ │ │ │ ├── ExplainUtils.scala │ │ │ │ ├── ExternalAppendOnlyUnsafeRowArray.scala │ │ │ │ ├── FileRelation.scala │ │ │ │ ├── FilterEvaluatorFactory.scala │ │ │ │ ├── GenerateExec.scala │ │ │ │ ├── GroupedIterator.scala │ │ │ │ ├── HiveResult.scala │ │ │ │ ├── InsertSortForLimitAndOffset.scala │ │ │ │ ├── KeyGroupedPartitionedScan.scala │ │ │ │ ├── LocalTableScanExec.scala │ │ │ │ ├── MultiResultExec.scala │ │ │ │ ├── OptimizeMetadataOnlyQuery.scala │ │ │ │ ├── PartitionedFileUtil.scala │ │ │ │ ├── ProjectEvaluatorFactory.scala │ │ │ │ ├── QueryExecution.scala │ │ │ │ ├── RemoveRedundantProjects.scala │ │ │ │ ├── RemoveRedundantSorts.scala │ │ │ │ ├── RemoveRedundantWindowGroupLimits.scala │ │ │ │ ├── ReplaceHashWithSortAgg.scala │ │ │ │ ├── SQLExecution.scala │ │ │ │ ├── SQLExecutionRDD.scala │ │ │ │ ├── ScanFileListing.scala │ │ │ │ ├── ShuffledRowRDD.scala │ │ │ │ ├── SortExec.scala │ │ │ │ ├── SortPrefixUtils.scala │ │ │ │ ├── SparkOptimizer.scala │ │ │ │ ├── SparkPlan.scala │ │ │ │ ├── SparkPlanInfo.scala │ │ │ │ ├── SparkPlanner.scala │ │ │ │ ├── SparkScriptTransformationExec.scala │ │ │ │ ├── SparkSqlParser.scala │ │ │ │ ├── SparkStrategies.scala │ │ │ │ ├── StreamSourceAwareSparkPlan.scala │ │ │ │ ├── SubqueryAdaptiveBroadcastExec.scala │ │ │ │ ├── SubqueryBroadcastExec.scala │ │ │ │ ├── UnionLoopExec.scala │ │ │ │ ├── UnsafeRowSerializer.scala │ │ │ │ ├── WholeStageCodegenEvaluatorFactory.scala │ │ │ │ ├── WholeStageCodegenExec.scala │ │ │ │ ├── adaptive │ │ │ │ │ ├── AQEOptimizer.scala │ │ │ │ │ ├── AQEPropagateEmptyRelation.scala │ │ │ │ │ ├── AQEShuffleReadExec.scala │ │ │ │ │ ├── AQEShuffleReadRule.scala │ │ │ │ │ ├── AQEUtils.scala │ │ │ │ │ ├── AdaptiveRulesHolder.scala │ │ │ │ │ ├── AdaptiveSparkPlanExec.scala │ │ │ │ │ ├── AdaptiveSparkPlanHelper.scala │ │ │ │ │ ├── AdjustShuffleExchangePosition.scala │ │ │ │ │ ├── CoalesceShufflePartitions.scala │ │ │ │ │ ├── DynamicJoinSelection.scala │ │ │ │ │ ├── InsertAdaptiveSparkPlan.scala │ │ │ │ │ ├── InvalidAQEPlanException.scala │ │ │ │ │ ├── LogicalQueryStage.scala │ │ │ │ │ ├── LogicalQueryStageStrategy.scala │ │ │ │ │ ├── OptimizeShuffleWithLocalRead.scala │ │ │ │ │ ├── OptimizeSkewInRebalancePartitions.scala │ │ │ │ │ ├── OptimizeSkewedJoin.scala │ │ │ │ │ ├── PlanAdaptiveDynamicPruningFilters.scala │ │ │ │ │ ├── PlanAdaptiveSubqueries.scala │ │ │ │ │ ├── QueryStageExec.scala │ │ │ │ │ ├── ReuseAdaptiveSubquery.scala │ │ │ │ │ ├── ShufflePartitionsUtil.scala │ │ │ │ │ ├── ValidateSparkPlan.scala │ │ │ │ │ ├── costing.scala │ │ │ │ │ └── simpleCosting.scala │ │ │ │ ├── aggregate │ │ │ │ │ ├── AggUtils.scala │ │ │ │ │ ├── AggregateCodegenSupport.scala │ │ │ │ │ ├── AggregationIterator.scala │ │ │ │ │ ├── BaseAggregateExec.scala │ │ │ │ │ ├── HashAggregateExec.scala │ │ │ │ │ ├── HashMapGenerator.scala │ │ │ │ │ ├── MergingSessionsExec.scala │ │ │ │ │ ├── MergingSessionsIterator.scala │ │ │ │ │ ├── ObjectAggregationIterator.scala │ │ │ │ │ ├── ObjectAggregationMap.scala │ │ │ │ │ ├── ObjectHashAggregateExec.scala │ │ │ │ │ ├── RowBasedHashMapGenerator.scala │ │ │ │ │ ├── SortAggregateExec.scala │ │ │ │ │ ├── SortBasedAggregationIterator.scala │ │ │ │ │ ├── TungstenAggregationIterator.scala │ │ │ │ │ ├── TypedAggregateExpression.scala │ │ │ │ │ ├── UpdatingSessionsExec.scala │ │ │ │ │ ├── UpdatingSessionsIterator.scala │ │ │ │ │ ├── VectorizedHashMapGenerator.scala │ │ │ │ │ └── udaf.scala │ │ │ │ ├── analysis │ │ │ │ │ └── DetectAmbiguousSelfJoin.scala │ │ │ │ ├── arrow │ │ │ │ │ ├── ArrowConverters.scala │ │ │ │ │ └── ArrowFileReadWrite.scala │ │ │ │ ├── basicPhysicalOperators.scala │ │ │ │ ├── bucketing │ │ │ │ │ ├── CoalesceBucketsInJoin.scala │ │ │ │ │ └── DisableUnnecessaryBucketedScan.scala │ │ │ │ ├── columnar │ │ │ │ │ ├── ColumnAccessor.scala │ │ │ │ │ ├── ColumnBuilder.scala │ │ │ │ │ ├── ColumnStats.scala │ │ │ │ │ ├── ColumnType.scala │ │ │ │ │ ├── GenerateColumnAccessor.scala │ │ │ │ │ ├── InMemoryRelation.scala │ │ │ │ │ ├── InMemoryTableScanExec.scala │ │ │ │ │ ├── NullableColumnAccessor.scala │ │ │ │ │ ├── NullableColumnBuilder.scala │ │ │ │ │ └── compression │ │ │ │ │ │ ├── CompressibleColumnAccessor.scala │ │ │ │ │ │ ├── CompressibleColumnBuilder.scala │ │ │ │ │ │ ├── CompressionScheme.scala │ │ │ │ │ │ └── compressionSchemes.scala │ │ │ │ ├── command │ │ │ │ │ ├── AnalyzeColumnCommand.scala │ │ │ │ │ ├── AnalyzePartitionCommand.scala │ │ │ │ │ ├── AnalyzeTableCommand.scala │ │ │ │ │ ├── AnalyzeTablesCommand.scala │ │ │ │ │ ├── CommandCheck.scala │ │ │ │ │ ├── CommandUtils.scala │ │ │ │ │ ├── CreateSQLFunctionCommand.scala │ │ │ │ │ ├── CreateUserDefinedFunctionCommand.scala │ │ │ │ │ ├── DataWritingCommand.scala │ │ │ │ │ ├── DescribeProcedureCommand.scala │ │ │ │ │ ├── DescribeRelationJsonCommand.scala │ │ │ │ │ ├── InsertIntoDataSourceDirCommand.scala │ │ │ │ │ ├── SetCatalogCommand.scala │ │ │ │ │ ├── SetCommand.scala │ │ │ │ │ ├── SetNamespaceCollation.scala │ │ │ │ │ ├── SetNamespaceCommand.scala │ │ │ │ │ ├── ShowCatalogsCommand.scala │ │ │ │ │ ├── ShowCurrentNamespaceCommand.scala │ │ │ │ │ ├── ShowNamespacesCommand.scala │ │ │ │ │ ├── ShowProceduresCommand.scala │ │ │ │ │ ├── UnsetNamespacePropertiesCommand.scala │ │ │ │ │ ├── cache.scala │ │ │ │ │ ├── commands.scala │ │ │ │ │ ├── createDataSourceTables.scala │ │ │ │ │ ├── ddl.scala │ │ │ │ │ ├── functions.scala │ │ │ │ │ ├── resources.scala │ │ │ │ │ ├── tables.scala │ │ │ │ │ ├── v2 │ │ │ │ │ │ ├── CreateVariableExec.scala │ │ │ │ │ │ ├── DropVariableExec.scala │ │ │ │ │ │ ├── SetVariableExec.scala │ │ │ │ │ │ └── V2CommandStrategy.scala │ │ │ │ │ └── views.scala │ │ │ │ ├── datasources │ │ │ │ │ ├── AggregatePushDownUtils.scala │ │ │ │ │ ├── ApplyCharTypePadding.scala │ │ │ │ │ ├── BasicWriteStatsTracker.scala │ │ │ │ │ ├── BucketingUtils.scala │ │ │ │ │ ├── CatalogFileIndex.scala │ │ │ │ │ ├── CodecStreams.scala │ │ │ │ │ ├── DataSource.scala │ │ │ │ │ ├── DataSourceManager.scala │ │ │ │ │ ├── DataSourceMetricsMixin.scala │ │ │ │ │ ├── DataSourceResolver.scala │ │ │ │ │ ├── DataSourceStrategy.scala │ │ │ │ │ ├── DataSourceUtils.scala │ │ │ │ │ ├── DaysWritable.scala │ │ │ │ │ ├── ExternalEngineDatasourceRDD.scala │ │ │ │ │ ├── FallBackFileSourceV2.scala │ │ │ │ │ ├── FileFormat.scala │ │ │ │ │ ├── FileFormatDataWriter.scala │ │ │ │ │ ├── FileFormatWriter.scala │ │ │ │ │ ├── FileIndex.scala │ │ │ │ │ ├── FileIndexOptions.scala │ │ │ │ │ ├── FilePartition.scala │ │ │ │ │ ├── FileResolver.scala │ │ │ │ │ ├── FileScanRDD.scala │ │ │ │ │ ├── FileSourceStrategy.scala │ │ │ │ │ ├── FileStatusCache.scala │ │ │ │ │ ├── HadoopFileLinesReader.scala │ │ │ │ │ ├── HadoopFileWholeTextReader.scala │ │ │ │ │ ├── HadoopFsRelation.scala │ │ │ │ │ ├── InMemoryFileIndex.scala │ │ │ │ │ ├── InsertIntoDataSourceCommand.scala │ │ │ │ │ ├── InsertIntoHadoopFsRelationCommand.scala │ │ │ │ │ ├── LogicalRelation.scala │ │ │ │ │ ├── LogicalRelationResolver.scala │ │ │ │ │ ├── OutputWriter.scala │ │ │ │ │ ├── PartitioningAwareFileIndex.scala │ │ │ │ │ ├── PartitioningUtils.scala │ │ │ │ │ ├── PruneFileSourcePartitions.scala │ │ │ │ │ ├── PushVariantIntoScan.scala │ │ │ │ │ ├── RecordReaderIterator.scala │ │ │ │ │ ├── SQLHadoopMapReduceCommitProtocol.scala │ │ │ │ │ ├── SaveIntoDataSourceCommand.scala │ │ │ │ │ ├── SchemaMergeUtils.scala │ │ │ │ │ ├── SchemaPruning.scala │ │ │ │ │ ├── SourceOptions.scala │ │ │ │ │ ├── V1Writes.scala │ │ │ │ │ ├── WriteFiles.scala │ │ │ │ │ ├── WriteStatsTracker.scala │ │ │ │ │ ├── binaryfile │ │ │ │ │ │ └── BinaryFileFormat.scala │ │ │ │ │ ├── csv │ │ │ │ │ │ ├── CSVDataSource.scala │ │ │ │ │ │ ├── CSVFileFormat.scala │ │ │ │ │ │ ├── CSVUtils.scala │ │ │ │ │ │ └── CsvOutputWriter.scala │ │ │ │ │ ├── ddl.scala │ │ │ │ │ ├── jdbc │ │ │ │ │ │ ├── DriverRegistry.scala │ │ │ │ │ │ ├── DriverWrapper.scala │ │ │ │ │ │ ├── JDBCDatabaseMetadata.scala │ │ │ │ │ │ ├── JDBCOptions.scala │ │ │ │ │ │ ├── JDBCRDD.scala │ │ │ │ │ │ ├── JDBCRelation.scala │ │ │ │ │ │ ├── JdbcRelationProvider.scala │ │ │ │ │ │ ├── JdbcUtils.scala │ │ │ │ │ │ └── connection │ │ │ │ │ │ │ ├── BasicConnectionProvider.scala │ │ │ │ │ │ │ ├── ConnectionProvider.scala │ │ │ │ │ │ │ ├── DB2ConnectionProvider.scala │ │ │ │ │ │ │ ├── MSSQLConnectionProvider.scala │ │ │ │ │ │ │ ├── MariaDBConnectionProvider.scala │ │ │ │ │ │ │ ├── OracleConnectionProvider.scala │ │ │ │ │ │ │ ├── PostgresConnectionProvider.scala │ │ │ │ │ │ │ └── SecureConnectionProvider.scala │ │ │ │ │ ├── json │ │ │ │ │ │ ├── JsonDataSource.scala │ │ │ │ │ │ ├── JsonFileFormat.scala │ │ │ │ │ │ ├── JsonOutputWriter.scala │ │ │ │ │ │ └── JsonUtils.scala │ │ │ │ │ ├── noop │ │ │ │ │ │ └── NoopDataSource.scala │ │ │ │ │ ├── orc │ │ │ │ │ │ ├── OrcDeserializer.scala │ │ │ │ │ │ ├── OrcFileFormat.scala │ │ │ │ │ │ ├── OrcFilters.scala │ │ │ │ │ │ ├── OrcFiltersBase.scala │ │ │ │ │ │ ├── OrcOptions.scala │ │ │ │ │ │ ├── OrcOutputWriter.scala │ │ │ │ │ │ ├── OrcSerializer.scala │ │ │ │ │ │ ├── OrcShimUtils.scala │ │ │ │ │ │ └── OrcUtils.scala │ │ │ │ │ ├── parquet │ │ │ │ │ │ ├── InferVariantShreddingSchema.scala │ │ │ │ │ │ ├── ParquetColumn.scala │ │ │ │ │ │ ├── ParquetFileFormat.scala │ │ │ │ │ │ ├── ParquetFilters.scala │ │ │ │ │ │ ├── ParquetOptions.scala │ │ │ │ │ │ ├── ParquetOutputWriter.scala │ │ │ │ │ │ ├── ParquetOutputWriterWithVariantShredding.scala │ │ │ │ │ │ ├── ParquetReadSupport.scala │ │ │ │ │ │ ├── ParquetRecordMaterializer.scala │ │ │ │ │ │ ├── ParquetRowConverter.scala │ │ │ │ │ │ ├── ParquetRowIndexUtil.scala │ │ │ │ │ │ ├── ParquetSchemaConverter.scala │ │ │ │ │ │ ├── ParquetUtils.scala │ │ │ │ │ │ ├── ParquetWriteSupport.scala │ │ │ │ │ │ └── SparkShreddingUtils.scala │ │ │ │ │ ├── pathFilters.scala │ │ │ │ │ ├── rules.scala │ │ │ │ │ ├── text │ │ │ │ │ │ ├── TextFileFormat.scala │ │ │ │ │ │ ├── TextOptions.scala │ │ │ │ │ │ └── TextOutputWriter.scala │ │ │ │ │ ├── v2 │ │ │ │ │ │ ├── AddPartitionExec.scala │ │ │ │ │ │ ├── AlterNamespaceSetPropertiesExec.scala │ │ │ │ │ │ ├── AlterTableExec.scala │ │ │ │ │ │ ├── BatchScanExec.scala │ │ │ │ │ │ ├── CacheTableExec.scala │ │ │ │ │ │ ├── ContinuousScanExec.scala │ │ │ │ │ │ ├── CreateIndexExec.scala │ │ │ │ │ │ ├── CreateNamespaceExec.scala │ │ │ │ │ │ ├── CreateTableExec.scala │ │ │ │ │ │ ├── DataSourceRDD.scala │ │ │ │ │ │ ├── DataSourceV2ScanExecBase.scala │ │ │ │ │ │ ├── DataSourceV2Strategy.scala │ │ │ │ │ │ ├── DataSourceV2Utils.scala │ │ │ │ │ │ ├── DeleteFromTableExec.scala │ │ │ │ │ │ ├── DescribeColumnExec.scala │ │ │ │ │ │ ├── DescribeNamespaceExec.scala │ │ │ │ │ │ ├── DescribeTableExec.scala │ │ │ │ │ │ ├── DistributionAndOrderingUtils.scala │ │ │ │ │ │ ├── DropIndexExec.scala │ │ │ │ │ │ ├── DropNamespaceExec.scala │ │ │ │ │ │ ├── DropPartitionExec.scala │ │ │ │ │ │ ├── DropTableExec.scala │ │ │ │ │ │ ├── EmptyPartitionReader.scala │ │ │ │ │ │ ├── ExplainOnlySparkPlan.scala │ │ │ │ │ │ ├── FileBatchWrite.scala │ │ │ │ │ │ ├── FileDataSourceV2.scala │ │ │ │ │ │ ├── FilePartitionReader.scala │ │ │ │ │ │ ├── FilePartitionReaderFactory.scala │ │ │ │ │ │ ├── FileScan.scala │ │ │ │ │ │ ├── FileScanBuilder.scala │ │ │ │ │ │ ├── FileTable.scala │ │ │ │ │ │ ├── FileWrite.scala │ │ │ │ │ │ ├── FileWriterFactory.scala │ │ │ │ │ │ ├── GroupBasedRowLevelOperationScanPlanning.scala │ │ │ │ │ │ ├── MergeRowsExec.scala │ │ │ │ │ │ ├── MicroBatchScanExec.scala │ │ │ │ │ │ ├── OptimizeMetadataOnlyDeleteFromTable.scala │ │ │ │ │ │ ├── PartitionReaderFromIterator.scala │ │ │ │ │ │ ├── PartitionReaderWithPartitionValues.scala │ │ │ │ │ │ ├── PartitionRecordReader.scala │ │ │ │ │ │ ├── PushDownUtils.scala │ │ │ │ │ │ ├── PushedDownOperators.scala │ │ │ │ │ │ ├── RealTimeStreamScanExec.scala │ │ │ │ │ │ ├── RefreshTableExec.scala │ │ │ │ │ │ ├── RenamePartitionExec.scala │ │ │ │ │ │ ├── RenameTableExec.scala │ │ │ │ │ │ ├── ReplaceTableExec.scala │ │ │ │ │ │ ├── SetCatalogAndNamespaceExec.scala │ │ │ │ │ │ ├── ShowColumnsExec.scala │ │ │ │ │ │ ├── ShowCreateTableExec.scala │ │ │ │ │ │ ├── ShowFunctionsExec.scala │ │ │ │ │ │ ├── ShowPartitionsExec.scala │ │ │ │ │ │ ├── ShowTablePropertiesExec.scala │ │ │ │ │ │ ├── ShowTablesExec.scala │ │ │ │ │ │ ├── ShowTablesExtendedExec.scala │ │ │ │ │ │ ├── TableCapabilityCheck.scala │ │ │ │ │ │ ├── TableSampleInfo.scala │ │ │ │ │ │ ├── TextBasedFileScan.scala │ │ │ │ │ │ ├── TruncatePartitionExec.scala │ │ │ │ │ │ ├── TruncateTableExec.scala │ │ │ │ │ │ ├── V1FallbackWriters.scala │ │ │ │ │ │ ├── V2ColumnUtils.scala │ │ │ │ │ │ ├── V2CommandExec.scala │ │ │ │ │ │ ├── V2ScanPartitioningAndOrdering.scala │ │ │ │ │ │ ├── V2ScanRelationPushDown.scala │ │ │ │ │ │ ├── V2SessionCatalog.scala │ │ │ │ │ │ ├── V2TableRefreshUtil.scala │ │ │ │ │ │ ├── V2Writes.scala │ │ │ │ │ │ ├── WriteToDataSourceV2Exec.scala │ │ │ │ │ │ ├── csv │ │ │ │ │ │ │ ├── CSVDataSourceV2.scala │ │ │ │ │ │ │ ├── CSVPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── CSVScan.scala │ │ │ │ │ │ │ ├── CSVScanBuilder.scala │ │ │ │ │ │ │ ├── CSVTable.scala │ │ │ │ │ │ │ └── CSVWrite.scala │ │ │ │ │ │ ├── jdbc │ │ │ │ │ │ │ ├── JDBCScan.scala │ │ │ │ │ │ │ ├── JDBCScanBuilder.scala │ │ │ │ │ │ │ ├── JDBCTable.scala │ │ │ │ │ │ │ ├── JDBCTableCatalog.scala │ │ │ │ │ │ │ ├── JDBCV1RelationFromV2Scan.scala │ │ │ │ │ │ │ └── JDBCWriteBuilder.scala │ │ │ │ │ │ ├── json │ │ │ │ │ │ │ ├── JsonDataSourceV2.scala │ │ │ │ │ │ │ ├── JsonPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── JsonScan.scala │ │ │ │ │ │ │ ├── JsonScanBuilder.scala │ │ │ │ │ │ │ ├── JsonTable.scala │ │ │ │ │ │ │ └── JsonWrite.scala │ │ │ │ │ │ ├── orc │ │ │ │ │ │ │ ├── OrcDataSourceV2.scala │ │ │ │ │ │ │ ├── OrcPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── OrcScan.scala │ │ │ │ │ │ │ ├── OrcScanBuilder.scala │ │ │ │ │ │ │ ├── OrcTable.scala │ │ │ │ │ │ │ └── OrcWrite.scala │ │ │ │ │ │ ├── parquet │ │ │ │ │ │ │ ├── ParquetDataSourceV2.scala │ │ │ │ │ │ │ ├── ParquetPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── ParquetScan.scala │ │ │ │ │ │ │ ├── ParquetScanBuilder.scala │ │ │ │ │ │ │ ├── ParquetTable.scala │ │ │ │ │ │ │ └── ParquetWrite.scala │ │ │ │ │ │ ├── python │ │ │ │ │ │ │ ├── PythonBatchWriterFactory.scala │ │ │ │ │ │ │ ├── PythonCustomMetric.scala │ │ │ │ │ │ │ ├── PythonDataSourceV2.scala │ │ │ │ │ │ │ ├── PythonMicroBatchStream.scala │ │ │ │ │ │ │ ├── PythonPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── PythonScan.scala │ │ │ │ │ │ │ ├── PythonScanBuilder.scala │ │ │ │ │ │ │ ├── PythonStreamingPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── PythonStreamingSinkCommitRunner.scala │ │ │ │ │ │ │ ├── PythonStreamingWrite.scala │ │ │ │ │ │ │ ├── PythonTable.scala │ │ │ │ │ │ │ ├── PythonWrite.scala │ │ │ │ │ │ │ ├── PythonWriteBuilder.scala │ │ │ │ │ │ │ └── UserDefinedPythonDataSource.scala │ │ │ │ │ │ ├── state │ │ │ │ │ │ │ ├── StateDataSource.scala │ │ │ │ │ │ │ ├── StateDataSourceErrors.scala │ │ │ │ │ │ │ ├── StatePartitionReader.scala │ │ │ │ │ │ │ ├── StateScanBuilder.scala │ │ │ │ │ │ │ ├── StateTable.scala │ │ │ │ │ │ │ ├── StreamStreamJoinStateHelper.scala │ │ │ │ │ │ │ ├── StreamStreamJoinStatePartitionReader.scala │ │ │ │ │ │ │ ├── metadata │ │ │ │ │ │ │ │ └── StateMetadataSource.scala │ │ │ │ │ │ │ └── utils │ │ │ │ │ │ │ │ └── SchemaUtil.scala │ │ │ │ │ │ └── text │ │ │ │ │ │ │ ├── TextDataSourceV2.scala │ │ │ │ │ │ │ ├── TextPartitionReaderFactory.scala │ │ │ │ │ │ │ ├── TextScan.scala │ │ │ │ │ │ │ ├── TextScanBuilder.scala │ │ │ │ │ │ │ ├── TextTable.scala │ │ │ │ │ │ │ └── TextWrite.scala │ │ │ │ │ └── xml │ │ │ │ │ │ ├── XSDToSchema.scala │ │ │ │ │ │ ├── XmlDataSource.scala │ │ │ │ │ │ ├── XmlFileFormat.scala │ │ │ │ │ │ ├── XmlInputFormat.scala │ │ │ │ │ │ ├── XmlOutputWriter.scala │ │ │ │ │ │ └── XmlUtils.scala │ │ │ │ ├── debug │ │ │ │ │ ├── DebugEvaluatorFactory.scala │ │ │ │ │ └── package.scala │ │ │ │ ├── dynamicpruning │ │ │ │ │ ├── CleanupDynamicPruningFilters.scala │ │ │ │ │ ├── PartitionPruning.scala │ │ │ │ │ ├── PlanDynamicPruningFilters.scala │ │ │ │ │ └── RowLevelOperationRuntimeGroupFiltering.scala │ │ │ │ ├── exchange │ │ │ │ │ ├── BroadcastExchangeExec.scala │ │ │ │ │ ├── EnsureRequirements.scala │ │ │ │ │ ├── Exchange.scala │ │ │ │ │ ├── ShuffleExchangeExec.scala │ │ │ │ │ └── ValidateRequirements.scala │ │ │ │ ├── history │ │ │ │ │ └── SQLEventFilterBuilder.scala │ │ │ │ ├── joins │ │ │ │ │ ├── BaseJoinExec.scala │ │ │ │ │ ├── BroadcastHashJoinExec.scala │ │ │ │ │ ├── BroadcastNestedLoopJoinExec.scala │ │ │ │ │ ├── CartesianProductExec.scala │ │ │ │ │ ├── HashJoin.scala │ │ │ │ │ ├── HashedRelation.scala │ │ │ │ │ ├── JoinCodegenSupport.scala │ │ │ │ │ ├── ShuffledHashJoinExec.scala │ │ │ │ │ ├── ShuffledJoin.scala │ │ │ │ │ ├── SortMergeJoinEvaluatorFactory.scala │ │ │ │ │ ├── SortMergeJoinExec.scala │ │ │ │ │ └── StoragePartitionJoinParams.scala │ │ │ │ ├── limit.scala │ │ │ │ ├── metric │ │ │ │ │ ├── CustomMetrics.scala │ │ │ │ │ ├── SQLMetricInfo.scala │ │ │ │ │ ├── SQLMetrics.scala │ │ │ │ │ └── SQLShuffleMetricsReporter.scala │ │ │ │ ├── objects.scala │ │ │ │ ├── package.scala │ │ │ │ ├── python │ │ │ │ │ ├── ArrowAggregatePythonExec.scala │ │ │ │ │ ├── ArrowEvalPythonExec.scala │ │ │ │ │ ├── ArrowEvalPythonUDTFExec.scala │ │ │ │ │ ├── ArrowPythonRunner.scala │ │ │ │ │ ├── ArrowPythonUDTFRunner.scala │ │ │ │ │ ├── ArrowWindowPythonEvaluatorFactory.scala │ │ │ │ │ ├── ArrowWindowPythonExec.scala │ │ │ │ │ ├── AttachDistributedSequenceExec.scala │ │ │ │ │ ├── BatchEvalPythonExec.scala │ │ │ │ │ ├── BatchEvalPythonUDTFExec.scala │ │ │ │ │ ├── CoGroupedArrowPythonRunner.scala │ │ │ │ │ ├── EvalPythonEvaluatorFactory.scala │ │ │ │ │ ├── EvalPythonExec.scala │ │ │ │ │ ├── EvalPythonUDTFExec.scala │ │ │ │ │ ├── EvaluatePython.scala │ │ │ │ │ ├── ExtractPythonUDFs.scala │ │ │ │ │ ├── FlatMapCoGroupsInArrowExec.scala │ │ │ │ │ ├── FlatMapCoGroupsInBatchExec.scala │ │ │ │ │ ├── FlatMapCoGroupsInPandasExec.scala │ │ │ │ │ ├── FlatMapGroupsInArrowExec.scala │ │ │ │ │ ├── FlatMapGroupsInBatchExec.scala │ │ │ │ │ ├── FlatMapGroupsInPandasExec.scala │ │ │ │ │ ├── HybridQueue.scala │ │ │ │ │ ├── MapInArrowExec.scala │ │ │ │ │ ├── MapInBatchEvaluatorFactory.scala │ │ │ │ │ ├── MapInBatchExec.scala │ │ │ │ │ ├── MapInPandasExec.scala │ │ │ │ │ ├── PandasGroupUtils.scala │ │ │ │ │ ├── PythonArrowInput.scala │ │ │ │ │ ├── PythonArrowOutput.scala │ │ │ │ │ ├── PythonPlannerRunner.scala │ │ │ │ │ ├── PythonSQLMetrics.scala │ │ │ │ │ ├── PythonUDFRunner.scala │ │ │ │ │ ├── PythonWorkerLogsExec.scala │ │ │ │ │ ├── RowQueue.scala │ │ │ │ │ ├── UserDefinedPythonFunction.scala │ │ │ │ │ └── streaming │ │ │ │ │ │ ├── ApplyInPandasWithStatePythonRunner.scala │ │ │ │ │ │ ├── ApplyInPandasWithStateWriter.scala │ │ │ │ │ │ ├── BaseStreamingArrowWriter.scala │ │ │ │ │ │ ├── FlatMapGroupsInPandasWithStateExec.scala │ │ │ │ │ │ ├── PythonForeachWriter.scala │ │ │ │ │ │ ├── PythonStreamingSourceRunner.scala │ │ │ │ │ │ ├── TransformWithStateInPySparkDeserializer.scala │ │ │ │ │ │ ├── TransformWithStateInPySparkExec.scala │ │ │ │ │ │ ├── TransformWithStateInPySparkPythonRunner.scala │ │ │ │ │ │ ├── TransformWithStateInPySparkStateServer.scala │ │ │ │ │ │ └── benchmark │ │ │ │ │ │ └── BenchmarkTransformWithStateInPySparkStateServer.scala │ │ │ │ ├── r │ │ │ │ │ ├── ArrowRRunner.scala │ │ │ │ │ └── MapPartitionsRWrapper.scala │ │ │ │ ├── reuse │ │ │ │ │ └── ReuseExchangeAndSubquery.scala │ │ │ │ ├── stat │ │ │ │ │ ├── FrequentItems.scala │ │ │ │ │ └── StatFunctions.scala │ │ │ │ ├── streaming │ │ │ │ │ ├── ManifestFileCommitProtocol.scala │ │ │ │ │ ├── Sink.scala │ │ │ │ │ ├── Source.scala │ │ │ │ │ ├── StreamingErrors.scala │ │ │ │ │ ├── StreamingQueryPlanTraverseHelper.scala │ │ │ │ │ ├── checkpointing │ │ │ │ │ │ ├── AsyncCommitLog.scala │ │ │ │ │ │ ├── AsyncOffsetSeqLog.scala │ │ │ │ │ │ ├── CheckpointFileManager.scala │ │ │ │ │ │ ├── ChecksumCheckpointFileManager.scala │ │ │ │ │ │ ├── CommitLog.scala │ │ │ │ │ │ ├── HDFSMetadataLog.scala │ │ │ │ │ │ ├── MetadataLog.scala │ │ │ │ │ │ ├── MetadataVersionUtil.scala │ │ │ │ │ │ ├── OffsetSeq.scala │ │ │ │ │ │ └── OffsetSeqLog.scala │ │ │ │ │ ├── console.scala │ │ │ │ │ ├── continuous │ │ │ │ │ │ ├── ContinuousDataSourceRDD.scala │ │ │ │ │ │ ├── ContinuousExecution.scala │ │ │ │ │ │ ├── ContinuousQueuedDataReader.scala │ │ │ │ │ │ ├── ContinuousRateStreamSource.scala │ │ │ │ │ │ ├── ContinuousTaskRetryException.scala │ │ │ │ │ │ ├── ContinuousTextSocketSource.scala │ │ │ │ │ │ ├── ContinuousWriteRDD.scala │ │ │ │ │ │ ├── EpochCoordinator.scala │ │ │ │ │ │ ├── EpochTracker.scala │ │ │ │ │ │ ├── WriteToContinuousDataSource.scala │ │ │ │ │ │ └── WriteToContinuousDataSourceExec.scala │ │ │ │ │ ├── legacy.scala │ │ │ │ │ ├── operators │ │ │ │ │ │ └── stateful │ │ │ │ │ │ │ ├── EventTimeWatermarkExec.scala │ │ │ │ │ │ │ ├── MergingSortWithSessionWindowStateIterator.scala │ │ │ │ │ │ │ ├── StatefulOperatorPartitioning.scala │ │ │ │ │ │ │ ├── StreamingAggregationStateManager.scala │ │ │ │ │ │ │ ├── StreamingSessionWindowStateManager.scala │ │ │ │ │ │ │ ├── flatmapgroupswithstate │ │ │ │ │ │ │ ├── FlatMapGroupsWithStateExec.scala │ │ │ │ │ │ │ ├── FlatMapGroupsWithStateExecHelper.scala │ │ │ │ │ │ │ └── GroupStateImpl.scala │ │ │ │ │ │ │ ├── join │ │ │ │ │ │ │ ├── StreamingSymmetricHashJoinExec.scala │ │ │ │ │ │ │ ├── StreamingSymmetricHashJoinHelper.scala │ │ │ │ │ │ │ └── SymmetricHashJoinStateManager.scala │ │ │ │ │ │ │ ├── statefulOperators.scala │ │ │ │ │ │ │ ├── streamingLimits.scala │ │ │ │ │ │ │ └── transformwithstate │ │ │ │ │ │ │ ├── StateStoreColumnFamilySchemaUtils.scala │ │ │ │ │ │ │ ├── StateTypesEncoderUtils.scala │ │ │ │ │ │ │ ├── TransformWithStateExec.scala │ │ │ │ │ │ │ ├── TransformWithStateExecBase.scala │ │ │ │ │ │ │ ├── TransformWithStateVariableUtils.scala │ │ │ │ │ │ │ ├── statefulprocessor │ │ │ │ │ │ │ ├── StatefulProcessorHandleImpl.scala │ │ │ │ │ │ │ └── StatefulProcessorHandleImplBase.scala │ │ │ │ │ │ │ ├── statevariables │ │ │ │ │ │ │ ├── ListStateImpl.scala │ │ │ │ │ │ │ ├── ListStateMetricsImpl.scala │ │ │ │ │ │ │ ├── MapStateImpl.scala │ │ │ │ │ │ │ └── ValueStateImpl.scala │ │ │ │ │ │ │ ├── timers │ │ │ │ │ │ │ ├── ExpiredTimerInfoImpl.scala │ │ │ │ │ │ │ ├── TimerStateImpl.scala │ │ │ │ │ │ │ └── TimerValuesImpl.scala │ │ │ │ │ │ │ └── ttl │ │ │ │ │ │ │ ├── ListStateImplWithTTL.scala │ │ │ │ │ │ │ ├── MapStateImplWithTTL.scala │ │ │ │ │ │ │ ├── TTLState.scala │ │ │ │ │ │ │ └── ValueStateImplWithTTL.scala │ │ │ │ │ ├── runtime │ │ │ │ │ │ ├── AcceptsLatestSeenOffsetHandler.scala │ │ │ │ │ │ ├── AsyncLogPurge.scala │ │ │ │ │ │ ├── AsyncProgressTrackingMicroBatchExecution.scala │ │ │ │ │ │ ├── AsyncStreamingQueryCheckpointMetadata.scala │ │ │ │ │ │ ├── AvailableNowDataStreamWrapper.scala │ │ │ │ │ │ ├── AvailableNowMicroBatchStreamWrapper.scala │ │ │ │ │ │ ├── AvailableNowSourceWrapper.scala │ │ │ │ │ │ ├── CompactibleFileStreamLog.scala │ │ │ │ │ │ ├── ContinuousRecordEndpoint.scala │ │ │ │ │ │ ├── ErrorNotifier.scala │ │ │ │ │ │ ├── FileStreamOptions.scala │ │ │ │ │ │ ├── FileStreamSource.scala │ │ │ │ │ │ ├── FileStreamSourceLog.scala │ │ │ │ │ │ ├── FileStreamSourceOffset.scala │ │ │ │ │ │ ├── IncrementalExecution.scala │ │ │ │ │ │ ├── LongOffset.scala │ │ │ │ │ │ ├── MetadataLogFileIndex.scala │ │ │ │ │ │ ├── MetricsReporter.scala │ │ │ │ │ │ ├── MicroBatchExecution.scala │ │ │ │ │ │ ├── ProgressReporter.scala │ │ │ │ │ │ ├── RateStreamOffset.scala │ │ │ │ │ │ ├── RealTimeModeAllowlist.scala │ │ │ │ │ │ ├── ResolveWriteToStream.scala │ │ │ │ │ │ ├── SerializedOffset.scala │ │ │ │ │ │ ├── StreamExecution.scala │ │ │ │ │ │ ├── StreamExecutionContext.scala │ │ │ │ │ │ ├── StreamMetadata.scala │ │ │ │ │ │ ├── StreamProgress.scala │ │ │ │ │ │ ├── StreamingCheckpointConstants.scala │ │ │ │ │ │ ├── StreamingQueryCheckpointMetadata.scala │ │ │ │ │ │ ├── StreamingQueryListenerBus.scala │ │ │ │ │ │ ├── StreamingQueryWrapper.scala │ │ │ │ │ │ ├── StreamingRelation.scala │ │ │ │ │ │ ├── TriggerExecutor.scala │ │ │ │ │ │ ├── WatermarkPropagator.scala │ │ │ │ │ │ ├── WatermarkTracker.scala │ │ │ │ │ │ └── memory.scala │ │ │ │ │ ├── sinks │ │ │ │ │ │ ├── FileStreamSink.scala │ │ │ │ │ │ └── FileStreamSinkLog.scala │ │ │ │ │ ├── sources │ │ │ │ │ │ ├── ConsoleStreamingWrite.scala │ │ │ │ │ │ ├── ContinuousMemory.scala │ │ │ │ │ │ ├── ContinuousMemoryStream.scala │ │ │ │ │ │ ├── ForeachBatchSink.scala │ │ │ │ │ │ ├── ForeachWriterTable.scala │ │ │ │ │ │ ├── LowLatencyMemoryStream.scala │ │ │ │ │ │ ├── MicroBatchWrite.scala │ │ │ │ │ │ ├── PackedRowWriterFactory.scala │ │ │ │ │ │ ├── RatePerMicroBatchProvider.scala │ │ │ │ │ │ ├── RatePerMicroBatchStream.scala │ │ │ │ │ │ ├── RateStreamMicroBatchStream.scala │ │ │ │ │ │ ├── RateStreamProvider.scala │ │ │ │ │ │ ├── RealTimeRowWriterFactory.scala │ │ │ │ │ │ ├── TextSocketMicroBatchStream.scala │ │ │ │ │ │ ├── TextSocketSourceProvider.scala │ │ │ │ │ │ ├── WriteToMicroBatchDataSource.scala │ │ │ │ │ │ ├── WriteToMicroBatchDataSourceV1.scala │ │ │ │ │ │ └── memory.scala │ │ │ │ │ ├── state │ │ │ │ │ │ ├── AutoSnapshotLoader.scala │ │ │ │ │ │ ├── HDFSBackedStateStoreMap.scala │ │ │ │ │ │ ├── HDFSBackedStateStoreProvider.scala │ │ │ │ │ │ ├── OfflineStateRepartitionErrors.scala │ │ │ │ │ │ ├── OfflineStateRepartitionRunner.scala │ │ │ │ │ │ ├── OperatorStateMetadata.scala │ │ │ │ │ │ ├── RocksDB.scala │ │ │ │ │ │ ├── RocksDBFileManager.scala │ │ │ │ │ │ ├── RocksDBLoader.scala │ │ │ │ │ │ ├── RocksDBMemoryManager.scala │ │ │ │ │ │ ├── RocksDBStateEncoder.scala │ │ │ │ │ │ ├── RocksDBStateMachine.scala │ │ │ │ │ │ ├── RocksDBStateStoreProvider.scala │ │ │ │ │ │ ├── SchemaHelper.scala │ │ │ │ │ │ ├── StateSchemaCompatibilityChecker.scala │ │ │ │ │ │ ├── StateStore.scala │ │ │ │ │ │ ├── StateStoreChangelog.scala │ │ │ │ │ │ ├── StateStoreConf.scala │ │ │ │ │ │ ├── StateStoreCoordinator.scala │ │ │ │ │ │ ├── StateStoreErrors.scala │ │ │ │ │ │ ├── StateStoreRDD.scala │ │ │ │ │ │ ├── StateStoreRow.scala │ │ │ │ │ │ ├── StateStoreRowChecksum.scala │ │ │ │ │ │ └── package.scala │ │ │ │ │ └── utils │ │ │ │ │ │ └── StreamingUtils.scala │ │ │ │ ├── subquery.scala │ │ │ │ ├── ui │ │ │ │ │ ├── AllExecutionsPage.scala │ │ │ │ │ ├── ExecutionPage.scala │ │ │ │ │ ├── SQLAppStatusListener.scala │ │ │ │ │ ├── SQLAppStatusStore.scala │ │ │ │ │ ├── SQLHistoryServerPlugin.scala │ │ │ │ │ ├── SQLListener.scala │ │ │ │ │ ├── SQLTab.scala │ │ │ │ │ ├── SparkPlanGraph.scala │ │ │ │ │ ├── StreamingQueryHistoryServerPlugin.scala │ │ │ │ │ └── StreamingQueryStatusStore.scala │ │ │ │ └── window │ │ │ │ │ ├── AggregateProcessor.scala │ │ │ │ │ ├── BoundOrdering.scala │ │ │ │ │ ├── WindowEvaluatorFactory.scala │ │ │ │ │ ├── WindowEvaluatorFactoryBase.scala │ │ │ │ │ ├── WindowExec.scala │ │ │ │ │ ├── WindowExecBase.scala │ │ │ │ │ ├── WindowFunctionFrame.scala │ │ │ │ │ ├── WindowGroupLimitEvaluatorFactory.scala │ │ │ │ │ └── WindowGroupLimitExec.scala │ │ │ ├── internal │ │ │ │ ├── BaseSessionStateBuilder.scala │ │ │ │ ├── HiveSerDe.scala │ │ │ │ ├── SessionState.scala │ │ │ │ ├── SessionStateHelper.scala │ │ │ │ ├── SharedState.scala │ │ │ │ ├── VariableSubstitution.scala │ │ │ │ ├── package-info.java │ │ │ │ └── package.scala │ │ │ ├── jdbc │ │ │ │ ├── AggregatedDialect.scala │ │ │ │ ├── DB2Dialect.scala │ │ │ │ ├── DatabricksDialect.scala │ │ │ │ ├── DerbyDialect.scala │ │ │ │ ├── H2Dialect.scala │ │ │ │ ├── JdbcConnectionProvider.scala │ │ │ │ ├── JdbcDialects.scala │ │ │ │ ├── JdbcSQLQueryBuilder.scala │ │ │ │ ├── MsSqlServerDialect.scala │ │ │ │ ├── MySQLDialect.scala │ │ │ │ ├── OracleDialect.scala │ │ │ │ ├── PostgresDialect.scala │ │ │ │ ├── README.md │ │ │ │ ├── SnowflakeDialect.scala │ │ │ │ └── TeradataDialect.scala │ │ │ ├── scripting │ │ │ │ ├── SqlScriptingContextManagerImpl.scala │ │ │ │ ├── SqlScriptingExecution.scala │ │ │ │ ├── SqlScriptingExecutionContext.scala │ │ │ │ ├── SqlScriptingExecutionNode.scala │ │ │ │ ├── SqlScriptingInterpreter.scala │ │ │ │ └── SqlScriptingLocalVariableManager.scala │ │ │ ├── sources │ │ │ │ ├── interfaces.scala │ │ │ │ └── package.scala │ │ │ ├── streaming │ │ │ │ ├── TestGroupState.scala │ │ │ │ └── ui │ │ │ │ │ ├── StreamingQueryPage.scala │ │ │ │ │ ├── StreamingQueryStatisticsPage.scala │ │ │ │ │ ├── StreamingQueryStatusListener.scala │ │ │ │ │ ├── StreamingQueryTab.scala │ │ │ │ │ └── UIUtils.scala │ │ │ ├── test │ │ │ │ ├── ExamplePointUDT.scala │ │ │ │ └── README.md │ │ │ └── util │ │ │ │ ├── MapperRowCounter.scala │ │ │ │ └── QueryExecutionListener.scala │ │ │ └── status │ │ │ ├── api │ │ │ └── v1 │ │ │ │ └── sql │ │ │ │ ├── ApiSqlRootResource.scala │ │ │ │ ├── SqlResource.scala │ │ │ │ └── api.scala │ │ │ └── protobuf │ │ │ └── sql │ │ │ ├── SQLExecutionUIDataSerializer.scala │ │ │ ├── SQLPlanMetricSerializer.scala │ │ │ ├── SinkProgressSerializer.scala │ │ │ ├── SourceProgressSerializer.scala │ │ │ ├── SparkPlanGraphWrapperSerializer.scala │ │ │ ├── StateOperatorProgressSerializer.scala │ │ │ ├── StreamingQueryDataSerializer.scala │ │ │ ├── StreamingQueryProgressSerializer.scala │ │ │ └── StreamingQueryProgressWrapperSerializer.scala │ │ └── test │ │ ├── README.md │ │ ├── avro │ │ ├── parquet-compat.avdl │ │ └── parquet-compat.avpr │ │ ├── gen-java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── execution │ │ │ └── datasources │ │ │ └── parquet │ │ │ └── test │ │ │ └── avro │ │ │ ├── AvroArrayOfArray.java │ │ │ ├── AvroMapOfArray.java │ │ │ ├── AvroNonNullableArrays.java │ │ │ ├── AvroOptionalPrimitives.java │ │ │ ├── AvroPrimitives.java │ │ │ ├── CompatibilityTest.java │ │ │ ├── Nested.java │ │ │ ├── ParquetAvroCompat.java │ │ │ ├── ParquetEnum.java │ │ │ └── Suit.java │ │ ├── java │ │ ├── org │ │ │ └── apache │ │ │ │ └── spark │ │ │ │ └── sql │ │ │ │ ├── api │ │ │ │ └── java │ │ │ │ │ └── UDF23Test.java │ │ │ │ ├── execution │ │ │ │ └── streaming │ │ │ │ │ └── state │ │ │ │ │ └── POJOTestClass.java │ │ │ │ └── types │ │ │ │ ├── GeographyClientSuite.java │ │ │ │ └── GeometryClientSuite.java │ │ └── test │ │ │ └── org │ │ │ └── apache │ │ │ ├── parquet │ │ │ └── column │ │ │ │ └── page │ │ │ │ └── TestDataPage.java │ │ │ └── spark │ │ │ └── sql │ │ │ ├── Java8DatasetAggregatorSuite.java │ │ │ ├── JavaApplySchemaSuite.java │ │ │ ├── JavaBeanDeserializationSuite.java │ │ │ ├── JavaColumnExpressionSuite.java │ │ │ ├── JavaDataFrameReaderWriterSuite.java │ │ │ ├── JavaDataFrameSuite.java │ │ │ ├── JavaDataFrameWriterV2Suite.java │ │ │ ├── JavaDatasetAggregatorSuite.java │ │ │ ├── JavaDatasetAggregatorSuiteBase.java │ │ │ ├── JavaDatasetSuite.java │ │ │ ├── JavaHigherOrderFunctionsSuite.java │ │ │ ├── JavaRowSuite.java │ │ │ ├── JavaSaveLoadSuite.java │ │ │ ├── JavaSparkSessionSuite.java │ │ │ ├── JavaStringLength.java │ │ │ ├── JavaUDAFSuite.java │ │ │ ├── JavaUDFSuite.java │ │ │ ├── MyDoubleAvg.java │ │ │ ├── MyDoubleSum.java │ │ │ ├── TestStatefulProcessor.java │ │ │ ├── TestStatefulProcessorWithInitialState.java │ │ │ ├── connector │ │ │ ├── JavaAdvancedDataSourceV2.java │ │ │ ├── JavaAdvancedDataSourceV2WithV2Filter.java │ │ │ ├── JavaColumnarDataSourceV2.java │ │ │ ├── JavaOrderAndPartitionAwareDataSource.java │ │ │ ├── JavaPartitionAwareDataSource.java │ │ │ ├── JavaRangeInputPartition.java │ │ │ ├── JavaReportStatisticsDataSource.java │ │ │ ├── JavaSchemaRequiredDataSource.java │ │ │ ├── JavaSimpleBatchTable.java │ │ │ ├── JavaSimpleDataSourceV2.java │ │ │ ├── JavaSimpleReaderFactory.java │ │ │ ├── JavaSimpleScanBuilder.java │ │ │ ├── JavaSimpleWritableDataSource.java │ │ │ └── catalog │ │ │ │ └── functions │ │ │ │ ├── JavaAverage.java │ │ │ │ ├── JavaLongAdd.java │ │ │ │ ├── JavaRandomAdd.java │ │ │ │ └── JavaStrLen.java │ │ │ ├── execution │ │ │ ├── datasources │ │ │ │ ├── orc │ │ │ │ │ └── FakeKeyProvider.java │ │ │ │ └── xml │ │ │ │ │ └── JavaXmlSuite.java │ │ │ └── sort │ │ │ │ └── RecordBinaryComparatorSuite.java │ │ │ └── streaming │ │ │ └── JavaDataStreamReaderWriterSuite.java │ │ ├── resources │ │ ├── META-INF │ │ │ └── services │ │ │ │ ├── org.apache.hadoop.crypto.key.KeyProviderFactory │ │ │ │ ├── org.apache.spark.sql.SparkSessionExtensionsProvider │ │ │ │ ├── org.apache.spark.sql.jdbc.JdbcConnectionProvider │ │ │ │ ├── org.apache.spark.sql.jdbc.JdbcDialect │ │ │ │ └── org.apache.spark.sql.sources.DataSourceRegister │ │ ├── SPARK-33084.jar │ │ ├── artifact-tests │ │ │ ├── Hello.class │ │ │ ├── HelloWithPackage.class │ │ │ ├── HelloWithPackage.java │ │ │ ├── IntSumUdf.class │ │ │ ├── IntSumUdf.scala │ │ │ ├── smallClassFile.class │ │ │ └── udf_noA.jar │ │ ├── collations │ │ │ └── ICU-collations-map.md │ │ ├── hive-site.xml │ │ ├── log4j2.properties │ │ ├── sample.json │ │ ├── spark-events │ │ │ └── local-1596020211915 │ │ ├── sql-functions │ │ │ └── sql-expression-schema.md │ │ ├── sql-tests │ │ │ ├── analyzer-results │ │ │ │ ├── alias-resolution-edge-cases.sql.out │ │ │ │ ├── array.sql.out │ │ │ │ ├── binary.sql.out │ │ │ │ ├── binary_base64.sql.out │ │ │ │ ├── binary_basic.sql.out │ │ │ │ ├── binary_hex.sql.out │ │ │ │ ├── binary_hex_discrete.sql.out │ │ │ │ ├── bitwise.sql.out │ │ │ │ ├── cast.sql.out │ │ │ │ ├── ceil-floor-with-scale-param.sql.out │ │ │ │ ├── change-column.sql.out │ │ │ │ ├── charvarchar.sql.out │ │ │ │ ├── collations-aliases.sql.out │ │ │ │ ├── collations-basic.sql.out │ │ │ │ ├── collations-padding-trim.sql.out │ │ │ │ ├── collations-string-functions.sql.out │ │ │ │ ├── column-resolution-aggregate.sql.out │ │ │ │ ├── column-resolution-sort.sql.out │ │ │ │ ├── columnresolution-negative.sql.out │ │ │ │ ├── columnresolution-views.sql.out │ │ │ │ ├── columnresolution.sql.out │ │ │ │ ├── comments.sql.out │ │ │ │ ├── comparator.sql.out │ │ │ │ ├── conditional-functions.sql.out │ │ │ │ ├── count.sql.out │ │ │ │ ├── cross-join.sql.out │ │ │ │ ├── csv-functions.sql.out │ │ │ │ ├── cte-command.sql.out │ │ │ │ ├── cte-legacy.sql.out │ │ │ │ ├── cte-nested.sql.out │ │ │ │ ├── cte-nonlegacy.sql.out │ │ │ │ ├── cte-recursion.sql.out │ │ │ │ ├── cte.sql.out │ │ │ │ ├── current_database_catalog.sql.out │ │ │ │ ├── date.sql.out │ │ │ │ ├── datetime-formatting-invalid.sql.out │ │ │ │ ├── datetime-formatting-legacy.sql.out │ │ │ │ ├── datetime-formatting.sql.out │ │ │ │ ├── datetime-legacy.sql.out │ │ │ │ ├── datetime-parsing-invalid.sql.out │ │ │ │ ├── datetime-parsing-legacy.sql.out │ │ │ │ ├── datetime-parsing.sql.out │ │ │ │ ├── datetime-special.sql.out │ │ │ │ ├── decimalArithmeticOperations.sql.out │ │ │ │ ├── describe-part-after-analyze.sql.out │ │ │ │ ├── describe-query.sql.out │ │ │ │ ├── describe-table-after-alter-table.sql.out │ │ │ │ ├── describe.sql.out │ │ │ │ ├── double-quoted-identifiers-enabled.sql.out │ │ │ │ ├── double-quoted-identifiers.sql.out │ │ │ │ ├── except-all.sql.out │ │ │ │ ├── except.sql.out │ │ │ │ ├── execute-immediate.sql.out │ │ │ │ ├── explain-aqe.sql.out │ │ │ │ ├── explain-cbo.sql.out │ │ │ │ ├── explain.sql.out │ │ │ │ ├── extract-value-resolution-edge-cases.sql.out │ │ │ │ ├── extract.sql.out │ │ │ │ ├── generators.sql.out │ │ │ │ ├── group-analytics.sql.out │ │ │ │ ├── group-by-alias.sql.out │ │ │ │ ├── group-by-all-duckdb.sql.out │ │ │ │ ├── group-by-all-mosha.sql.out │ │ │ │ ├── group-by-all.sql.out │ │ │ │ ├── group-by-filter.sql.out │ │ │ │ ├── group-by-ordinal.sql.out │ │ │ │ ├── group-by.sql.out │ │ │ │ ├── grouping_set.sql.out │ │ │ │ ├── having-and-order-by-recursive-type-name-resolution.sql.out │ │ │ │ ├── having.sql.out │ │ │ │ ├── higher-order-functions.sql.out │ │ │ │ ├── hll.sql.out │ │ │ │ ├── identifier-clause-legacy.sql.out │ │ │ │ ├── identifier-clause.sql.out │ │ │ │ ├── ilike-all.sql.out │ │ │ │ ├── ilike-any.sql.out │ │ │ │ ├── ilike.sql.out │ │ │ │ ├── inline-table.sql.out │ │ │ │ ├── inner-join.sql.out │ │ │ │ ├── intersect-all.sql.out │ │ │ │ ├── interval.sql.out │ │ │ │ ├── join-empty-relation.sql.out │ │ │ │ ├── join-lateral.sql.out │ │ │ │ ├── join-resolution-edge-cases.sql.out │ │ │ │ ├── json-functions.sql.out │ │ │ │ ├── keywords-enforced.sql.out │ │ │ │ ├── keywords.sql.out │ │ │ │ ├── kllquantiles.sql.out │ │ │ │ ├── like-all.sql.out │ │ │ │ ├── like-any.sql.out │ │ │ │ ├── limit.sql.out │ │ │ │ ├── linear-regression.sql.out │ │ │ │ ├── listagg-collations.sql.out │ │ │ │ ├── listagg.sql.out │ │ │ │ ├── literals.sql.out │ │ │ │ ├── map.sql.out │ │ │ │ ├── mask-functions.sql.out │ │ │ │ ├── math.sql.out │ │ │ │ ├── misc-functions.sql.out │ │ │ │ ├── mode.sql.out │ │ │ │ ├── name-precedence-in-order-by-and-having-with-conflicting-attributes.sql.out │ │ │ │ ├── named-function-arguments.sql.out │ │ │ │ ├── natural-join.sql.out │ │ │ │ ├── non-excludable-rule.sql.out │ │ │ │ ├── nonansi │ │ │ │ │ ├── array.sql.out │ │ │ │ │ ├── cast.sql.out │ │ │ │ │ ├── conditional-functions.sql.out │ │ │ │ │ ├── date.sql.out │ │ │ │ │ ├── datetime-parsing-invalid.sql.out │ │ │ │ │ ├── datetime-special.sql.out │ │ │ │ │ ├── decimalArithmeticOperations.sql.out │ │ │ │ │ ├── double-quoted-identifiers.sql.out │ │ │ │ │ ├── higher-order-functions.sql.out │ │ │ │ │ ├── interval.sql.out │ │ │ │ │ ├── keywords.sql.out │ │ │ │ │ ├── literals.sql.out │ │ │ │ │ ├── map.sql.out │ │ │ │ │ ├── math.sql.out │ │ │ │ │ ├── parse-schema-string.sql.out │ │ │ │ │ ├── st-functions.sql.out │ │ │ │ │ ├── string-functions.sql.out │ │ │ │ │ ├── timestamp.sql.out │ │ │ │ │ ├── try_aggregates.sql.out │ │ │ │ │ ├── try_arithmetic.sql.out │ │ │ │ │ ├── try_datetime_functions.sql.out │ │ │ │ │ └── try_element_at.sql.out │ │ │ │ ├── null-handling.sql.out │ │ │ │ ├── null-propagation.sql.out │ │ │ │ ├── operators.sql.out │ │ │ │ ├── order-by-alias.sql.out │ │ │ │ ├── order-by-all.sql.out │ │ │ │ ├── order-by-and-having-on-top-of-aggregate-with-join.sql.out │ │ │ │ ├── order-by-nulls-ordering.sql.out │ │ │ │ ├── order-by-ordinal.sql.out │ │ │ │ ├── order-by.sql.out │ │ │ │ ├── outer-join.sql.out │ │ │ │ ├── parse-query-correctness-old-behavior.sql.out │ │ │ │ ├── parse-query-correctness.sql.out │ │ │ │ ├── parse-schema-string.sql.out │ │ │ │ ├── percentiles.sql.out │ │ │ │ ├── pipe-operators.sql.out │ │ │ │ ├── pivot.sql.out │ │ │ │ ├── postgreSQL │ │ │ │ │ ├── aggregates_part1.sql.out │ │ │ │ │ ├── aggregates_part2.sql.out │ │ │ │ │ ├── aggregates_part3.sql.out │ │ │ │ │ ├── aggregates_part4.sql.out │ │ │ │ │ ├── boolean.sql.out │ │ │ │ │ ├── case.sql.out │ │ │ │ │ ├── comments.sql.out │ │ │ │ │ ├── create_view.sql.out │ │ │ │ │ ├── date.sql.out │ │ │ │ │ ├── float4.sql.out │ │ │ │ │ ├── float8.sql.out │ │ │ │ │ ├── groupingsets.sql.out │ │ │ │ │ ├── insert.sql.out │ │ │ │ │ ├── int2.sql.out │ │ │ │ │ ├── int4.sql.out │ │ │ │ │ ├── int8.sql.out │ │ │ │ │ ├── interval.sql.out │ │ │ │ │ ├── join.sql.out │ │ │ │ │ ├── limit.sql.out │ │ │ │ │ ├── numeric.sql.out │ │ │ │ │ ├── select.sql.out │ │ │ │ │ ├── select_distinct.sql.out │ │ │ │ │ ├── select_having.sql.out │ │ │ │ │ ├── select_implicit.sql.out │ │ │ │ │ ├── strings.sql.out │ │ │ │ │ ├── text.sql.out │ │ │ │ │ ├── timestamp.sql.out │ │ │ │ │ ├── union.sql.out │ │ │ │ │ ├── window_part1.sql.out │ │ │ │ │ ├── window_part2.sql.out │ │ │ │ │ ├── window_part3.sql.out │ │ │ │ │ ├── window_part4.sql.out │ │ │ │ │ └── with.sql.out │ │ │ │ ├── pred-pushdown.sql.out │ │ │ │ ├── predicate-functions.sql.out │ │ │ │ ├── query_regex_column.sql.out │ │ │ │ ├── random.sql.out │ │ │ │ ├── regexp-functions.sql.out │ │ │ │ ├── replacing-missing-expression-with-alias.sql.out │ │ │ │ ├── runtime-replaceable-edge-cases.sql.out │ │ │ │ ├── scripting │ │ │ │ │ └── randomly_generated_scripts.sql.out │ │ │ │ ├── selectExcept.sql.out │ │ │ │ ├── session-variable-precedence.sql.out │ │ │ │ ├── show-create-table.sql.out │ │ │ │ ├── show-tables.sql.out │ │ │ │ ├── show-tblproperties.sql.out │ │ │ │ ├── show-views.sql.out │ │ │ │ ├── show_columns.sql.out │ │ │ │ ├── sql-compatibility-functions.sql.out │ │ │ │ ├── sql-on-files.sql.out │ │ │ │ ├── sql-session-variables.sql.out │ │ │ │ ├── sql-udf.sql.out │ │ │ │ ├── st-functions.sql.out │ │ │ │ ├── string-functions.sql.out │ │ │ │ ├── struct.sql.out │ │ │ │ ├── subexp-elimination.sql.out │ │ │ │ ├── subquery │ │ │ │ │ ├── exists-subquery │ │ │ │ │ │ ├── exists-aggregate.sql.out │ │ │ │ │ │ ├── exists-basic.sql.out │ │ │ │ │ │ ├── exists-count-bug.sql.out │ │ │ │ │ │ ├── exists-cte.sql.out │ │ │ │ │ │ ├── exists-having.sql.out │ │ │ │ │ │ ├── exists-in-join-condition.sql.out │ │ │ │ │ │ ├── exists-joins-and-set-ops.sql.out │ │ │ │ │ │ ├── exists-orderby-limit.sql.out │ │ │ │ │ │ ├── exists-outside-filter.sql.out │ │ │ │ │ │ └── exists-within-and-or.sql.out │ │ │ │ │ ├── in-subquery │ │ │ │ │ │ ├── in-basic.sql.out │ │ │ │ │ │ ├── in-count-bug.sql.out │ │ │ │ │ │ ├── in-group-by.sql.out │ │ │ │ │ │ ├── in-having.sql.out │ │ │ │ │ │ ├── in-joins.sql.out │ │ │ │ │ │ ├── in-limit.sql.out │ │ │ │ │ │ ├── in-multiple-columns.sql.out │ │ │ │ │ │ ├── in-null-semantics.sql.out │ │ │ │ │ │ ├── in-nullability.sql.out │ │ │ │ │ │ ├── in-order-by.sql.out │ │ │ │ │ │ ├── in-set-operations.sql.out │ │ │ │ │ │ ├── in-subquery-in-join-condition.sql.out │ │ │ │ │ │ ├── in-with-cte.sql.out │ │ │ │ │ │ ├── nested-not-in.sql.out │ │ │ │ │ │ ├── not-in-group-by.sql.out │ │ │ │ │ │ ├── not-in-joins.sql.out │ │ │ │ │ │ ├── not-in-unit-tests-multi-column-literal.sql.out │ │ │ │ │ │ ├── not-in-unit-tests-multi-column.sql.out │ │ │ │ │ │ ├── not-in-unit-tests-single-column-literal.sql.out │ │ │ │ │ │ ├── not-in-unit-tests-single-column.sql.out │ │ │ │ │ │ └── simple-in.sql.out │ │ │ │ │ ├── negative-cases │ │ │ │ │ │ ├── invalid-correlation.sql.out │ │ │ │ │ │ └── subq-input-typecheck.sql.out │ │ │ │ │ ├── resolution-edge-cases.sql.out │ │ │ │ │ ├── scalar-subquery │ │ │ │ │ │ ├── nested-scalar-subquery-count-bug.sql.out │ │ │ │ │ │ ├── scalar-subquery-count-bug.sql.out │ │ │ │ │ │ ├── scalar-subquery-group-by.sql.out │ │ │ │ │ │ ├── scalar-subquery-predicate.sql.out │ │ │ │ │ │ ├── scalar-subquery-select.sql.out │ │ │ │ │ │ └── scalar-subquery-set-op.sql.out │ │ │ │ │ ├── subquery-in-from.sql.out │ │ │ │ │ ├── subquery-nested-data.sql.out │ │ │ │ │ └── subquery-offset.sql.out │ │ │ │ ├── table-aliases.sql.out │ │ │ │ ├── table-valued-functions.sql.out │ │ │ │ ├── tablesample-negative.sql.out │ │ │ │ ├── thetasketch.sql.out │ │ │ │ ├── time.sql.out │ │ │ │ ├── timestamp-ltz.sql.out │ │ │ │ ├── timestamp-ntz.sql.out │ │ │ │ ├── timestamp.sql.out │ │ │ │ ├── timestampNTZ │ │ │ │ │ ├── datetime-special-ansi.sql.out │ │ │ │ │ ├── datetime-special.sql.out │ │ │ │ │ ├── timestamp-ansi.sql.out │ │ │ │ │ └── timestamp.sql.out │ │ │ │ ├── timezone.sql.out │ │ │ │ ├── to_from_avro.sql.out │ │ │ │ ├── transform.sql.out │ │ │ │ ├── try-string-functions.sql.out │ │ │ │ ├── try_aggregates.sql.out │ │ │ │ ├── try_arithmetic.sql.out │ │ │ │ ├── try_cast.sql.out │ │ │ │ ├── try_datetime_functions.sql.out │ │ │ │ ├── try_element_at.sql.out │ │ │ │ ├── try_reflect.sql.out │ │ │ │ ├── type-coercion-edge-cases.sql.out │ │ │ │ ├── typeCoercion │ │ │ │ │ └── native │ │ │ │ │ │ ├── arrayJoin.sql.out │ │ │ │ │ │ ├── binaryComparison.sql.out │ │ │ │ │ │ ├── booleanEquality.sql.out │ │ │ │ │ │ ├── caseWhenCoercion.sql.out │ │ │ │ │ │ ├── concat.sql.out │ │ │ │ │ │ ├── dateTimeOperations.sql.out │ │ │ │ │ │ ├── decimalPrecision.sql.out │ │ │ │ │ │ ├── division.sql.out │ │ │ │ │ │ ├── elt.sql.out │ │ │ │ │ │ ├── ifCoercion.sql.out │ │ │ │ │ │ ├── implicitTypeCasts.sql.out │ │ │ │ │ │ ├── inConversion.sql.out │ │ │ │ │ │ ├── mapZipWith.sql.out │ │ │ │ │ │ ├── mapconcat.sql.out │ │ │ │ │ │ ├── promoteStrings.sql.out │ │ │ │ │ │ ├── stringCastAndExpressions.sql.out │ │ │ │ │ │ ├── widenSetOperationTypes.sql.out │ │ │ │ │ │ └── windowFrameCoercion.sql.out │ │ │ │ ├── udf │ │ │ │ │ ├── postgreSQL │ │ │ │ │ │ ├── udf-aggregates_part1.sql.out │ │ │ │ │ │ ├── udf-aggregates_part2.sql.out │ │ │ │ │ │ ├── udf-aggregates_part3.sql.out │ │ │ │ │ │ ├── udf-aggregates_part4.sql.out │ │ │ │ │ │ ├── udf-case.sql.out │ │ │ │ │ │ ├── udf-join.sql.out │ │ │ │ │ │ ├── udf-select_having.sql.out │ │ │ │ │ │ └── udf-select_implicit.sql.out │ │ │ │ │ ├── udf-count.sql.out │ │ │ │ │ ├── udf-cross-join.sql.out │ │ │ │ │ ├── udf-except-all.sql.out │ │ │ │ │ ├── udf-except.sql.out │ │ │ │ │ ├── udf-group-analytics.sql.out │ │ │ │ │ ├── udf-group-by.sql.out │ │ │ │ │ ├── udf-having.sql.out │ │ │ │ │ ├── udf-inline-table.sql.out │ │ │ │ │ ├── udf-inner-join.sql.out │ │ │ │ │ ├── udf-intersect-all.sql.out │ │ │ │ │ ├── udf-join-empty-relation.sql.out │ │ │ │ │ ├── udf-natural-join.sql.out │ │ │ │ │ ├── udf-outer-join.sql.out │ │ │ │ │ ├── udf-pivot.sql.out │ │ │ │ │ ├── udf-special-values.sql.out │ │ │ │ │ ├── udf-udaf.sql.out │ │ │ │ │ ├── udf-union.sql.out │ │ │ │ │ └── udf-window.sql.out │ │ │ │ ├── udtf │ │ │ │ │ └── udtf.sql.out │ │ │ │ ├── union-per-child-output-deduplication.sql.out │ │ │ │ ├── union-resolution-edge-cases.sql.out │ │ │ │ ├── union.sql.out │ │ │ │ ├── unpivot.sql.out │ │ │ │ ├── url-functions.sql.out │ │ │ │ ├── using-join.sql.out │ │ │ │ ├── variant-field-extractions.sql.out │ │ │ │ ├── variant │ │ │ │ │ └── named-function-arguments.sql.out │ │ │ │ ├── view-conf.sql.out │ │ │ │ ├── view-schema-binding-config.sql.out │ │ │ │ ├── view-schema-binding.sql.out │ │ │ │ ├── view-schema-compensation.sql.out │ │ │ │ ├── view-schema-evolution.sql.out │ │ │ │ ├── view-schema-type-evolution.sql.out │ │ │ │ ├── view-with-default-collation.sql.out │ │ │ │ ├── window-with-aggregates.sql.out │ │ │ │ ├── window.sql.out │ │ │ │ └── xml-functions.sql.out │ │ │ ├── inputs │ │ │ │ ├── alias-resolution-edge-cases.sql │ │ │ │ ├── array.sql │ │ │ │ ├── binary.sql │ │ │ │ ├── binary_base64.sql │ │ │ │ ├── binary_basic.sql │ │ │ │ ├── binary_hex.sql │ │ │ │ ├── binary_hex_discrete.sql │ │ │ │ ├── bitwise.sql │ │ │ │ ├── cast.sql │ │ │ │ ├── ceil-floor-with-scale-param.sql │ │ │ │ ├── change-column.sql │ │ │ │ ├── charvarchar.sql │ │ │ │ ├── collations-aliases.sql │ │ │ │ ├── collations-basic.sql │ │ │ │ ├── collations-padding-trim.sql │ │ │ │ ├── collations-string-functions.sql │ │ │ │ ├── column-resolution-aggregate.sql │ │ │ │ ├── column-resolution-sort.sql │ │ │ │ ├── columnresolution-negative.sql │ │ │ │ ├── columnresolution-views.sql │ │ │ │ ├── columnresolution.sql │ │ │ │ ├── comments.sql │ │ │ │ ├── comparator.sql │ │ │ │ ├── conditional-functions.sql │ │ │ │ ├── count.sql │ │ │ │ ├── cross-join.sql │ │ │ │ ├── csv-functions.sql │ │ │ │ ├── cte-command.sql │ │ │ │ ├── cte-legacy.sql │ │ │ │ ├── cte-nested.sql │ │ │ │ ├── cte-nonlegacy.sql │ │ │ │ ├── cte-recursion.sql │ │ │ │ ├── cte.sql │ │ │ │ ├── current_database_catalog.sql │ │ │ │ ├── date.sql │ │ │ │ ├── datetime-formatting-invalid.sql │ │ │ │ ├── datetime-formatting-legacy.sql │ │ │ │ ├── datetime-formatting.sql │ │ │ │ ├── datetime-legacy.sql │ │ │ │ ├── datetime-parsing-invalid.sql │ │ │ │ ├── datetime-parsing-legacy.sql │ │ │ │ ├── datetime-parsing.sql │ │ │ │ ├── datetime-special.sql │ │ │ │ ├── decimalArithmeticOperations.sql │ │ │ │ ├── describe-part-after-analyze.sql │ │ │ │ ├── describe-query.sql │ │ │ │ ├── describe-table-after-alter-table.sql │ │ │ │ ├── describe.sql │ │ │ │ ├── double-quoted-identifiers-enabled.sql │ │ │ │ ├── double-quoted-identifiers.sql │ │ │ │ ├── except-all.sql │ │ │ │ ├── except.sql │ │ │ │ ├── execute-immediate.sql │ │ │ │ ├── explain-aqe.sql │ │ │ │ ├── explain-cbo.sql │ │ │ │ ├── explain.sql │ │ │ │ ├── extract-value-resolution-edge-cases.sql │ │ │ │ ├── extract.sql │ │ │ │ ├── generators.sql │ │ │ │ ├── group-analytics.sql │ │ │ │ ├── group-by-alias.sql │ │ │ │ ├── group-by-all-duckdb.sql │ │ │ │ ├── group-by-all-mosha.sql │ │ │ │ ├── group-by-all.sql │ │ │ │ ├── group-by-filter.sql │ │ │ │ ├── group-by-ordinal.sql │ │ │ │ ├── group-by.sql │ │ │ │ ├── grouping_set.sql │ │ │ │ ├── having-and-order-by-recursive-type-name-resolution.sql │ │ │ │ ├── having.sql │ │ │ │ ├── higher-order-functions.sql │ │ │ │ ├── hll.sql │ │ │ │ ├── identifier-clause-legacy.sql │ │ │ │ ├── identifier-clause.sql │ │ │ │ ├── ignored.sql │ │ │ │ ├── ilike-all.sql │ │ │ │ ├── ilike-any.sql │ │ │ │ ├── ilike.sql │ │ │ │ ├── inline-table.sql │ │ │ │ ├── inner-join.sql │ │ │ │ ├── intersect-all.sql │ │ │ │ ├── interval.sql │ │ │ │ ├── join-empty-relation.sql │ │ │ │ ├── join-lateral.sql │ │ │ │ ├── join-resolution-edge-cases.sql │ │ │ │ ├── json-functions.sql │ │ │ │ ├── keywords-enforced.sql │ │ │ │ ├── keywords.sql │ │ │ │ ├── kllquantiles.sql │ │ │ │ ├── like-all.sql │ │ │ │ ├── like-any.sql │ │ │ │ ├── limit.sql │ │ │ │ ├── linear-regression.sql │ │ │ │ ├── listagg-collations.sql │ │ │ │ ├── listagg.sql │ │ │ │ ├── literals.sql │ │ │ │ ├── map.sql │ │ │ │ ├── mask-functions.sql │ │ │ │ ├── math.sql │ │ │ │ ├── misc-functions.sql │ │ │ │ ├── mode.sql │ │ │ │ ├── name-precedence-in-order-by-and-having-with-conflicting-attributes.sql │ │ │ │ ├── named-function-arguments.sql │ │ │ │ ├── natural-join.sql │ │ │ │ ├── non-excludable-rule.sql │ │ │ │ ├── nonansi │ │ │ │ │ ├── array.sql │ │ │ │ │ ├── cast.sql │ │ │ │ │ ├── conditional-functions.sql │ │ │ │ │ ├── date.sql │ │ │ │ │ ├── datetime-parsing-invalid.sql │ │ │ │ │ ├── datetime-special.sql │ │ │ │ │ ├── decimalArithmeticOperations.sql │ │ │ │ │ ├── double-quoted-identifiers.sql │ │ │ │ │ ├── higher-order-functions.sql │ │ │ │ │ ├── interval.sql │ │ │ │ │ ├── keywords.sql │ │ │ │ │ ├── literals.sql │ │ │ │ │ ├── map.sql │ │ │ │ │ ├── math.sql │ │ │ │ │ ├── parse-schema-string.sql │ │ │ │ │ ├── st-functions.sql │ │ │ │ │ ├── string-functions.sql │ │ │ │ │ ├── timestamp.sql │ │ │ │ │ ├── try_aggregates.sql │ │ │ │ │ ├── try_arithmetic.sql │ │ │ │ │ ├── try_datetime_functions.sql │ │ │ │ │ └── try_element_at.sql │ │ │ │ ├── null-handling.sql │ │ │ │ ├── null-propagation.sql │ │ │ │ ├── operators.sql │ │ │ │ ├── order-by-alias.sql │ │ │ │ ├── order-by-all.sql │ │ │ │ ├── order-by-and-having-on-top-of-aggregate-with-join.sql │ │ │ │ ├── order-by-nulls-ordering.sql │ │ │ │ ├── order-by-ordinal.sql │ │ │ │ ├── order-by.sql │ │ │ │ ├── outer-join.sql │ │ │ │ ├── parse-query-correctness-old-behavior.sql │ │ │ │ ├── parse-query-correctness.sql │ │ │ │ ├── parse-schema-string.sql │ │ │ │ ├── percentiles.sql │ │ │ │ ├── pipe-operators.sql │ │ │ │ ├── pivot.sql │ │ │ │ ├── postgreSQL │ │ │ │ │ ├── aggregates_part1.sql │ │ │ │ │ ├── aggregates_part2.sql │ │ │ │ │ ├── aggregates_part3.sql │ │ │ │ │ ├── aggregates_part4.sql │ │ │ │ │ ├── boolean.sql │ │ │ │ │ ├── case.sql │ │ │ │ │ ├── comments.sql │ │ │ │ │ ├── create_view.sql │ │ │ │ │ ├── date.sql │ │ │ │ │ ├── float4.sql │ │ │ │ │ ├── float8.sql │ │ │ │ │ ├── groupingsets.sql │ │ │ │ │ ├── insert.sql │ │ │ │ │ ├── int2.sql │ │ │ │ │ ├── int4.sql │ │ │ │ │ ├── int8.sql │ │ │ │ │ ├── interval.sql │ │ │ │ │ ├── join.sql │ │ │ │ │ ├── limit.sql │ │ │ │ │ ├── numeric.sql │ │ │ │ │ ├── select.sql │ │ │ │ │ ├── select_distinct.sql │ │ │ │ │ ├── select_having.sql │ │ │ │ │ ├── select_implicit.sql │ │ │ │ │ ├── strings.sql │ │ │ │ │ ├── text.sql │ │ │ │ │ ├── timestamp.sql │ │ │ │ │ ├── union.sql │ │ │ │ │ ├── window_part1.sql │ │ │ │ │ ├── window_part2.sql │ │ │ │ │ ├── window_part3.sql │ │ │ │ │ ├── window_part4.sql │ │ │ │ │ └── with.sql │ │ │ │ ├── pred-pushdown.sql │ │ │ │ ├── predicate-functions.sql │ │ │ │ ├── query_regex_column.sql │ │ │ │ ├── random.sql │ │ │ │ ├── regexp-functions.sql │ │ │ │ ├── replacing-missing-expression-with-alias.sql │ │ │ │ ├── runtime-replaceable-edge-cases.sql │ │ │ │ ├── scripting │ │ │ │ │ └── randomly_generated_scripts.sql │ │ │ │ ├── selectExcept.sql │ │ │ │ ├── session-variable-precedence.sql │ │ │ │ ├── show-create-table.sql │ │ │ │ ├── show-tables.sql │ │ │ │ ├── show-tblproperties.sql │ │ │ │ ├── show-views.sql │ │ │ │ ├── show_columns.sql │ │ │ │ ├── sql-compatibility-functions.sql │ │ │ │ ├── sql-on-files.sql │ │ │ │ ├── sql-session-variables.sql │ │ │ │ ├── sql-udf.sql │ │ │ │ ├── st-functions.sql │ │ │ │ ├── string-functions.sql │ │ │ │ ├── struct.sql │ │ │ │ ├── subexp-elimination.sql │ │ │ │ ├── subquery │ │ │ │ │ ├── exists-subquery │ │ │ │ │ │ ├── exists-aggregate.sql │ │ │ │ │ │ ├── exists-basic.sql │ │ │ │ │ │ ├── exists-count-bug.sql │ │ │ │ │ │ ├── exists-cte.sql │ │ │ │ │ │ ├── exists-having.sql │ │ │ │ │ │ ├── exists-in-join-condition.sql │ │ │ │ │ │ ├── exists-joins-and-set-ops.sql │ │ │ │ │ │ ├── exists-orderby-limit.sql │ │ │ │ │ │ ├── exists-outside-filter.sql │ │ │ │ │ │ └── exists-within-and-or.sql │ │ │ │ │ ├── in-subquery │ │ │ │ │ │ ├── in-basic.sql │ │ │ │ │ │ ├── in-count-bug.sql │ │ │ │ │ │ ├── in-group-by.sql │ │ │ │ │ │ ├── in-having.sql │ │ │ │ │ │ ├── in-joins.sql │ │ │ │ │ │ ├── in-limit.sql │ │ │ │ │ │ ├── in-multiple-columns.sql │ │ │ │ │ │ ├── in-null-semantics.sql │ │ │ │ │ │ ├── in-nullability.sql │ │ │ │ │ │ ├── in-order-by.sql │ │ │ │ │ │ ├── in-set-operations.sql │ │ │ │ │ │ ├── in-subquery-in-join-condition.sql │ │ │ │ │ │ ├── in-with-cte.sql │ │ │ │ │ │ ├── nested-not-in.sql │ │ │ │ │ │ ├── not-in-group-by.sql │ │ │ │ │ │ ├── not-in-joins.sql │ │ │ │ │ │ ├── not-in-unit-tests-multi-column-literal.sql │ │ │ │ │ │ ├── not-in-unit-tests-multi-column.sql │ │ │ │ │ │ ├── not-in-unit-tests-single-column-literal.sql │ │ │ │ │ │ ├── not-in-unit-tests-single-column.sql │ │ │ │ │ │ └── simple-in.sql │ │ │ │ │ ├── negative-cases │ │ │ │ │ │ ├── invalid-correlation.sql │ │ │ │ │ │ └── subq-input-typecheck.sql │ │ │ │ │ ├── resolution-edge-cases.sql │ │ │ │ │ ├── scalar-subquery │ │ │ │ │ │ ├── nested-scalar-subquery-count-bug.sql │ │ │ │ │ │ ├── scalar-subquery-count-bug.sql │ │ │ │ │ │ ├── scalar-subquery-group-by.sql │ │ │ │ │ │ ├── scalar-subquery-predicate.sql │ │ │ │ │ │ ├── scalar-subquery-select.sql │ │ │ │ │ │ └── scalar-subquery-set-op.sql │ │ │ │ │ ├── subquery-in-from.sql │ │ │ │ │ ├── subquery-nested-data.sql │ │ │ │ │ └── subquery-offset.sql │ │ │ │ ├── table-aliases.sql │ │ │ │ ├── table-valued-functions.sql │ │ │ │ ├── tablesample-negative.sql │ │ │ │ ├── thetasketch.sql │ │ │ │ ├── time.sql │ │ │ │ ├── timestamp-ltz.sql │ │ │ │ ├── timestamp-ntz.sql │ │ │ │ ├── timestamp.sql │ │ │ │ ├── timestampNTZ │ │ │ │ │ ├── datetime-special-ansi.sql │ │ │ │ │ ├── datetime-special.sql │ │ │ │ │ ├── timestamp-ansi.sql │ │ │ │ │ └── timestamp.sql │ │ │ │ ├── timezone.sql │ │ │ │ ├── to_from_avro.sql │ │ │ │ ├── transform.sql │ │ │ │ ├── try-string-functions.sql │ │ │ │ ├── try_aggregates.sql │ │ │ │ ├── try_arithmetic.sql │ │ │ │ ├── try_cast.sql │ │ │ │ ├── try_datetime_functions.sql │ │ │ │ ├── try_element_at.sql │ │ │ │ ├── try_reflect.sql │ │ │ │ ├── type-coercion-edge-cases.sql │ │ │ │ ├── typeCoercion │ │ │ │ │ └── native │ │ │ │ │ │ ├── arrayJoin.sql │ │ │ │ │ │ ├── binaryComparison.sql │ │ │ │ │ │ ├── booleanEquality.sql │ │ │ │ │ │ ├── caseWhenCoercion.sql │ │ │ │ │ │ ├── concat.sql │ │ │ │ │ │ ├── dateTimeOperations.sql │ │ │ │ │ │ ├── decimalPrecision.sql │ │ │ │ │ │ ├── division.sql │ │ │ │ │ │ ├── elt.sql │ │ │ │ │ │ ├── ifCoercion.sql │ │ │ │ │ │ ├── implicitTypeCasts.sql │ │ │ │ │ │ ├── inConversion.sql │ │ │ │ │ │ ├── mapZipWith.sql │ │ │ │ │ │ ├── mapconcat.sql │ │ │ │ │ │ ├── promoteStrings.sql │ │ │ │ │ │ ├── stringCastAndExpressions.sql │ │ │ │ │ │ ├── widenSetOperationTypes.sql │ │ │ │ │ │ └── windowFrameCoercion.sql │ │ │ │ ├── udaf │ │ │ │ │ ├── udaf-group-analytics.sql │ │ │ │ │ ├── udaf-group-by-ordinal.sql │ │ │ │ │ ├── udaf-group-by.sql │ │ │ │ │ ├── udaf-grouping-set.sql │ │ │ │ │ └── udaf.sql │ │ │ │ ├── udf │ │ │ │ │ ├── postgreSQL │ │ │ │ │ │ ├── udf-aggregates_part1.sql │ │ │ │ │ │ ├── udf-aggregates_part2.sql │ │ │ │ │ │ ├── udf-aggregates_part3.sql │ │ │ │ │ │ ├── udf-aggregates_part4.sql │ │ │ │ │ │ ├── udf-case.sql │ │ │ │ │ │ ├── udf-join.sql │ │ │ │ │ │ ├── udf-select_having.sql │ │ │ │ │ │ └── udf-select_implicit.sql │ │ │ │ │ ├── udf-count.sql │ │ │ │ │ ├── udf-cross-join.sql │ │ │ │ │ ├── udf-except-all.sql │ │ │ │ │ ├── udf-except.sql │ │ │ │ │ ├── udf-group-analytics.sql │ │ │ │ │ ├── udf-group-by.sql │ │ │ │ │ ├── udf-having.sql │ │ │ │ │ ├── udf-inline-table.sql │ │ │ │ │ ├── udf-inner-join.sql │ │ │ │ │ ├── udf-intersect-all.sql │ │ │ │ │ ├── udf-join-empty-relation.sql │ │ │ │ │ ├── udf-natural-join.sql │ │ │ │ │ ├── udf-outer-join.sql │ │ │ │ │ ├── udf-pivot.sql │ │ │ │ │ ├── udf-special-values.sql │ │ │ │ │ ├── udf-udaf.sql │ │ │ │ │ ├── udf-union.sql │ │ │ │ │ └── udf-window.sql │ │ │ │ ├── udtf │ │ │ │ │ └── udtf.sql │ │ │ │ ├── union-per-child-output-deduplication.sql │ │ │ │ ├── union-resolution-edge-cases.sql │ │ │ │ ├── union.sql │ │ │ │ ├── unpivot.sql │ │ │ │ ├── url-functions.sql │ │ │ │ ├── using-join.sql │ │ │ │ ├── variant-field-extractions.sql │ │ │ │ ├── variant │ │ │ │ │ └── named-function-arguments.sql │ │ │ │ ├── view-conf.sql │ │ │ │ ├── view-schema-binding-config.sql │ │ │ │ ├── view-schema-binding.sql │ │ │ │ ├── view-schema-compensation.sql │ │ │ │ ├── view-schema-evolution.sql │ │ │ │ ├── view-schema-type-evolution.sql │ │ │ │ ├── view-with-default-collation.sql │ │ │ │ ├── window-with-aggregates.sql │ │ │ │ ├── window.sql │ │ │ │ └── xml-functions.sql │ │ │ └── results │ │ │ │ ├── alias-resolution-edge-cases.sql.out │ │ │ │ ├── array.sql.out │ │ │ │ ├── binary.sql.out │ │ │ │ ├── binary_base64.sql.out │ │ │ │ ├── binary_basic.sql.out │ │ │ │ ├── binary_hex.sql.out │ │ │ │ ├── binary_hex_discrete.sql.out │ │ │ │ ├── bitwise.sql.out │ │ │ │ ├── cast.sql.out │ │ │ │ ├── ceil-floor-with-scale-param.sql.out │ │ │ │ ├── change-column.sql.out │ │ │ │ ├── charvarchar.sql.out │ │ │ │ ├── collations-aliases.sql.out │ │ │ │ ├── collations-basic.sql.out │ │ │ │ ├── collations-padding-trim.sql.out │ │ │ │ ├── collations-string-functions.sql.out │ │ │ │ ├── column-resolution-aggregate.sql.out │ │ │ │ ├── column-resolution-sort.sql.out │ │ │ │ ├── columnresolution-negative.sql.out │ │ │ │ ├── columnresolution-views.sql.out │ │ │ │ ├── columnresolution.sql.out │ │ │ │ ├── comments.sql.out │ │ │ │ ├── comparator.sql.out │ │ │ │ ├── conditional-functions.sql.out │ │ │ │ ├── count.sql.out │ │ │ │ ├── cross-join.sql.out │ │ │ │ ├── csv-functions.sql.out │ │ │ │ ├── cte-command.sql.out │ │ │ │ ├── cte-legacy.sql.out │ │ │ │ ├── cte-nested.sql.out │ │ │ │ ├── cte-nonlegacy.sql.out │ │ │ │ ├── cte-recursion.sql.out │ │ │ │ ├── cte.sql.out │ │ │ │ ├── current_database_catalog.sql.out │ │ │ │ ├── date.sql.out │ │ │ │ ├── datetime-formatting-invalid.sql.out │ │ │ │ ├── datetime-formatting-legacy.sql.out │ │ │ │ ├── datetime-formatting.sql.out │ │ │ │ ├── datetime-formatting.sql.out.java21 │ │ │ │ ├── datetime-legacy.sql.out │ │ │ │ ├── datetime-parsing-invalid.sql.out │ │ │ │ ├── datetime-parsing-legacy.sql.out │ │ │ │ ├── datetime-parsing.sql.out │ │ │ │ ├── datetime-special.sql.out │ │ │ │ ├── decimalArithmeticOperations.sql.out │ │ │ │ ├── describe-part-after-analyze.sql.out │ │ │ │ ├── describe-query.sql.out │ │ │ │ ├── describe-table-after-alter-table.sql.out │ │ │ │ ├── describe.sql.out │ │ │ │ ├── double-quoted-identifiers-enabled.sql.out │ │ │ │ ├── double-quoted-identifiers.sql.out │ │ │ │ ├── except-all.sql.out │ │ │ │ ├── except.sql.out │ │ │ │ ├── execute-immediate.sql.out │ │ │ │ ├── explain-aqe.sql.out │ │ │ │ ├── explain-cbo.sql.out │ │ │ │ ├── explain.sql.out │ │ │ │ ├── extract-value-resolution-edge-cases.sql.out │ │ │ │ ├── extract.sql.out │ │ │ │ ├── generators.sql.out │ │ │ │ ├── group-analytics.sql.out │ │ │ │ ├── group-by-alias.sql.out │ │ │ │ ├── group-by-all-duckdb.sql.out │ │ │ │ ├── group-by-all-mosha.sql.out │ │ │ │ ├── group-by-all.sql.out │ │ │ │ ├── group-by-filter.sql.out │ │ │ │ ├── group-by-ordinal.sql.out │ │ │ │ ├── group-by.sql.out │ │ │ │ ├── grouping_set.sql.out │ │ │ │ ├── having-and-order-by-recursive-type-name-resolution.sql.out │ │ │ │ ├── having.sql.out │ │ │ │ ├── higher-order-functions.sql.out │ │ │ │ ├── hll.sql.out │ │ │ │ ├── identifier-clause-legacy.sql.out │ │ │ │ ├── identifier-clause.sql.out │ │ │ │ ├── ilike-all.sql.out │ │ │ │ ├── ilike-any.sql.out │ │ │ │ ├── ilike.sql.out │ │ │ │ ├── inline-table.sql.out │ │ │ │ ├── inner-join.sql.out │ │ │ │ ├── intersect-all.sql.out │ │ │ │ ├── interval.sql.out │ │ │ │ ├── join-empty-relation.sql.out │ │ │ │ ├── join-lateral.sql.out │ │ │ │ ├── join-resolution-edge-cases.sql.out │ │ │ │ ├── json-functions.sql.out │ │ │ │ ├── keywords-enforced.sql.out │ │ │ │ ├── keywords.sql.out │ │ │ │ ├── kllquantiles.sql.out │ │ │ │ ├── like-all.sql.out │ │ │ │ ├── like-any.sql.out │ │ │ │ ├── limit.sql.out │ │ │ │ ├── linear-regression.sql.out │ │ │ │ ├── listagg-collations.sql.out │ │ │ │ ├── listagg.sql.out │ │ │ │ ├── literals.sql.out │ │ │ │ ├── map.sql.out │ │ │ │ ├── mask-functions.sql.out │ │ │ │ ├── math.sql.out │ │ │ │ ├── misc-functions.sql.out │ │ │ │ ├── mode.sql.out │ │ │ │ ├── name-precedence-in-order-by-and-having-with-conflicting-attributes.sql.out │ │ │ │ ├── named-function-arguments.sql.out │ │ │ │ ├── natural-join.sql.out │ │ │ │ ├── non-excludable-rule.sql.out │ │ │ │ ├── nonansi │ │ │ │ ├── array.sql.out │ │ │ │ ├── cast.sql.out │ │ │ │ ├── conditional-functions.sql.out │ │ │ │ ├── date.sql.out │ │ │ │ ├── datetime-parsing-invalid.sql.out │ │ │ │ ├── datetime-special.sql.out │ │ │ │ ├── decimalArithmeticOperations.sql.out │ │ │ │ ├── double-quoted-identifiers.sql.out │ │ │ │ ├── higher-order-functions.sql.out │ │ │ │ ├── interval.sql.out │ │ │ │ ├── keywords.sql.out │ │ │ │ ├── literals.sql.out │ │ │ │ ├── map.sql.out │ │ │ │ ├── math.sql.out │ │ │ │ ├── parse-schema-string.sql.out │ │ │ │ ├── st-functions.sql.out │ │ │ │ ├── string-functions.sql.out │ │ │ │ ├── timestamp.sql.out │ │ │ │ ├── try_aggregates.sql.out │ │ │ │ ├── try_aggregates.sql.out.java21 │ │ │ │ ├── try_arithmetic.sql.out │ │ │ │ ├── try_arithmetic.sql.out.java21 │ │ │ │ ├── try_datetime_functions.sql.out │ │ │ │ └── try_element_at.sql.out │ │ │ │ ├── null-handling.sql.out │ │ │ │ ├── null-propagation.sql.out │ │ │ │ ├── operators.sql.out │ │ │ │ ├── order-by-alias.sql.out │ │ │ │ ├── order-by-all.sql.out │ │ │ │ ├── order-by-and-having-on-top-of-aggregate-with-join.sql.out │ │ │ │ ├── order-by-nulls-ordering.sql.out │ │ │ │ ├── order-by-ordinal.sql.out │ │ │ │ ├── order-by.sql.out │ │ │ │ ├── outer-join.sql.out │ │ │ │ ├── parse-query-correctness-old-behavior.sql.out │ │ │ │ ├── parse-query-correctness.sql.out │ │ │ │ ├── parse-schema-string.sql.out │ │ │ │ ├── percentiles.sql.out │ │ │ │ ├── pipe-operators.sql.out │ │ │ │ ├── pivot.sql.out │ │ │ │ ├── postgreSQL │ │ │ │ ├── aggregates_part1.sql.out │ │ │ │ ├── aggregates_part2.sql.out │ │ │ │ ├── aggregates_part3.sql.out │ │ │ │ ├── aggregates_part4.sql.out │ │ │ │ ├── boolean.sql.out │ │ │ │ ├── case.sql.out │ │ │ │ ├── comments.sql.out │ │ │ │ ├── create_view.sql.out │ │ │ │ ├── date.sql.out │ │ │ │ ├── float4.sql.out │ │ │ │ ├── float4.sql.out.java21 │ │ │ │ ├── float8.sql.out │ │ │ │ ├── groupingsets.sql.out │ │ │ │ ├── insert.sql.out │ │ │ │ ├── int2.sql.out │ │ │ │ ├── int4.sql.out │ │ │ │ ├── int8.sql.out │ │ │ │ ├── int8.sql.out.java21 │ │ │ │ ├── interval.sql.out │ │ │ │ ├── join.sql.out │ │ │ │ ├── limit.sql.out │ │ │ │ ├── numeric.sql.out │ │ │ │ ├── numeric.sql.out.java21 │ │ │ │ ├── select.sql.out │ │ │ │ ├── select_distinct.sql.out │ │ │ │ ├── select_having.sql.out │ │ │ │ ├── select_implicit.sql.out │ │ │ │ ├── strings.sql.out │ │ │ │ ├── text.sql.out │ │ │ │ ├── timestamp.sql.out │ │ │ │ ├── union.sql.out │ │ │ │ ├── window_part1.sql.out │ │ │ │ ├── window_part2.sql.out │ │ │ │ ├── window_part3.sql.out │ │ │ │ ├── window_part4.sql.out │ │ │ │ └── with.sql.out │ │ │ │ ├── pred-pushdown.sql.out │ │ │ │ ├── predicate-functions.sql.out │ │ │ │ ├── query_regex_column.sql.out │ │ │ │ ├── random.sql.out │ │ │ │ ├── regexp-functions.sql.out │ │ │ │ ├── replacing-missing-expression-with-alias.sql.out │ │ │ │ ├── runtime-replaceable-edge-cases.sql.out │ │ │ │ ├── scripting │ │ │ │ └── randomly_generated_scripts.sql.out │ │ │ │ ├── selectExcept.sql.out │ │ │ │ ├── session-variable-precedence.sql.out │ │ │ │ ├── show-create-table.sql.out │ │ │ │ ├── show-tables.sql.out │ │ │ │ ├── show-tblproperties.sql.out │ │ │ │ ├── show-views.sql.out │ │ │ │ ├── show_columns.sql.out │ │ │ │ ├── sql-compatibility-functions.sql.out │ │ │ │ ├── sql-on-files.sql.out │ │ │ │ ├── sql-session-variables.sql.out │ │ │ │ ├── sql-udf.sql.out │ │ │ │ ├── st-functions.sql.out │ │ │ │ ├── string-functions.sql.out │ │ │ │ ├── struct.sql.out │ │ │ │ ├── subexp-elimination.sql.out │ │ │ │ ├── subquery │ │ │ │ ├── exists-subquery │ │ │ │ │ ├── exists-aggregate.sql.out │ │ │ │ │ ├── exists-basic.sql.out │ │ │ │ │ ├── exists-count-bug.sql.out │ │ │ │ │ ├── exists-cte.sql.out │ │ │ │ │ ├── exists-having.sql.out │ │ │ │ │ ├── exists-in-join-condition.sql.out │ │ │ │ │ ├── exists-joins-and-set-ops.sql.out │ │ │ │ │ ├── exists-orderby-limit.sql.out │ │ │ │ │ ├── exists-outside-filter.sql.out │ │ │ │ │ └── exists-within-and-or.sql.out │ │ │ │ ├── in-subquery │ │ │ │ │ ├── in-basic.sql.out │ │ │ │ │ ├── in-count-bug.sql.out │ │ │ │ │ ├── in-group-by.sql.out │ │ │ │ │ ├── in-having.sql.out │ │ │ │ │ ├── in-joins.sql.out │ │ │ │ │ ├── in-limit.sql.out │ │ │ │ │ ├── in-multiple-columns.sql.out │ │ │ │ │ ├── in-null-semantics.sql.out │ │ │ │ │ ├── in-nullability.sql.out │ │ │ │ │ ├── in-order-by.sql.out │ │ │ │ │ ├── in-set-operations.sql.out │ │ │ │ │ ├── in-subquery-in-join-condition.sql.out │ │ │ │ │ ├── in-with-cte.sql.out │ │ │ │ │ ├── nested-not-in.sql.out │ │ │ │ │ ├── not-in-group-by.sql.out │ │ │ │ │ ├── not-in-joins.sql.out │ │ │ │ │ ├── not-in-unit-tests-multi-column-literal.sql.out │ │ │ │ │ ├── not-in-unit-tests-multi-column.sql.out │ │ │ │ │ ├── not-in-unit-tests-single-column-literal.sql.out │ │ │ │ │ ├── not-in-unit-tests-single-column.sql.out │ │ │ │ │ └── simple-in.sql.out │ │ │ │ ├── negative-cases │ │ │ │ │ ├── invalid-correlation.sql.out │ │ │ │ │ └── subq-input-typecheck.sql.out │ │ │ │ ├── resolution-edge-cases.sql.out │ │ │ │ ├── scalar-subquery │ │ │ │ │ ├── nested-scalar-subquery-count-bug.sql.out │ │ │ │ │ ├── scalar-subquery-count-bug.sql.out │ │ │ │ │ ├── scalar-subquery-group-by.sql.out │ │ │ │ │ ├── scalar-subquery-predicate.sql.out │ │ │ │ │ ├── scalar-subquery-select.sql.out │ │ │ │ │ └── scalar-subquery-set-op.sql.out │ │ │ │ ├── subquery-in-from.sql.out │ │ │ │ ├── subquery-nested-data.sql.out │ │ │ │ └── subquery-offset.sql.out │ │ │ │ ├── table-aliases.sql.out │ │ │ │ ├── table-valued-functions.sql.out │ │ │ │ ├── tablesample-negative.sql.out │ │ │ │ ├── thetasketch.sql.out │ │ │ │ ├── time.sql.out │ │ │ │ ├── timestamp-ltz.sql.out │ │ │ │ ├── timestamp-ntz.sql.out │ │ │ │ ├── timestamp.sql.out │ │ │ │ ├── timestampNTZ │ │ │ │ ├── datetime-special-ansi.sql.out │ │ │ │ ├── datetime-special.sql.out │ │ │ │ ├── timestamp-ansi.sql.out │ │ │ │ └── timestamp.sql.out │ │ │ │ ├── timezone.sql.out │ │ │ │ ├── to_from_avro.sql.out │ │ │ │ ├── transform.sql.out │ │ │ │ ├── try-string-functions.sql.out │ │ │ │ ├── try_aggregates.sql.out │ │ │ │ ├── try_aggregates.sql.out.java21 │ │ │ │ ├── try_arithmetic.sql.out │ │ │ │ ├── try_cast.sql.out │ │ │ │ ├── try_datetime_functions.sql.out │ │ │ │ ├── try_element_at.sql.out │ │ │ │ ├── try_reflect.sql.out │ │ │ │ ├── type-coercion-edge-cases.sql.out │ │ │ │ ├── typeCoercion │ │ │ │ └── native │ │ │ │ │ ├── arrayJoin.sql.out │ │ │ │ │ ├── binaryComparison.sql.out │ │ │ │ │ ├── booleanEquality.sql.out │ │ │ │ │ ├── caseWhenCoercion.sql.out │ │ │ │ │ ├── concat.sql.out │ │ │ │ │ ├── dateTimeOperations.sql.out │ │ │ │ │ ├── decimalPrecision.sql.out │ │ │ │ │ ├── division.sql.out │ │ │ │ │ ├── elt.sql.out │ │ │ │ │ ├── ifCoercion.sql.out │ │ │ │ │ ├── implicitTypeCasts.sql.out │ │ │ │ │ ├── inConversion.sql.out │ │ │ │ │ ├── mapZipWith.sql.out │ │ │ │ │ ├── mapconcat.sql.out │ │ │ │ │ ├── promoteStrings.sql.out │ │ │ │ │ ├── stringCastAndExpressions.sql.out │ │ │ │ │ ├── widenSetOperationTypes.sql.out │ │ │ │ │ └── windowFrameCoercion.sql.out │ │ │ │ ├── udaf │ │ │ │ ├── udaf-group-analytics.sql.out │ │ │ │ ├── udaf-group-by-ordinal.sql.out │ │ │ │ ├── udaf-group-by.sql.out │ │ │ │ ├── udaf-grouping-set.sql.out │ │ │ │ └── udaf.sql.out │ │ │ │ ├── udf │ │ │ │ ├── postgreSQL │ │ │ │ │ ├── udf-aggregates_part1.sql.out │ │ │ │ │ ├── udf-aggregates_part2.sql.out │ │ │ │ │ ├── udf-aggregates_part3.sql.out │ │ │ │ │ ├── udf-aggregates_part4.sql.out │ │ │ │ │ ├── udf-case.sql.out │ │ │ │ │ ├── udf-join.sql.out │ │ │ │ │ ├── udf-select_having.sql.out │ │ │ │ │ └── udf-select_implicit.sql.out │ │ │ │ ├── udf-count.sql.out │ │ │ │ ├── udf-cross-join.sql.out │ │ │ │ ├── udf-except-all.sql.out │ │ │ │ ├── udf-except.sql.out │ │ │ │ ├── udf-group-analytics.sql.out │ │ │ │ ├── udf-group-by.sql.out │ │ │ │ ├── udf-having.sql.out │ │ │ │ ├── udf-inline-table.sql.out │ │ │ │ ├── udf-inner-join.sql.out │ │ │ │ ├── udf-intersect-all.sql.out │ │ │ │ ├── udf-join-empty-relation.sql.out │ │ │ │ ├── udf-natural-join.sql.out │ │ │ │ ├── udf-outer-join.sql.out │ │ │ │ ├── udf-pivot.sql.out │ │ │ │ ├── udf-special-values.sql.out │ │ │ │ ├── udf-udaf.sql.out │ │ │ │ ├── udf-union.sql.out │ │ │ │ └── udf-window.sql.out │ │ │ │ ├── udtf │ │ │ │ └── udtf.sql.out │ │ │ │ ├── union-per-child-output-deduplication.sql.out │ │ │ │ ├── union-resolution-edge-cases.sql.out │ │ │ │ ├── union.sql.out │ │ │ │ ├── unpivot.sql.out │ │ │ │ ├── url-functions.sql.out │ │ │ │ ├── using-join.sql.out │ │ │ │ ├── variant-field-extractions.sql.out │ │ │ │ ├── variant │ │ │ │ └── named-function-arguments.sql.out │ │ │ │ ├── view-conf.sql.out │ │ │ │ ├── view-schema-binding-config.sql.out │ │ │ │ ├── view-schema-binding.sql.out │ │ │ │ ├── view-schema-compensation.sql.out │ │ │ │ ├── view-schema-evolution.sql.out │ │ │ │ ├── view-schema-type-evolution.sql.out │ │ │ │ ├── view-with-default-collation.sql.out │ │ │ │ ├── window-with-aggregates.sql.out │ │ │ │ ├── window.sql.out │ │ │ │ └── xml-functions.sql.out │ │ ├── ssb │ │ │ ├── 1.1.sql │ │ │ ├── 1.2.sql │ │ │ ├── 1.3.sql │ │ │ ├── 2.1.sql │ │ │ ├── 2.2.sql │ │ │ ├── 2.3.sql │ │ │ ├── 3.1.sql │ │ │ ├── 3.2.sql │ │ │ ├── 3.3.sql │ │ │ ├── 3.4.sql │ │ │ ├── 4.1.sql │ │ │ ├── 4.2.sql │ │ │ └── 4.3.sql │ │ ├── structured-streaming │ │ │ ├── checkpoint-test-offsetId-commitId-inconsistent │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ └── 2 │ │ │ │ ├── metadata │ │ │ │ └── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 2 │ │ │ │ │ └── 4 │ │ │ ├── checkpoint-version-2.1.0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 4 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 5 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 6 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 7 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 8 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 9 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-2.3.1-flatMapGroupsWithState-state-format-1 │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-2.3.1-for-multi-watermark-policy │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ ├── metadata │ │ │ │ └── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ ├── checkpoint-version-2.3.1-streaming-aggregate-state-format-1 │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-2.3.1-without-commit-log-metadata │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-2.4.0-streaming-join │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 1 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-2.4.5-for-compatibility-test-common-functions │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 1 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-2.4.5-for-compatibility-test-deduplicate │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 1 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-2.4.5-for-compatibility-test-statistical-functions │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 1 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-2.4.5-for-compatibility-test-sum-decimal │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 1 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-3.0.0-streaming-statestore-codec │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ └── 0 │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-3.1.0-flatmapgroupswithstate-repartition │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-3.2.0-deduplication-with-repartition │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ ├── 2.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-3.2.0-flatmapgroupswithstate1-repartition │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── .0.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── .0.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-3.2.0-flatmapgroupswithstate2-repartition │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── .0.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── .0.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-3.2.0-session-window-with-repartition │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ ├── 2.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-3.2.0-streaming-aggregate-with-repartition │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ ├── 2.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-3.3.0-streaming-deduplication │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ ├── 2.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-3.5.1-streaming-deduplication │ │ │ │ ├── .metadata.crc │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ ├── 2.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ ├── .2.delta.crc │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── 2.delta │ │ │ ├── checkpoint-version-3.5.1-streaming-join │ │ │ │ ├── .metadata.crc │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ └── .0.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ └── .0.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ └── schema │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ └── schema │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ └── schema │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ │ └── 1.delta │ │ │ │ │ └── 4 │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ ├── .1.delta.crc │ │ │ │ │ └── 1.delta │ │ │ ├── checkpoint-version-4.0.0-checkpoint-v2 │ │ │ │ └── rocksdb │ │ │ │ │ ├── dedup │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── .0.crc │ │ │ │ │ │ ├── .1.crc │ │ │ │ │ │ ├── .2.crc │ │ │ │ │ │ └── .3.crc │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── .0.crc │ │ │ │ │ │ ├── .1.crc │ │ │ │ │ │ ├── .2.crc │ │ │ │ │ │ └── .3.crc │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── .1_502abf89-6c11-49e0-b008-5e2f90008d17.changelog.crc │ │ │ │ │ │ ├── .2_c80c40ef-6092-497d-badd-733e1cc8929f.changelog.crc │ │ │ │ │ │ ├── .2_c80c40ef-6092-497d-badd-733e1cc8929f.zip.crc │ │ │ │ │ │ ├── .3_02123a76-a01a-4304-8094-802f16d55e31.changelog.crc │ │ │ │ │ │ ├── .4_bf826c41-d5f6-4abb-bf56-379167c045cd.changelog.crc │ │ │ │ │ │ ├── .4_bf826c41-d5f6-4abb-bf56-379167c045cd.zip.crc │ │ │ │ │ │ ├── 1_502abf89-6c11-49e0-b008-5e2f90008d17.changelog │ │ │ │ │ │ ├── 2_c80c40ef-6092-497d-badd-733e1cc8929f.changelog │ │ │ │ │ │ ├── 2_c80c40ef-6092-497d-badd-733e1cc8929f.zip │ │ │ │ │ │ ├── 3_02123a76-a01a-4304-8094-802f16d55e31.changelog │ │ │ │ │ │ ├── 4_bf826c41-d5f6-4abb-bf56-379167c045cd.changelog │ │ │ │ │ │ ├── 4_bf826c41-d5f6-4abb-bf56-379167c045cd.zip │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── .1_d9007f70-cd0c-43ef-9389-afcec6b669a4.changelog.crc │ │ │ │ │ │ ├── .2_3f85db1c-439d-413c-920d-aa7fe300f9af.changelog.crc │ │ │ │ │ │ ├── .2_3f85db1c-439d-413c-920d-aa7fe300f9af.zip.crc │ │ │ │ │ │ ├── .3_e27e4639-ab69-483c-bf19-f9daec0d8328.changelog.crc │ │ │ │ │ │ ├── .4_e2a4feae-a4e3-4183-b07b-db9b8e0794a5.changelog.crc │ │ │ │ │ │ ├── .4_e2a4feae-a4e3-4183-b07b-db9b8e0794a5.zip.crc │ │ │ │ │ │ ├── 1_d9007f70-cd0c-43ef-9389-afcec6b669a4.changelog │ │ │ │ │ │ ├── 2_3f85db1c-439d-413c-920d-aa7fe300f9af.changelog │ │ │ │ │ │ ├── 2_3f85db1c-439d-413c-920d-aa7fe300f9af.zip │ │ │ │ │ │ ├── 3_e27e4639-ab69-483c-bf19-f9daec0d8328.changelog │ │ │ │ │ │ ├── 4_e2a4feae-a4e3-4183-b07b-db9b8e0794a5.changelog │ │ │ │ │ │ ├── 4_e2a4feae-a4e3-4183-b07b-db9b8e0794a5.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-76d123c4-8ad7-4365-9c6a-632d352f04a3.sst.crc │ │ │ │ │ │ │ ├── .000009-b27fc453-a65d-40d3-8c74-30157baa9099.sst.crc │ │ │ │ │ │ │ ├── 000008-76d123c4-8ad7-4365-9c6a-632d352f04a3.sst │ │ │ │ │ │ │ └── 000009-b27fc453-a65d-40d3-8c74-30157baa9099.sst │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── .1_d5647a99-4b94-4683-ae80-67db2b5d40b8.changelog.crc │ │ │ │ │ │ ├── .2_35b5e88f-381b-4d77-bcae-77c70d54b4b9.changelog.crc │ │ │ │ │ │ ├── .2_35b5e88f-381b-4d77-bcae-77c70d54b4b9.zip.crc │ │ │ │ │ │ ├── .3_ec14cef6-eadb-4493-962c-e108b5b8acae.changelog.crc │ │ │ │ │ │ ├── .4_64a2a298-f3f7-4670-9629-c36cd3fac1ea.changelog.crc │ │ │ │ │ │ ├── .4_64a2a298-f3f7-4670-9629-c36cd3fac1ea.zip.crc │ │ │ │ │ │ ├── 1_d5647a99-4b94-4683-ae80-67db2b5d40b8.changelog │ │ │ │ │ │ ├── 2_35b5e88f-381b-4d77-bcae-77c70d54b4b9.changelog │ │ │ │ │ │ ├── 2_35b5e88f-381b-4d77-bcae-77c70d54b4b9.zip │ │ │ │ │ │ ├── 3_ec14cef6-eadb-4493-962c-e108b5b8acae.changelog │ │ │ │ │ │ ├── 4_64a2a298-f3f7-4670-9629-c36cd3fac1ea.changelog │ │ │ │ │ │ ├── 4_64a2a298-f3f7-4670-9629-c36cd3fac1ea.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-b87b2cb5-3569-4055-a42e-138575d698ef.sst.crc │ │ │ │ │ │ │ └── 000008-b87b2cb5-3569-4055-a42e-138575d698ef.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── .1_385921b6-ce74-4827-9294-d7b7b5cd8374.changelog.crc │ │ │ │ │ │ ├── .2_67f09fbd-c2af-4bf6-a1d0-8bca968ac2e6.changelog.crc │ │ │ │ │ │ ├── .2_67f09fbd-c2af-4bf6-a1d0-8bca968ac2e6.zip.crc │ │ │ │ │ │ ├── .3_1cdac062-90db-4c25-986c-68eecec0c062.changelog.crc │ │ │ │ │ │ ├── .4_bfdda7d9-f699-4e2b-acbd-8cf1687fd017.changelog.crc │ │ │ │ │ │ ├── .4_bfdda7d9-f699-4e2b-acbd-8cf1687fd017.zip.crc │ │ │ │ │ │ ├── 1_385921b6-ce74-4827-9294-d7b7b5cd8374.changelog │ │ │ │ │ │ ├── 2_67f09fbd-c2af-4bf6-a1d0-8bca968ac2e6.changelog │ │ │ │ │ │ ├── 2_67f09fbd-c2af-4bf6-a1d0-8bca968ac2e6.zip │ │ │ │ │ │ ├── 3_1cdac062-90db-4c25-986c-68eecec0c062.changelog │ │ │ │ │ │ ├── 4_bfdda7d9-f699-4e2b-acbd-8cf1687fd017.changelog │ │ │ │ │ │ ├── 4_bfdda7d9-f699-4e2b-acbd-8cf1687fd017.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-a5ac0523-cd27-4a25-b56e-9529c51ec4ea.sst.crc │ │ │ │ │ │ │ └── 000008-a5ac0523-cd27-4a25-b56e-9529c51ec4ea.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── .1_c6a353ef-6d1b-4d80-8cc8-ed61f286ef96.changelog.crc │ │ │ │ │ │ ├── .2_793e52db-29f8-4304-9863-fccc9fc95314.changelog.crc │ │ │ │ │ │ ├── .2_793e52db-29f8-4304-9863-fccc9fc95314.zip.crc │ │ │ │ │ │ ├── .3_ce2bc745-a873-47e1-8dab-a4a90e9e9b80.changelog.crc │ │ │ │ │ │ ├── .4_54731796-ed79-463f-a4ee-fbd027dc3374.changelog.crc │ │ │ │ │ │ ├── .4_54731796-ed79-463f-a4ee-fbd027dc3374.zip.crc │ │ │ │ │ │ ├── 1_c6a353ef-6d1b-4d80-8cc8-ed61f286ef96.changelog │ │ │ │ │ │ ├── 2_793e52db-29f8-4304-9863-fccc9fc95314.changelog │ │ │ │ │ │ ├── 2_793e52db-29f8-4304-9863-fccc9fc95314.zip │ │ │ │ │ │ ├── 3_ce2bc745-a873-47e1-8dab-a4a90e9e9b80.changelog │ │ │ │ │ │ ├── 4_54731796-ed79-463f-a4ee-fbd027dc3374.changelog │ │ │ │ │ │ ├── 4_54731796-ed79-463f-a4ee-fbd027dc3374.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-22e14be0-182a-4d87-a1f8-bd348424678a.sst.crc │ │ │ │ │ │ │ ├── .000009-a10b6be2-7555-4b28-b9c3-c3760b3c3f1c.sst.crc │ │ │ │ │ │ │ ├── 000008-22e14be0-182a-4d87-a1f8-bd348424678a.sst │ │ │ │ │ │ │ └── 000009-a10b6be2-7555-4b28-b9c3-c3760b3c3f1c.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── join1 │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── .0.crc │ │ │ │ │ │ ├── .1.crc │ │ │ │ │ │ ├── .2.crc │ │ │ │ │ │ ├── .3.crc │ │ │ │ │ │ └── .4.crc │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── .0.crc │ │ │ │ │ │ ├── .1.crc │ │ │ │ │ │ ├── .2.crc │ │ │ │ │ │ ├── .3.crc │ │ │ │ │ │ └── .4.crc │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_057f7174-b83c-4f06-a25f-93a4c06a9ef2.changelog.crc │ │ │ │ │ │ │ ├── .2_798b1127-ef90-439b-bff1-00ed9e1afa88.changelog.crc │ │ │ │ │ │ │ ├── .2_798b1127-ef90-439b-bff1-00ed9e1afa88.zip.crc │ │ │ │ │ │ │ ├── .3_d188302f-ef9a-4e20-9371-13581cde3a3e.changelog.crc │ │ │ │ │ │ │ ├── .4_8801c6c5-16bf-4269-8828-a94e1d625f24.changelog.crc │ │ │ │ │ │ │ ├── .4_8801c6c5-16bf-4269-8828-a94e1d625f24.zip.crc │ │ │ │ │ │ │ ├── .5_e47cbd81-687a-40b5-b04f-03baee0786eb.changelog.crc │ │ │ │ │ │ │ ├── 1_057f7174-b83c-4f06-a25f-93a4c06a9ef2.changelog │ │ │ │ │ │ │ ├── 2_798b1127-ef90-439b-bff1-00ed9e1afa88.changelog │ │ │ │ │ │ │ ├── 2_798b1127-ef90-439b-bff1-00ed9e1afa88.zip │ │ │ │ │ │ │ ├── 3_d188302f-ef9a-4e20-9371-13581cde3a3e.changelog │ │ │ │ │ │ │ ├── 4_8801c6c5-16bf-4269-8828-a94e1d625f24.changelog │ │ │ │ │ │ │ ├── 4_8801c6c5-16bf-4269-8828-a94e1d625f24.zip │ │ │ │ │ │ │ ├── 5_e47cbd81-687a-40b5-b04f-03baee0786eb.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_cbe493b0-7a15-4914-9277-87260cba4d45.changelog.crc │ │ │ │ │ │ │ ├── .2_d73ef231-9420-4e4e-b6bb-9bada25e8692.changelog.crc │ │ │ │ │ │ │ ├── .2_d73ef231-9420-4e4e-b6bb-9bada25e8692.zip.crc │ │ │ │ │ │ │ ├── .3_96919dfe-10ab-4424-a1fc-22b77b844c67.changelog.crc │ │ │ │ │ │ │ ├── .4_6e759769-1843-4d9e-8134-547bd52d2a0f.changelog.crc │ │ │ │ │ │ │ ├── .4_6e759769-1843-4d9e-8134-547bd52d2a0f.zip.crc │ │ │ │ │ │ │ ├── .5_97b6b8d6-351a-4d9f-b7c3-54e1d6303f0d.changelog.crc │ │ │ │ │ │ │ ├── 1_cbe493b0-7a15-4914-9277-87260cba4d45.changelog │ │ │ │ │ │ │ ├── 2_d73ef231-9420-4e4e-b6bb-9bada25e8692.changelog │ │ │ │ │ │ │ ├── 2_d73ef231-9420-4e4e-b6bb-9bada25e8692.zip │ │ │ │ │ │ │ ├── 3_96919dfe-10ab-4424-a1fc-22b77b844c67.changelog │ │ │ │ │ │ │ ├── 4_6e759769-1843-4d9e-8134-547bd52d2a0f.changelog │ │ │ │ │ │ │ ├── 4_6e759769-1843-4d9e-8134-547bd52d2a0f.zip │ │ │ │ │ │ │ ├── 5_97b6b8d6-351a-4d9f-b7c3-54e1d6303f0d.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_ffe70db3-f62b-494c-bca0-bdfe4b03eb2d.changelog.crc │ │ │ │ │ │ │ ├── .2_b9c6d162-2375-4be1-af05-86fae13a9a5d.changelog.crc │ │ │ │ │ │ │ ├── .2_b9c6d162-2375-4be1-af05-86fae13a9a5d.zip.crc │ │ │ │ │ │ │ ├── .3_1455e423-44ab-4686-bef0-dad0b08c5d61.changelog.crc │ │ │ │ │ │ │ ├── .4_c5744ef8-4613-44ed-a839-f601421b2066.changelog.crc │ │ │ │ │ │ │ ├── .4_c5744ef8-4613-44ed-a839-f601421b2066.zip.crc │ │ │ │ │ │ │ ├── .5_2d33cccf-8c58-401d-9566-c7312863d0f9.changelog.crc │ │ │ │ │ │ │ ├── 1_ffe70db3-f62b-494c-bca0-bdfe4b03eb2d.changelog │ │ │ │ │ │ │ ├── 2_b9c6d162-2375-4be1-af05-86fae13a9a5d.changelog │ │ │ │ │ │ │ ├── 2_b9c6d162-2375-4be1-af05-86fae13a9a5d.zip │ │ │ │ │ │ │ ├── 3_1455e423-44ab-4686-bef0-dad0b08c5d61.changelog │ │ │ │ │ │ │ ├── 4_c5744ef8-4613-44ed-a839-f601421b2066.changelog │ │ │ │ │ │ │ ├── 4_c5744ef8-4613-44ed-a839-f601421b2066.zip │ │ │ │ │ │ │ ├── 5_2d33cccf-8c58-401d-9566-c7312863d0f9.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_098158a2-78b1-4c85-84b2-6cec7026b7f4.changelog.crc │ │ │ │ │ │ │ ├── .2_c1a3baa8-f5f7-465d-90da-1632c1338025.changelog.crc │ │ │ │ │ │ │ ├── .2_c1a3baa8-f5f7-465d-90da-1632c1338025.zip.crc │ │ │ │ │ │ │ ├── .3_207be0af-e21b-460f-9438-133098ee72da.changelog.crc │ │ │ │ │ │ │ ├── .4_07e09eb7-d18c-446a-aa24-95f4dfbcc955.changelog.crc │ │ │ │ │ │ │ ├── .4_07e09eb7-d18c-446a-aa24-95f4dfbcc955.zip.crc │ │ │ │ │ │ │ ├── .5_b34b885b-40c3-4aab-a79f-27e9f99b9818.changelog.crc │ │ │ │ │ │ │ ├── 1_098158a2-78b1-4c85-84b2-6cec7026b7f4.changelog │ │ │ │ │ │ │ ├── 2_c1a3baa8-f5f7-465d-90da-1632c1338025.changelog │ │ │ │ │ │ │ ├── 2_c1a3baa8-f5f7-465d-90da-1632c1338025.zip │ │ │ │ │ │ │ ├── 3_207be0af-e21b-460f-9438-133098ee72da.changelog │ │ │ │ │ │ │ ├── 4_07e09eb7-d18c-446a-aa24-95f4dfbcc955.changelog │ │ │ │ │ │ │ ├── 4_07e09eb7-d18c-446a-aa24-95f4dfbcc955.zip │ │ │ │ │ │ │ ├── 5_b34b885b-40c3-4aab-a79f-27e9f99b9818.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_c2684cbe-1829-4cec-945d-8e07981680dc.changelog.crc │ │ │ │ │ │ │ ├── .2_58bb5df1-d456-42c0-9539-01a4bfaa58bc.changelog.crc │ │ │ │ │ │ │ ├── .2_58bb5df1-d456-42c0-9539-01a4bfaa58bc.zip.crc │ │ │ │ │ │ │ ├── .3_d96d5604-d1bd-43f2-a1ec-6c4fbfe48fce.changelog.crc │ │ │ │ │ │ │ ├── .4_6d3cbb7b-6551-41b0-8985-dcd69ce7ef51.changelog.crc │ │ │ │ │ │ │ ├── .4_6d3cbb7b-6551-41b0-8985-dcd69ce7ef51.zip.crc │ │ │ │ │ │ │ ├── .5_9dfb1bed-1696-4184-8a95-54a52f457134.changelog.crc │ │ │ │ │ │ │ ├── 1_c2684cbe-1829-4cec-945d-8e07981680dc.changelog │ │ │ │ │ │ │ ├── 2_58bb5df1-d456-42c0-9539-01a4bfaa58bc.changelog │ │ │ │ │ │ │ ├── 2_58bb5df1-d456-42c0-9539-01a4bfaa58bc.zip │ │ │ │ │ │ │ ├── 3_d96d5604-d1bd-43f2-a1ec-6c4fbfe48fce.changelog │ │ │ │ │ │ │ ├── 4_6d3cbb7b-6551-41b0-8985-dcd69ce7ef51.changelog │ │ │ │ │ │ │ ├── 4_6d3cbb7b-6551-41b0-8985-dcd69ce7ef51.zip │ │ │ │ │ │ │ └── 5_9dfb1bed-1696-4184-8a95-54a52f457134.changelog │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_a38d761c-9f5d-474f-b052-8f88bb31891d.changelog.crc │ │ │ │ │ │ │ ├── .2_765e6af2-eb8e-4969-a89d-8141dee4eb17.changelog.crc │ │ │ │ │ │ │ ├── .2_765e6af2-eb8e-4969-a89d-8141dee4eb17.zip.crc │ │ │ │ │ │ │ ├── .3_93714ff3-d8af-4320-9649-a09d289e64e6.changelog.crc │ │ │ │ │ │ │ ├── .4_c984dd0c-9c5d-42d1-b258-25f54d0188b9.changelog.crc │ │ │ │ │ │ │ ├── .4_c984dd0c-9c5d-42d1-b258-25f54d0188b9.zip.crc │ │ │ │ │ │ │ ├── .5_85c1b24d-fd7c-42a1-b690-84aaf28673b3.changelog.crc │ │ │ │ │ │ │ ├── 1_a38d761c-9f5d-474f-b052-8f88bb31891d.changelog │ │ │ │ │ │ │ ├── 2_765e6af2-eb8e-4969-a89d-8141dee4eb17.changelog │ │ │ │ │ │ │ ├── 2_765e6af2-eb8e-4969-a89d-8141dee4eb17.zip │ │ │ │ │ │ │ ├── 3_93714ff3-d8af-4320-9649-a09d289e64e6.changelog │ │ │ │ │ │ │ ├── 4_c984dd0c-9c5d-42d1-b258-25f54d0188b9.changelog │ │ │ │ │ │ │ ├── 4_c984dd0c-9c5d-42d1-b258-25f54d0188b9.zip │ │ │ │ │ │ │ └── 5_85c1b24d-fd7c-42a1-b690-84aaf28673b3.changelog │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_a59ba75e-5cd2-45de-9178-bcfd6b8ff2c3.changelog.crc │ │ │ │ │ │ │ ├── .2_7685c7e7-fe78-4a76-b636-a05e76a9e8f2.changelog.crc │ │ │ │ │ │ │ ├── .2_7685c7e7-fe78-4a76-b636-a05e76a9e8f2.zip.crc │ │ │ │ │ │ │ ├── .3_cdca122e-527e-4f94-bf9a-f610b6a5f947.changelog.crc │ │ │ │ │ │ │ ├── .4_31564b0f-ca7d-4378-b27d-809b16a7e686.changelog.crc │ │ │ │ │ │ │ ├── .4_31564b0f-ca7d-4378-b27d-809b16a7e686.zip.crc │ │ │ │ │ │ │ ├── .5_a4df1a9a-b945-4728-9b28-b66f00c61baa.changelog.crc │ │ │ │ │ │ │ ├── 1_a59ba75e-5cd2-45de-9178-bcfd6b8ff2c3.changelog │ │ │ │ │ │ │ ├── 2_7685c7e7-fe78-4a76-b636-a05e76a9e8f2.changelog │ │ │ │ │ │ │ ├── 2_7685c7e7-fe78-4a76-b636-a05e76a9e8f2.zip │ │ │ │ │ │ │ ├── 3_cdca122e-527e-4f94-bf9a-f610b6a5f947.changelog │ │ │ │ │ │ │ ├── 4_31564b0f-ca7d-4378-b27d-809b16a7e686.changelog │ │ │ │ │ │ │ ├── 4_31564b0f-ca7d-4378-b27d-809b16a7e686.zip │ │ │ │ │ │ │ └── 5_a4df1a9a-b945-4728-9b28-b66f00c61baa.changelog │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_9178d3bc-b013-4b8b-9824-cd60cafb2151.changelog.crc │ │ │ │ │ │ │ ├── .2_7e07e11b-ba06-4f43-81ee-1f5105724d16.changelog.crc │ │ │ │ │ │ │ ├── .2_7e07e11b-ba06-4f43-81ee-1f5105724d16.zip.crc │ │ │ │ │ │ │ ├── .3_c5a6d372-4ed8-42cc-a66b-f9c0c4efb522.changelog.crc │ │ │ │ │ │ │ ├── .4_71cdd9b7-a8c2-489e-a128-32cc5e2b123a.changelog.crc │ │ │ │ │ │ │ ├── .4_71cdd9b7-a8c2-489e-a128-32cc5e2b123a.zip.crc │ │ │ │ │ │ │ ├── .5_c190575f-976f-4d9e-9298-7f852778d0ce.changelog.crc │ │ │ │ │ │ │ ├── 1_9178d3bc-b013-4b8b-9824-cd60cafb2151.changelog │ │ │ │ │ │ │ ├── 2_7e07e11b-ba06-4f43-81ee-1f5105724d16.changelog │ │ │ │ │ │ │ ├── 2_7e07e11b-ba06-4f43-81ee-1f5105724d16.zip │ │ │ │ │ │ │ ├── 3_c5a6d372-4ed8-42cc-a66b-f9c0c4efb522.changelog │ │ │ │ │ │ │ ├── 4_71cdd9b7-a8c2-489e-a128-32cc5e2b123a.changelog │ │ │ │ │ │ │ ├── 4_71cdd9b7-a8c2-489e-a128-32cc5e2b123a.zip │ │ │ │ │ │ │ └── 5_c190575f-976f-4d9e-9298-7f852778d0ce.changelog │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_1907b159-8e61-4610-bdd6-a82ca6f38da5.changelog.crc │ │ │ │ │ │ │ ├── .2_bb7de60e-7fc1-423f-86df-4027eadcbbba.changelog.crc │ │ │ │ │ │ │ ├── .2_bb7de60e-7fc1-423f-86df-4027eadcbbba.zip.crc │ │ │ │ │ │ │ ├── .3_49dedebf-166e-4f97-8a00-bd76ab11b41e.changelog.crc │ │ │ │ │ │ │ ├── .4_4d986b34-1ea3-489e-ae16-1214a0dbbc7b.changelog.crc │ │ │ │ │ │ │ ├── .4_4d986b34-1ea3-489e-ae16-1214a0dbbc7b.zip.crc │ │ │ │ │ │ │ ├── .5_d0ced361-ea40-4eaa-9647-f3d85228ba6c.changelog.crc │ │ │ │ │ │ │ ├── 1_1907b159-8e61-4610-bdd6-a82ca6f38da5.changelog │ │ │ │ │ │ │ ├── 2_bb7de60e-7fc1-423f-86df-4027eadcbbba.changelog │ │ │ │ │ │ │ ├── 2_bb7de60e-7fc1-423f-86df-4027eadcbbba.zip │ │ │ │ │ │ │ ├── 3_49dedebf-166e-4f97-8a00-bd76ab11b41e.changelog │ │ │ │ │ │ │ ├── 4_4d986b34-1ea3-489e-ae16-1214a0dbbc7b.changelog │ │ │ │ │ │ │ ├── 4_4d986b34-1ea3-489e-ae16-1214a0dbbc7b.zip │ │ │ │ │ │ │ ├── 5_d0ced361-ea40-4eaa-9647-f3d85228ba6c.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-1eec3806-9939-4b13-b1dd-d723956b6dea.sst.crc │ │ │ │ │ │ │ │ └── 000008-1eec3806-9939-4b13-b1dd-d723956b6dea.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_9f9d94cb-ed49-403a-a9cd-dfda232d9485.changelog.crc │ │ │ │ │ │ │ ├── .2_6225c438-35c9-421d-8fa7-311f9bf89b5c.changelog.crc │ │ │ │ │ │ │ ├── .2_6225c438-35c9-421d-8fa7-311f9bf89b5c.zip.crc │ │ │ │ │ │ │ ├── .3_4400d93a-91df-4e1a-a210-0e94c07a8dbb.changelog.crc │ │ │ │ │ │ │ ├── .4_472f5f70-3384-4ddc-a7d6-2b182df8c729.changelog.crc │ │ │ │ │ │ │ ├── .4_472f5f70-3384-4ddc-a7d6-2b182df8c729.zip.crc │ │ │ │ │ │ │ ├── .5_a62bfa7f-e29e-42b5-a4f2-51593b2dc9bf.changelog.crc │ │ │ │ │ │ │ ├── 1_9f9d94cb-ed49-403a-a9cd-dfda232d9485.changelog │ │ │ │ │ │ │ ├── 2_6225c438-35c9-421d-8fa7-311f9bf89b5c.changelog │ │ │ │ │ │ │ ├── 2_6225c438-35c9-421d-8fa7-311f9bf89b5c.zip │ │ │ │ │ │ │ ├── 3_4400d93a-91df-4e1a-a210-0e94c07a8dbb.changelog │ │ │ │ │ │ │ ├── 4_472f5f70-3384-4ddc-a7d6-2b182df8c729.changelog │ │ │ │ │ │ │ ├── 4_472f5f70-3384-4ddc-a7d6-2b182df8c729.zip │ │ │ │ │ │ │ ├── 5_a62bfa7f-e29e-42b5-a4f2-51593b2dc9bf.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-554c9da1-e4f8-4029-befd-b7d746125b7b.sst.crc │ │ │ │ │ │ │ │ └── 000008-554c9da1-e4f8-4029-befd-b7d746125b7b.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_3f4088b2-07e9-40a4-ab7f-325f53aa522d.changelog.crc │ │ │ │ │ │ │ ├── .2_c919b4ed-56ed-4e9d-a84f-d10a583c3176.changelog.crc │ │ │ │ │ │ │ ├── .2_c919b4ed-56ed-4e9d-a84f-d10a583c3176.zip.crc │ │ │ │ │ │ │ ├── .3_4cf8a931-fed7-4ec4-b007-3279c0fabd58.changelog.crc │ │ │ │ │ │ │ ├── .4_4f8cea8d-08d1-4394-b161-40b73a4153f6.changelog.crc │ │ │ │ │ │ │ ├── .4_4f8cea8d-08d1-4394-b161-40b73a4153f6.zip.crc │ │ │ │ │ │ │ ├── .5_ded695aa-21b8-4628-a14d-1ca366cf1773.changelog.crc │ │ │ │ │ │ │ ├── 1_3f4088b2-07e9-40a4-ab7f-325f53aa522d.changelog │ │ │ │ │ │ │ ├── 2_c919b4ed-56ed-4e9d-a84f-d10a583c3176.changelog │ │ │ │ │ │ │ ├── 2_c919b4ed-56ed-4e9d-a84f-d10a583c3176.zip │ │ │ │ │ │ │ ├── 3_4cf8a931-fed7-4ec4-b007-3279c0fabd58.changelog │ │ │ │ │ │ │ ├── 4_4f8cea8d-08d1-4394-b161-40b73a4153f6.changelog │ │ │ │ │ │ │ ├── 4_4f8cea8d-08d1-4394-b161-40b73a4153f6.zip │ │ │ │ │ │ │ ├── 5_ded695aa-21b8-4628-a14d-1ca366cf1773.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-adce55b9-ad43-4c80-b36e-c5607c6a5496.sst.crc │ │ │ │ │ │ │ │ ├── .000009-78ccbc50-5b9a-46da-b748-81ebe5ef3da5.sst.crc │ │ │ │ │ │ │ │ ├── 000008-adce55b9-ad43-4c80-b36e-c5607c6a5496.sst │ │ │ │ │ │ │ │ └── 000009-78ccbc50-5b9a-46da-b748-81ebe5ef3da5.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_e35bf8e0-2df3-4d07-905c-294acf5c1972.changelog.crc │ │ │ │ │ │ │ ├── .2_a6f41760-bb3a-4f66-8eac-b5b29989e4b5.changelog.crc │ │ │ │ │ │ │ ├── .2_a6f41760-bb3a-4f66-8eac-b5b29989e4b5.zip.crc │ │ │ │ │ │ │ ├── .3_d3e3fd82-20dd-4ab3-b517-9a7cfb2a6d30.changelog.crc │ │ │ │ │ │ │ ├── .4_3833a5e0-b36c-43c2-827b-a72f1cf73049.changelog.crc │ │ │ │ │ │ │ ├── .4_3833a5e0-b36c-43c2-827b-a72f1cf73049.zip.crc │ │ │ │ │ │ │ ├── .5_470e372e-3d2f-43f1-8e82-65f3bf2e0f66.changelog.crc │ │ │ │ │ │ │ ├── 1_e35bf8e0-2df3-4d07-905c-294acf5c1972.changelog │ │ │ │ │ │ │ ├── 2_a6f41760-bb3a-4f66-8eac-b5b29989e4b5.changelog │ │ │ │ │ │ │ ├── 2_a6f41760-bb3a-4f66-8eac-b5b29989e4b5.zip │ │ │ │ │ │ │ ├── 3_d3e3fd82-20dd-4ab3-b517-9a7cfb2a6d30.changelog │ │ │ │ │ │ │ ├── 4_3833a5e0-b36c-43c2-827b-a72f1cf73049.changelog │ │ │ │ │ │ │ ├── 4_3833a5e0-b36c-43c2-827b-a72f1cf73049.zip │ │ │ │ │ │ │ ├── 5_470e372e-3d2f-43f1-8e82-65f3bf2e0f66.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-d6f61c55-baee-4e82-8e1c-8413214bb7f6.sst.crc │ │ │ │ │ │ │ ├── .000009-df702d5a-2471-40ba-9bd2-01863321f4f4.sst.crc │ │ │ │ │ │ │ ├── 000008-d6f61c55-baee-4e82-8e1c-8413214bb7f6.sst │ │ │ │ │ │ │ └── 000009-df702d5a-2471-40ba-9bd2-01863321f4f4.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_11c4ae69-0043-4d0a-8435-43ed3917beea.changelog.crc │ │ │ │ │ │ │ ├── .2_ea813f1a-96a7-4326-a28c-906a78c61e06.changelog.crc │ │ │ │ │ │ │ ├── .2_ea813f1a-96a7-4326-a28c-906a78c61e06.zip.crc │ │ │ │ │ │ │ ├── .3_ea6cc9aa-d08b-459a-ba39-d9a3a8e00fc3.changelog.crc │ │ │ │ │ │ │ ├── .4_68d23059-2ad1-4ed4-ad24-1b5b696b9ec7.changelog.crc │ │ │ │ │ │ │ ├── .4_68d23059-2ad1-4ed4-ad24-1b5b696b9ec7.zip.crc │ │ │ │ │ │ │ ├── .5_4531ecd4-1b98-4793-ac78-da5ac0ec7e7c.changelog.crc │ │ │ │ │ │ │ ├── 1_11c4ae69-0043-4d0a-8435-43ed3917beea.changelog │ │ │ │ │ │ │ ├── 2_ea813f1a-96a7-4326-a28c-906a78c61e06.changelog │ │ │ │ │ │ │ ├── 2_ea813f1a-96a7-4326-a28c-906a78c61e06.zip │ │ │ │ │ │ │ ├── 3_ea6cc9aa-d08b-459a-ba39-d9a3a8e00fc3.changelog │ │ │ │ │ │ │ ├── 4_68d23059-2ad1-4ed4-ad24-1b5b696b9ec7.changelog │ │ │ │ │ │ │ ├── 4_68d23059-2ad1-4ed4-ad24-1b5b696b9ec7.zip │ │ │ │ │ │ │ ├── 5_4531ecd4-1b98-4793-ac78-da5ac0ec7e7c.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-db4557c2-0ff3-47dd-9693-d74cb46fa966.sst.crc │ │ │ │ │ │ │ │ ├── .000009-291f6422-3c94-4ae3-8b72-e7496c667b9f.sst.crc │ │ │ │ │ │ │ │ ├── 000008-db4557c2-0ff3-47dd-9693-d74cb46fa966.sst │ │ │ │ │ │ │ │ └── 000009-291f6422-3c94-4ae3-8b72-e7496c667b9f.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_eed857a8-176f-44fd-8756-6c7275cf3327.changelog.crc │ │ │ │ │ │ │ ├── .2_1da87f15-0019-465f-82fb-b904b1db9033.changelog.crc │ │ │ │ │ │ │ ├── .2_1da87f15-0019-465f-82fb-b904b1db9033.zip.crc │ │ │ │ │ │ │ ├── .3_c7fad650-bcba-491e-87ab-946dc0462203.changelog.crc │ │ │ │ │ │ │ ├── .4_eeb41fb7-2005-48d1-8ebe-fc4540c8e53b.changelog.crc │ │ │ │ │ │ │ ├── .4_eeb41fb7-2005-48d1-8ebe-fc4540c8e53b.zip.crc │ │ │ │ │ │ │ ├── .5_8683c28d-8fcf-48d2-8b3f-6d1834c5968c.changelog.crc │ │ │ │ │ │ │ ├── 1_eed857a8-176f-44fd-8756-6c7275cf3327.changelog │ │ │ │ │ │ │ ├── 2_1da87f15-0019-465f-82fb-b904b1db9033.changelog │ │ │ │ │ │ │ ├── 2_1da87f15-0019-465f-82fb-b904b1db9033.zip │ │ │ │ │ │ │ ├── 3_c7fad650-bcba-491e-87ab-946dc0462203.changelog │ │ │ │ │ │ │ ├── 4_eeb41fb7-2005-48d1-8ebe-fc4540c8e53b.changelog │ │ │ │ │ │ │ ├── 4_eeb41fb7-2005-48d1-8ebe-fc4540c8e53b.zip │ │ │ │ │ │ │ ├── 5_8683c28d-8fcf-48d2-8b3f-6d1834c5968c.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-2fb6d645-9618-43db-9d98-feb1f2dc1b53.sst.crc │ │ │ │ │ │ │ │ ├── .000009-84827ac9-d4c5-4ac4-a210-a1996e7ee85b.sst.crc │ │ │ │ │ │ │ │ ├── 000008-2fb6d645-9618-43db-9d98-feb1f2dc1b53.sst │ │ │ │ │ │ │ │ └── 000009-84827ac9-d4c5-4ac4-a210-a1996e7ee85b.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_664bf358-72e1-47ff-b8e0-596947b064a6.changelog.crc │ │ │ │ │ │ │ ├── .2_a18db5f8-577a-4c7e-b893-b1c9121c461e.changelog.crc │ │ │ │ │ │ │ ├── .2_a18db5f8-577a-4c7e-b893-b1c9121c461e.zip.crc │ │ │ │ │ │ │ ├── .3_0e6f4a80-ba3d-40e2-82c4-bfbd226f8a41.changelog.crc │ │ │ │ │ │ │ ├── .4_f8d667d0-9fc7-48c8-9662-244db0e2a7b6.changelog.crc │ │ │ │ │ │ │ ├── .4_f8d667d0-9fc7-48c8-9662-244db0e2a7b6.zip.crc │ │ │ │ │ │ │ ├── .5_3a1ef380-8c5f-4e6a-9d8d-128db68849f9.changelog.crc │ │ │ │ │ │ │ ├── 1_664bf358-72e1-47ff-b8e0-596947b064a6.changelog │ │ │ │ │ │ │ ├── 2_a18db5f8-577a-4c7e-b893-b1c9121c461e.changelog │ │ │ │ │ │ │ ├── 2_a18db5f8-577a-4c7e-b893-b1c9121c461e.zip │ │ │ │ │ │ │ ├── 3_0e6f4a80-ba3d-40e2-82c4-bfbd226f8a41.changelog │ │ │ │ │ │ │ ├── 4_f8d667d0-9fc7-48c8-9662-244db0e2a7b6.changelog │ │ │ │ │ │ │ ├── 4_f8d667d0-9fc7-48c8-9662-244db0e2a7b6.zip │ │ │ │ │ │ │ ├── 5_3a1ef380-8c5f-4e6a-9d8d-128db68849f9.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-c7bd2c00-b411-4413-8a97-7bc2c5aca28f.sst.crc │ │ │ │ │ │ │ │ ├── .000009-f4e35243-d651-435e-8a42-91f15b4a241e.sst.crc │ │ │ │ │ │ │ │ ├── 000008-c7bd2c00-b411-4413-8a97-7bc2c5aca28f.sst │ │ │ │ │ │ │ │ └── 000009-f4e35243-d651-435e-8a42-91f15b4a241e.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_c0055433-df0b-4456-ab34-2bf8efd2b687.changelog.crc │ │ │ │ │ │ │ ├── .2_8a8c64d1-b579-4b5c-9ffa-312d7c42de3f.changelog.crc │ │ │ │ │ │ │ ├── .2_8a8c64d1-b579-4b5c-9ffa-312d7c42de3f.zip.crc │ │ │ │ │ │ │ ├── .3_d6a0dcd6-2657-4879-b528-9cb21208bdbe.changelog.crc │ │ │ │ │ │ │ ├── .4_c5711e4e-9488-4944-9845-feda3b8aa10c.changelog.crc │ │ │ │ │ │ │ ├── .4_c5711e4e-9488-4944-9845-feda3b8aa10c.zip.crc │ │ │ │ │ │ │ ├── .5_e2553009-8003-4c43-9d2a-540f865f1e0d.changelog.crc │ │ │ │ │ │ │ ├── 1_c0055433-df0b-4456-ab34-2bf8efd2b687.changelog │ │ │ │ │ │ │ ├── 2_8a8c64d1-b579-4b5c-9ffa-312d7c42de3f.changelog │ │ │ │ │ │ │ ├── 2_8a8c64d1-b579-4b5c-9ffa-312d7c42de3f.zip │ │ │ │ │ │ │ ├── 3_d6a0dcd6-2657-4879-b528-9cb21208bdbe.changelog │ │ │ │ │ │ │ ├── 4_c5711e4e-9488-4944-9845-feda3b8aa10c.changelog │ │ │ │ │ │ │ ├── 4_c5711e4e-9488-4944-9845-feda3b8aa10c.zip │ │ │ │ │ │ │ ├── 5_e2553009-8003-4c43-9d2a-540f865f1e0d.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-d41a4c93-56ea-4814-8e7a-f92bd6c9da7e.sst.crc │ │ │ │ │ │ │ ├── .000009-cd157803-2739-45a3-8b5f-25ac0b8e9ae5.sst.crc │ │ │ │ │ │ │ ├── 000008-d41a4c93-56ea-4814-8e7a-f92bd6c9da7e.sst │ │ │ │ │ │ │ └── 000009-cd157803-2739-45a3-8b5f-25ac0b8e9ae5.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_9d2ab98c-6788-4891-9688-21e1711f1654.changelog.crc │ │ │ │ │ │ │ ├── .2_1f16fe91-b66d-4297-b2ab-8d4a3d7ee93a.changelog.crc │ │ │ │ │ │ │ ├── .2_1f16fe91-b66d-4297-b2ab-8d4a3d7ee93a.zip.crc │ │ │ │ │ │ │ ├── .3_d395f05b-3513-4b82-b8ae-508f84a0152f.changelog.crc │ │ │ │ │ │ │ ├── .4_e23790f1-6d21-48b4-af3d-59eb348b81e0.changelog.crc │ │ │ │ │ │ │ ├── .4_e23790f1-6d21-48b4-af3d-59eb348b81e0.zip.crc │ │ │ │ │ │ │ ├── .5_9d1bda14-3036-434c-a59f-fe19c1cd06dd.changelog.crc │ │ │ │ │ │ │ ├── 1_9d2ab98c-6788-4891-9688-21e1711f1654.changelog │ │ │ │ │ │ │ ├── 2_1f16fe91-b66d-4297-b2ab-8d4a3d7ee93a.changelog │ │ │ │ │ │ │ ├── 2_1f16fe91-b66d-4297-b2ab-8d4a3d7ee93a.zip │ │ │ │ │ │ │ ├── 3_d395f05b-3513-4b82-b8ae-508f84a0152f.changelog │ │ │ │ │ │ │ ├── 4_e23790f1-6d21-48b4-af3d-59eb348b81e0.changelog │ │ │ │ │ │ │ ├── 4_e23790f1-6d21-48b4-af3d-59eb348b81e0.zip │ │ │ │ │ │ │ ├── 5_9d1bda14-3036-434c-a59f-fe19c1cd06dd.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-aaa7a37c-7534-4abc-b568-992091dba204.sst.crc │ │ │ │ │ │ │ │ ├── .000009-31df202d-bd1b-44cc-a0c2-765d538ce070.sst.crc │ │ │ │ │ │ │ │ ├── 000008-aaa7a37c-7534-4abc-b568-992091dba204.sst │ │ │ │ │ │ │ │ └── 000009-31df202d-bd1b-44cc-a0c2-765d538ce070.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_ba57ef25-7306-4569-a2f4-356b264b3f9e.changelog.crc │ │ │ │ │ │ │ ├── .2_6eb97e10-ef16-4d6d-a8b6-7eaf720b2e5a.changelog.crc │ │ │ │ │ │ │ ├── .2_6eb97e10-ef16-4d6d-a8b6-7eaf720b2e5a.zip.crc │ │ │ │ │ │ │ ├── .3_4809b4df-4dc4-4173-af9c-c4585ce3d5cf.changelog.crc │ │ │ │ │ │ │ ├── .4_e9342296-3ef5-46c8-99b1-f4f57a196c1b.changelog.crc │ │ │ │ │ │ │ ├── .4_e9342296-3ef5-46c8-99b1-f4f57a196c1b.zip.crc │ │ │ │ │ │ │ ├── .5_5c11c009-30c0-474d-a236-9435dd740e3d.changelog.crc │ │ │ │ │ │ │ ├── 1_ba57ef25-7306-4569-a2f4-356b264b3f9e.changelog │ │ │ │ │ │ │ ├── 2_6eb97e10-ef16-4d6d-a8b6-7eaf720b2e5a.changelog │ │ │ │ │ │ │ ├── 2_6eb97e10-ef16-4d6d-a8b6-7eaf720b2e5a.zip │ │ │ │ │ │ │ ├── 3_4809b4df-4dc4-4173-af9c-c4585ce3d5cf.changelog │ │ │ │ │ │ │ ├── 4_e9342296-3ef5-46c8-99b1-f4f57a196c1b.changelog │ │ │ │ │ │ │ ├── 4_e9342296-3ef5-46c8-99b1-f4f57a196c1b.zip │ │ │ │ │ │ │ ├── 5_5c11c009-30c0-474d-a236-9435dd740e3d.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-1027a1ac-be30-467a-8547-7e5cb9b676f2.sst.crc │ │ │ │ │ │ │ │ ├── .000009-42c20e05-b298-44c9-b37b-45fb50d9f4bc.sst.crc │ │ │ │ │ │ │ │ ├── 000008-1027a1ac-be30-467a-8547-7e5cb9b676f2.sst │ │ │ │ │ │ │ │ └── 000009-42c20e05-b298-44c9-b37b-45fb50d9f4bc.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_7743ec6a-7958-497b-9c06-c54de516a1e9.changelog.crc │ │ │ │ │ │ │ ├── .2_97068b99-5d37-4226-94cc-4466312f6df1.changelog.crc │ │ │ │ │ │ │ ├── .2_97068b99-5d37-4226-94cc-4466312f6df1.zip.crc │ │ │ │ │ │ │ ├── .3_07c9f7e6-dceb-4bf1-a510-b806b37784e1.changelog.crc │ │ │ │ │ │ │ ├── .4_1ccbfd5b-1c88-499e-a809-53413a7fcdc7.changelog.crc │ │ │ │ │ │ │ ├── .4_1ccbfd5b-1c88-499e-a809-53413a7fcdc7.zip.crc │ │ │ │ │ │ │ ├── .5_1b44bee1-d9c4-44ba-9932-2e5e40bb4012.changelog.crc │ │ │ │ │ │ │ ├── 1_7743ec6a-7958-497b-9c06-c54de516a1e9.changelog │ │ │ │ │ │ │ ├── 2_97068b99-5d37-4226-94cc-4466312f6df1.changelog │ │ │ │ │ │ │ ├── 2_97068b99-5d37-4226-94cc-4466312f6df1.zip │ │ │ │ │ │ │ ├── 3_07c9f7e6-dceb-4bf1-a510-b806b37784e1.changelog │ │ │ │ │ │ │ ├── 4_1ccbfd5b-1c88-499e-a809-53413a7fcdc7.changelog │ │ │ │ │ │ │ ├── 4_1ccbfd5b-1c88-499e-a809-53413a7fcdc7.zip │ │ │ │ │ │ │ ├── 5_1b44bee1-d9c4-44ba-9932-2e5e40bb4012.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-11ebed3c-8b32-450e-8e7e-857a89ed9016.sst.crc │ │ │ │ │ │ │ │ ├── .000009-13f62a6e-72cd-4180-b730-ff7a9ffb8fb3.sst.crc │ │ │ │ │ │ │ │ ├── 000008-11ebed3c-8b32-450e-8e7e-857a89ed9016.sst │ │ │ │ │ │ │ │ └── 000009-13f62a6e-72cd-4180-b730-ff7a9ffb8fb3.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_20966a32-f99b-460b-bde1-6b8f7193384e.changelog.crc │ │ │ │ │ │ │ ├── .2_7576c9f4-254f-46cc-a3d5-3c1b4997921d.changelog.crc │ │ │ │ │ │ │ ├── .2_7576c9f4-254f-46cc-a3d5-3c1b4997921d.zip.crc │ │ │ │ │ │ │ ├── .3_fe6e9401-af4c-4580-b3e2-c1940306fde9.changelog.crc │ │ │ │ │ │ │ ├── .4_14b4f589-7af6-405c-a475-1bfad6ab6f66.changelog.crc │ │ │ │ │ │ │ ├── .4_14b4f589-7af6-405c-a475-1bfad6ab6f66.zip.crc │ │ │ │ │ │ │ ├── .5_3fa68cc1-d964-4f4e-bb9d-fd1ec2c73bbc.changelog.crc │ │ │ │ │ │ │ ├── 1_20966a32-f99b-460b-bde1-6b8f7193384e.changelog │ │ │ │ │ │ │ ├── 2_7576c9f4-254f-46cc-a3d5-3c1b4997921d.changelog │ │ │ │ │ │ │ ├── 2_7576c9f4-254f-46cc-a3d5-3c1b4997921d.zip │ │ │ │ │ │ │ ├── 3_fe6e9401-af4c-4580-b3e2-c1940306fde9.changelog │ │ │ │ │ │ │ ├── 4_14b4f589-7af6-405c-a475-1bfad6ab6f66.changelog │ │ │ │ │ │ │ ├── 4_14b4f589-7af6-405c-a475-1bfad6ab6f66.zip │ │ │ │ │ │ │ ├── 5_3fa68cc1-d964-4f4e-bb9d-fd1ec2c73bbc.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-39d85a72-b066-4941-a2cb-24e2736d4c72.sst.crc │ │ │ │ │ │ │ ├── .000009-059f01f1-53a6-46bb-b063-79f7b19be31a.sst.crc │ │ │ │ │ │ │ ├── 000008-39d85a72-b066-4941-a2cb-24e2736d4c72.sst │ │ │ │ │ │ │ └── 000009-059f01f1-53a6-46bb-b063-79f7b19be31a.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── join2 │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── .0.crc │ │ │ │ │ │ ├── .1.crc │ │ │ │ │ │ ├── .2.crc │ │ │ │ │ │ ├── .3.crc │ │ │ │ │ │ └── .4.crc │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── .0.crc │ │ │ │ │ │ ├── .1.crc │ │ │ │ │ │ ├── .2.crc │ │ │ │ │ │ ├── .3.crc │ │ │ │ │ │ └── .4.crc │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_b1340e4c-9ae6-4996-90e5-8722346b2479.changelog.crc │ │ │ │ │ │ │ ├── .2_ca3d3f6b-86d2-4019-9661-e3c28f44bcec.changelog.crc │ │ │ │ │ │ │ ├── .2_ca3d3f6b-86d2-4019-9661-e3c28f44bcec.zip.crc │ │ │ │ │ │ │ ├── .3_64d24e92-ec7b-4c3a-b18c-587c52e7fc8b.changelog.crc │ │ │ │ │ │ │ ├── .4_2b9fa65a-4b6e-4b7c-b3a8-b5f6c92674ce.changelog.crc │ │ │ │ │ │ │ ├── .4_2b9fa65a-4b6e-4b7c-b3a8-b5f6c92674ce.zip.crc │ │ │ │ │ │ │ ├── .5_4a86866c-66fc-4f34-be50-8c4a5b4d0dbd.changelog.crc │ │ │ │ │ │ │ ├── 1_b1340e4c-9ae6-4996-90e5-8722346b2479.changelog │ │ │ │ │ │ │ ├── 2_ca3d3f6b-86d2-4019-9661-e3c28f44bcec.changelog │ │ │ │ │ │ │ ├── 2_ca3d3f6b-86d2-4019-9661-e3c28f44bcec.zip │ │ │ │ │ │ │ ├── 3_64d24e92-ec7b-4c3a-b18c-587c52e7fc8b.changelog │ │ │ │ │ │ │ ├── 4_2b9fa65a-4b6e-4b7c-b3a8-b5f6c92674ce.changelog │ │ │ │ │ │ │ ├── 4_2b9fa65a-4b6e-4b7c-b3a8-b5f6c92674ce.zip │ │ │ │ │ │ │ ├── 5_4a86866c-66fc-4f34-be50-8c4a5b4d0dbd.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_7585d20a-d6f0-41cf-9e71-68e3b8c5644f.changelog.crc │ │ │ │ │ │ │ ├── .2_81442b9a-cc25-49cf-8381-8fbaf4c39eef.changelog.crc │ │ │ │ │ │ │ ├── .2_81442b9a-cc25-49cf-8381-8fbaf4c39eef.zip.crc │ │ │ │ │ │ │ ├── .3_a342a12c-87fb-4971-b2c3-ae8836be65dc.changelog.crc │ │ │ │ │ │ │ ├── .4_5a42f5bb-8bf1-4b0f-880c-e1dc216bc60d.changelog.crc │ │ │ │ │ │ │ ├── .4_5a42f5bb-8bf1-4b0f-880c-e1dc216bc60d.zip.crc │ │ │ │ │ │ │ ├── .5_cb8a3678-3010-44ea-bdaa-964654ecf177.changelog.crc │ │ │ │ │ │ │ ├── 1_7585d20a-d6f0-41cf-9e71-68e3b8c5644f.changelog │ │ │ │ │ │ │ ├── 2_81442b9a-cc25-49cf-8381-8fbaf4c39eef.changelog │ │ │ │ │ │ │ ├── 2_81442b9a-cc25-49cf-8381-8fbaf4c39eef.zip │ │ │ │ │ │ │ ├── 3_a342a12c-87fb-4971-b2c3-ae8836be65dc.changelog │ │ │ │ │ │ │ ├── 4_5a42f5bb-8bf1-4b0f-880c-e1dc216bc60d.changelog │ │ │ │ │ │ │ ├── 4_5a42f5bb-8bf1-4b0f-880c-e1dc216bc60d.zip │ │ │ │ │ │ │ ├── 5_cb8a3678-3010-44ea-bdaa-964654ecf177.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_bd638423-f644-4c1a-8c47-1e847eedb8cb.changelog.crc │ │ │ │ │ │ │ ├── .2_dda8a7f2-f740-46c1-ac0b-e7529db2c4b4.changelog.crc │ │ │ │ │ │ │ ├── .2_dda8a7f2-f740-46c1-ac0b-e7529db2c4b4.zip.crc │ │ │ │ │ │ │ ├── .3_2a6610ba-b227-4787-9738-d48f0d744d2f.changelog.crc │ │ │ │ │ │ │ ├── .4_d5a926d1-9e63-4fee-a425-384e09540459.changelog.crc │ │ │ │ │ │ │ ├── .4_d5a926d1-9e63-4fee-a425-384e09540459.zip.crc │ │ │ │ │ │ │ ├── .5_2b88860b-c125-48ac-87d3-425ddf6e471c.changelog.crc │ │ │ │ │ │ │ ├── 1_bd638423-f644-4c1a-8c47-1e847eedb8cb.changelog │ │ │ │ │ │ │ ├── 2_dda8a7f2-f740-46c1-ac0b-e7529db2c4b4.changelog │ │ │ │ │ │ │ ├── 2_dda8a7f2-f740-46c1-ac0b-e7529db2c4b4.zip │ │ │ │ │ │ │ ├── 3_2a6610ba-b227-4787-9738-d48f0d744d2f.changelog │ │ │ │ │ │ │ ├── 4_d5a926d1-9e63-4fee-a425-384e09540459.changelog │ │ │ │ │ │ │ ├── 4_d5a926d1-9e63-4fee-a425-384e09540459.zip │ │ │ │ │ │ │ ├── 5_2b88860b-c125-48ac-87d3-425ddf6e471c.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_7418fa4f-8b65-4621-840c-8ccd10827a66.changelog.crc │ │ │ │ │ │ │ ├── .2_33825fa0-b170-46f9-978b-71201deb0366.changelog.crc │ │ │ │ │ │ │ ├── .2_33825fa0-b170-46f9-978b-71201deb0366.zip.crc │ │ │ │ │ │ │ ├── .3_7579774b-9f68-4ce9-87ce-c27a854a828d.changelog.crc │ │ │ │ │ │ │ ├── .4_35fc23cb-2af4-4b9e-a679-c8b6e74d5f9a.changelog.crc │ │ │ │ │ │ │ ├── .4_35fc23cb-2af4-4b9e-a679-c8b6e74d5f9a.zip.crc │ │ │ │ │ │ │ ├── .5_72b5a9b3-773a-42dc-922d-157d68115737.changelog.crc │ │ │ │ │ │ │ ├── 1_7418fa4f-8b65-4621-840c-8ccd10827a66.changelog │ │ │ │ │ │ │ ├── 2_33825fa0-b170-46f9-978b-71201deb0366.changelog │ │ │ │ │ │ │ ├── 2_33825fa0-b170-46f9-978b-71201deb0366.zip │ │ │ │ │ │ │ ├── 3_7579774b-9f68-4ce9-87ce-c27a854a828d.changelog │ │ │ │ │ │ │ ├── 4_35fc23cb-2af4-4b9e-a679-c8b6e74d5f9a.changelog │ │ │ │ │ │ │ ├── 4_35fc23cb-2af4-4b9e-a679-c8b6e74d5f9a.zip │ │ │ │ │ │ │ ├── 5_72b5a9b3-773a-42dc-922d-157d68115737.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_1d3a4687-0dc5-4aaf-b651-4fbec512caa3.changelog.crc │ │ │ │ │ │ │ ├── .2_36da6470-13be-4a0f-98ea-56af45092d66.changelog.crc │ │ │ │ │ │ │ ├── .2_36da6470-13be-4a0f-98ea-56af45092d66.zip.crc │ │ │ │ │ │ │ ├── .3_70124def-d463-49ea-ae84-43da9ebb1e25.changelog.crc │ │ │ │ │ │ │ ├── .4_a36e9ee3-bc8b-40e1-bfcf-603e77fbbcd9.changelog.crc │ │ │ │ │ │ │ ├── .4_a36e9ee3-bc8b-40e1-bfcf-603e77fbbcd9.zip.crc │ │ │ │ │ │ │ ├── .5_66bca6fb-2fc2-4720-93c1-ef40858eab1c.changelog.crc │ │ │ │ │ │ │ ├── 1_1d3a4687-0dc5-4aaf-b651-4fbec512caa3.changelog │ │ │ │ │ │ │ ├── 2_36da6470-13be-4a0f-98ea-56af45092d66.changelog │ │ │ │ │ │ │ ├── 2_36da6470-13be-4a0f-98ea-56af45092d66.zip │ │ │ │ │ │ │ ├── 3_70124def-d463-49ea-ae84-43da9ebb1e25.changelog │ │ │ │ │ │ │ ├── 4_a36e9ee3-bc8b-40e1-bfcf-603e77fbbcd9.changelog │ │ │ │ │ │ │ ├── 4_a36e9ee3-bc8b-40e1-bfcf-603e77fbbcd9.zip │ │ │ │ │ │ │ └── 5_66bca6fb-2fc2-4720-93c1-ef40858eab1c.changelog │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_d41a0fa2-2a4e-4a05-b2af-c3c4689ff02b.changelog.crc │ │ │ │ │ │ │ ├── .2_7cca0fbe-5249-4274-8628-e559914657e4.changelog.crc │ │ │ │ │ │ │ ├── .2_7cca0fbe-5249-4274-8628-e559914657e4.zip.crc │ │ │ │ │ │ │ ├── .3_873fe17b-adcf-4226-af51-177f389e533b.changelog.crc │ │ │ │ │ │ │ ├── .4_77d8d0ac-8fa8-4418-8aab-2428bf045a52.changelog.crc │ │ │ │ │ │ │ ├── .4_77d8d0ac-8fa8-4418-8aab-2428bf045a52.zip.crc │ │ │ │ │ │ │ ├── .5_c2205bd9-7413-4078-843c-6a007964b6bd.changelog.crc │ │ │ │ │ │ │ ├── 1_d41a0fa2-2a4e-4a05-b2af-c3c4689ff02b.changelog │ │ │ │ │ │ │ ├── 2_7cca0fbe-5249-4274-8628-e559914657e4.changelog │ │ │ │ │ │ │ ├── 2_7cca0fbe-5249-4274-8628-e559914657e4.zip │ │ │ │ │ │ │ ├── 3_873fe17b-adcf-4226-af51-177f389e533b.changelog │ │ │ │ │ │ │ ├── 4_77d8d0ac-8fa8-4418-8aab-2428bf045a52.changelog │ │ │ │ │ │ │ ├── 4_77d8d0ac-8fa8-4418-8aab-2428bf045a52.zip │ │ │ │ │ │ │ └── 5_c2205bd9-7413-4078-843c-6a007964b6bd.changelog │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_09b0a2bf-cda2-444c-8b27-00853a92b171.changelog.crc │ │ │ │ │ │ │ ├── .2_cc928156-e550-4f9d-b6eb-9761c113985a.changelog.crc │ │ │ │ │ │ │ ├── .2_cc928156-e550-4f9d-b6eb-9761c113985a.zip.crc │ │ │ │ │ │ │ ├── .3_f37c3da2-8834-414a-aad9-0880c82e6c9f.changelog.crc │ │ │ │ │ │ │ ├── .4_f8f5c613-413a-4e94-9ccb-76d20320031d.changelog.crc │ │ │ │ │ │ │ ├── .4_f8f5c613-413a-4e94-9ccb-76d20320031d.zip.crc │ │ │ │ │ │ │ ├── .5_2ea177e1-e3f9-416b-bd83-6ffadb5acc02.changelog.crc │ │ │ │ │ │ │ ├── 1_09b0a2bf-cda2-444c-8b27-00853a92b171.changelog │ │ │ │ │ │ │ ├── 2_cc928156-e550-4f9d-b6eb-9761c113985a.changelog │ │ │ │ │ │ │ ├── 2_cc928156-e550-4f9d-b6eb-9761c113985a.zip │ │ │ │ │ │ │ ├── 3_f37c3da2-8834-414a-aad9-0880c82e6c9f.changelog │ │ │ │ │ │ │ ├── 4_f8f5c613-413a-4e94-9ccb-76d20320031d.changelog │ │ │ │ │ │ │ ├── 4_f8f5c613-413a-4e94-9ccb-76d20320031d.zip │ │ │ │ │ │ │ └── 5_2ea177e1-e3f9-416b-bd83-6ffadb5acc02.changelog │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_c5f094d3-a3b5-4280-8070-0255280ce028.changelog.crc │ │ │ │ │ │ │ ├── .2_91ed4781-6e06-4759-b54a-ac61dd952d64.changelog.crc │ │ │ │ │ │ │ ├── .2_91ed4781-6e06-4759-b54a-ac61dd952d64.zip.crc │ │ │ │ │ │ │ ├── .3_a7966766-83a8-4547-a286-ec8d32155f24.changelog.crc │ │ │ │ │ │ │ ├── .4_d523781f-7c4b-4d5d-bb5b-d782959aec5f.changelog.crc │ │ │ │ │ │ │ ├── .4_d523781f-7c4b-4d5d-bb5b-d782959aec5f.zip.crc │ │ │ │ │ │ │ ├── .5_516aa116-7a32-4f45-9d14-3da5f77362b6.changelog.crc │ │ │ │ │ │ │ ├── 1_c5f094d3-a3b5-4280-8070-0255280ce028.changelog │ │ │ │ │ │ │ ├── 2_91ed4781-6e06-4759-b54a-ac61dd952d64.changelog │ │ │ │ │ │ │ ├── 2_91ed4781-6e06-4759-b54a-ac61dd952d64.zip │ │ │ │ │ │ │ ├── 3_a7966766-83a8-4547-a286-ec8d32155f24.changelog │ │ │ │ │ │ │ ├── 4_d523781f-7c4b-4d5d-bb5b-d782959aec5f.changelog │ │ │ │ │ │ │ ├── 4_d523781f-7c4b-4d5d-bb5b-d782959aec5f.zip │ │ │ │ │ │ │ └── 5_516aa116-7a32-4f45-9d14-3da5f77362b6.changelog │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_8c9208b9-00d8-4ca1-b7d1-bb68654fb445.changelog.crc │ │ │ │ │ │ │ ├── .2_4c0013ff-b606-4343-904d-5a298ae215bf.changelog.crc │ │ │ │ │ │ │ ├── .2_4c0013ff-b606-4343-904d-5a298ae215bf.zip.crc │ │ │ │ │ │ │ ├── .3_932ea797-a834-4b15-9b47-d64b53f29b03.changelog.crc │ │ │ │ │ │ │ ├── .4_00e47a7e-0836-4528-a51d-f561a0c4fd85.changelog.crc │ │ │ │ │ │ │ ├── .4_00e47a7e-0836-4528-a51d-f561a0c4fd85.zip.crc │ │ │ │ │ │ │ ├── .5_653ce64a-9f67-47b4-bd9b-4435f232010d.changelog.crc │ │ │ │ │ │ │ ├── 1_8c9208b9-00d8-4ca1-b7d1-bb68654fb445.changelog │ │ │ │ │ │ │ ├── 2_4c0013ff-b606-4343-904d-5a298ae215bf.changelog │ │ │ │ │ │ │ ├── 2_4c0013ff-b606-4343-904d-5a298ae215bf.zip │ │ │ │ │ │ │ ├── 3_932ea797-a834-4b15-9b47-d64b53f29b03.changelog │ │ │ │ │ │ │ ├── 4_00e47a7e-0836-4528-a51d-f561a0c4fd85.changelog │ │ │ │ │ │ │ ├── 4_00e47a7e-0836-4528-a51d-f561a0c4fd85.zip │ │ │ │ │ │ │ ├── 5_653ce64a-9f67-47b4-bd9b-4435f232010d.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-d6e0358c-52d6-4415-9396-67aeea9e6292.sst.crc │ │ │ │ │ │ │ │ └── 000008-d6e0358c-52d6-4415-9396-67aeea9e6292.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_3ef859af-c89a-404f-89ec-e1c0a05fc999.changelog.crc │ │ │ │ │ │ │ ├── .2_43552f38-571c-46ac-a5a1-29ec9c7ccd08.changelog.crc │ │ │ │ │ │ │ ├── .2_43552f38-571c-46ac-a5a1-29ec9c7ccd08.zip.crc │ │ │ │ │ │ │ ├── .3_d91227ce-1a7f-4872-967e-d817bf3096c0.changelog.crc │ │ │ │ │ │ │ ├── .4_bd867bd4-76c9-44ce-ab59-6bc78e1e3941.changelog.crc │ │ │ │ │ │ │ ├── .4_bd867bd4-76c9-44ce-ab59-6bc78e1e3941.zip.crc │ │ │ │ │ │ │ ├── .5_856bea06-199c-4bf9-95b4-e0b5fd2cf736.changelog.crc │ │ │ │ │ │ │ ├── 1_3ef859af-c89a-404f-89ec-e1c0a05fc999.changelog │ │ │ │ │ │ │ ├── 2_43552f38-571c-46ac-a5a1-29ec9c7ccd08.changelog │ │ │ │ │ │ │ ├── 2_43552f38-571c-46ac-a5a1-29ec9c7ccd08.zip │ │ │ │ │ │ │ ├── 3_d91227ce-1a7f-4872-967e-d817bf3096c0.changelog │ │ │ │ │ │ │ ├── 4_bd867bd4-76c9-44ce-ab59-6bc78e1e3941.changelog │ │ │ │ │ │ │ ├── 4_bd867bd4-76c9-44ce-ab59-6bc78e1e3941.zip │ │ │ │ │ │ │ ├── 5_856bea06-199c-4bf9-95b4-e0b5fd2cf736.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-1540ac1a-36ba-427d-b071-3b0bf47d2bec.sst.crc │ │ │ │ │ │ │ │ └── 000008-1540ac1a-36ba-427d-b071-3b0bf47d2bec.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_4cb064c2-cf82-48d0-ab28-59a823ec1d0b.changelog.crc │ │ │ │ │ │ │ ├── .2_4709e034-e7a7-4c7c-b4a5-15a54c4cb533.changelog.crc │ │ │ │ │ │ │ ├── .2_4709e034-e7a7-4c7c-b4a5-15a54c4cb533.zip.crc │ │ │ │ │ │ │ ├── .3_387cc6fd-6aea-4f31-aee6-0e4c29e094bc.changelog.crc │ │ │ │ │ │ │ ├── .4_e019a70c-e45f-4280-b140-cf32ec57225e.changelog.crc │ │ │ │ │ │ │ ├── .4_e019a70c-e45f-4280-b140-cf32ec57225e.zip.crc │ │ │ │ │ │ │ ├── .5_abd45128-2b27-4cee-8466-17cd543cdeff.changelog.crc │ │ │ │ │ │ │ ├── 1_4cb064c2-cf82-48d0-ab28-59a823ec1d0b.changelog │ │ │ │ │ │ │ ├── 2_4709e034-e7a7-4c7c-b4a5-15a54c4cb533.changelog │ │ │ │ │ │ │ ├── 2_4709e034-e7a7-4c7c-b4a5-15a54c4cb533.zip │ │ │ │ │ │ │ ├── 3_387cc6fd-6aea-4f31-aee6-0e4c29e094bc.changelog │ │ │ │ │ │ │ ├── 4_e019a70c-e45f-4280-b140-cf32ec57225e.changelog │ │ │ │ │ │ │ ├── 4_e019a70c-e45f-4280-b140-cf32ec57225e.zip │ │ │ │ │ │ │ ├── 5_abd45128-2b27-4cee-8466-17cd543cdeff.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-31297002-f2be-4930-876b-3fd459976cf1.sst.crc │ │ │ │ │ │ │ │ ├── .000009-5d5c23d2-9e22-4a53-b1cd-407d0c3a029d.sst.crc │ │ │ │ │ │ │ │ ├── 000008-31297002-f2be-4930-876b-3fd459976cf1.sst │ │ │ │ │ │ │ │ └── 000009-5d5c23d2-9e22-4a53-b1cd-407d0c3a029d.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_660629fa-ccb7-4c2e-8bd9-c0917e51d1af.changelog.crc │ │ │ │ │ │ │ ├── .2_5cb49350-1260-48c3-b546-1eb53817decd.changelog.crc │ │ │ │ │ │ │ ├── .2_5cb49350-1260-48c3-b546-1eb53817decd.zip.crc │ │ │ │ │ │ │ ├── .3_a62dab53-b8d5-4329-b21c-0ee623b350d5.changelog.crc │ │ │ │ │ │ │ ├── .4_582e56d1-6a1d-434d-9afc-c1a812b37a06.changelog.crc │ │ │ │ │ │ │ ├── .4_582e56d1-6a1d-434d-9afc-c1a812b37a06.zip.crc │ │ │ │ │ │ │ ├── .5_db88e60d-780c-42d1-bd36-50e6666b322c.changelog.crc │ │ │ │ │ │ │ ├── 1_660629fa-ccb7-4c2e-8bd9-c0917e51d1af.changelog │ │ │ │ │ │ │ ├── 2_5cb49350-1260-48c3-b546-1eb53817decd.changelog │ │ │ │ │ │ │ ├── 2_5cb49350-1260-48c3-b546-1eb53817decd.zip │ │ │ │ │ │ │ ├── 3_a62dab53-b8d5-4329-b21c-0ee623b350d5.changelog │ │ │ │ │ │ │ ├── 4_582e56d1-6a1d-434d-9afc-c1a812b37a06.changelog │ │ │ │ │ │ │ ├── 4_582e56d1-6a1d-434d-9afc-c1a812b37a06.zip │ │ │ │ │ │ │ ├── 5_db88e60d-780c-42d1-bd36-50e6666b322c.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-17a15b91-abb1-4c81-b3dd-f4e36fae53a4.sst.crc │ │ │ │ │ │ │ ├── .000009-31c31aeb-37e5-477a-a908-cdb3336b732c.sst.crc │ │ │ │ │ │ │ ├── 000008-17a15b91-abb1-4c81-b3dd-f4e36fae53a4.sst │ │ │ │ │ │ │ └── 000009-31c31aeb-37e5-477a-a908-cdb3336b732c.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_321b1232-a719-446c-b197-4627893768cb.changelog.crc │ │ │ │ │ │ │ ├── .2_8b68d3d4-01ca-478a-9968-85481070d793.changelog.crc │ │ │ │ │ │ │ ├── .2_8b68d3d4-01ca-478a-9968-85481070d793.zip.crc │ │ │ │ │ │ │ ├── .3_fef54f55-9d1b-4733-862b-c0b42a3795ae.changelog.crc │ │ │ │ │ │ │ ├── .4_3c10e0cf-023f-4dfa-bbc7-329a4c0597e8.changelog.crc │ │ │ │ │ │ │ ├── .4_3c10e0cf-023f-4dfa-bbc7-329a4c0597e8.zip.crc │ │ │ │ │ │ │ ├── .5_4b6f18f7-2fb6-470d-b1dc-447089b72b38.changelog.crc │ │ │ │ │ │ │ ├── 1_321b1232-a719-446c-b197-4627893768cb.changelog │ │ │ │ │ │ │ ├── 2_8b68d3d4-01ca-478a-9968-85481070d793.changelog │ │ │ │ │ │ │ ├── 2_8b68d3d4-01ca-478a-9968-85481070d793.zip │ │ │ │ │ │ │ ├── 3_fef54f55-9d1b-4733-862b-c0b42a3795ae.changelog │ │ │ │ │ │ │ ├── 4_3c10e0cf-023f-4dfa-bbc7-329a4c0597e8.changelog │ │ │ │ │ │ │ ├── 4_3c10e0cf-023f-4dfa-bbc7-329a4c0597e8.zip │ │ │ │ │ │ │ ├── 5_4b6f18f7-2fb6-470d-b1dc-447089b72b38.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-06ae64e9-ae38-42e3-b432-f4f0c3a2d718.sst.crc │ │ │ │ │ │ │ │ ├── .000009-6a880d8c-3efc-4d74-bddc-2470cb77191e.sst.crc │ │ │ │ │ │ │ │ ├── 000008-06ae64e9-ae38-42e3-b432-f4f0c3a2d718.sst │ │ │ │ │ │ │ │ └── 000009-6a880d8c-3efc-4d74-bddc-2470cb77191e.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_49d64c9d-21df-4dbf-ab0f-947a47b91d53.changelog.crc │ │ │ │ │ │ │ ├── .2_0229f413-f8bf-4f9c-8ea2-1148a23305a8.changelog.crc │ │ │ │ │ │ │ ├── .2_0229f413-f8bf-4f9c-8ea2-1148a23305a8.zip.crc │ │ │ │ │ │ │ ├── .3_f7a82f8a-6c01-44d7-a984-aeb298b0a5fc.changelog.crc │ │ │ │ │ │ │ ├── .4_25ef5b0c-fbc4-4568-ae87-a53235efa728.changelog.crc │ │ │ │ │ │ │ ├── .4_25ef5b0c-fbc4-4568-ae87-a53235efa728.zip.crc │ │ │ │ │ │ │ ├── .5_ffdb4256-b0da-476c-9028-7ed3233befb3.changelog.crc │ │ │ │ │ │ │ ├── 1_49d64c9d-21df-4dbf-ab0f-947a47b91d53.changelog │ │ │ │ │ │ │ ├── 2_0229f413-f8bf-4f9c-8ea2-1148a23305a8.changelog │ │ │ │ │ │ │ ├── 2_0229f413-f8bf-4f9c-8ea2-1148a23305a8.zip │ │ │ │ │ │ │ ├── 3_f7a82f8a-6c01-44d7-a984-aeb298b0a5fc.changelog │ │ │ │ │ │ │ ├── 4_25ef5b0c-fbc4-4568-ae87-a53235efa728.changelog │ │ │ │ │ │ │ ├── 4_25ef5b0c-fbc4-4568-ae87-a53235efa728.zip │ │ │ │ │ │ │ ├── 5_ffdb4256-b0da-476c-9028-7ed3233befb3.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-2872cbb8-ed4f-49b6-a758-2bd0785c9813.sst.crc │ │ │ │ │ │ │ │ ├── .000009-da165204-f078-4d4f-983a-39c581fdd01c.sst.crc │ │ │ │ │ │ │ │ ├── 000008-2872cbb8-ed4f-49b6-a758-2bd0785c9813.sst │ │ │ │ │ │ │ │ └── 000009-da165204-f078-4d4f-983a-39c581fdd01c.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_196dfd41-d84c-407a-b5c8-374ad31aee0e.changelog.crc │ │ │ │ │ │ │ ├── .2_c0169e38-57f3-4e1e-8568-24a4481bafd4.changelog.crc │ │ │ │ │ │ │ ├── .2_c0169e38-57f3-4e1e-8568-24a4481bafd4.zip.crc │ │ │ │ │ │ │ ├── .3_91a401ae-a73c-45da-a3c9-7ad53af90c6e.changelog.crc │ │ │ │ │ │ │ ├── .4_64486e03-757d-444d-80a5-81f4d10f7279.changelog.crc │ │ │ │ │ │ │ ├── .4_64486e03-757d-444d-80a5-81f4d10f7279.zip.crc │ │ │ │ │ │ │ ├── .5_14f32827-c3d9-4d85-bb6b-a61c317d06b7.changelog.crc │ │ │ │ │ │ │ ├── 1_196dfd41-d84c-407a-b5c8-374ad31aee0e.changelog │ │ │ │ │ │ │ ├── 2_c0169e38-57f3-4e1e-8568-24a4481bafd4.changelog │ │ │ │ │ │ │ ├── 2_c0169e38-57f3-4e1e-8568-24a4481bafd4.zip │ │ │ │ │ │ │ ├── 3_91a401ae-a73c-45da-a3c9-7ad53af90c6e.changelog │ │ │ │ │ │ │ ├── 4_64486e03-757d-444d-80a5-81f4d10f7279.changelog │ │ │ │ │ │ │ ├── 4_64486e03-757d-444d-80a5-81f4d10f7279.zip │ │ │ │ │ │ │ ├── 5_14f32827-c3d9-4d85-bb6b-a61c317d06b7.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-c10ffbfa-cdf0-4e28-b213-fac5e0bc17e6.sst.crc │ │ │ │ │ │ │ │ ├── .000009-66339210-614b-4efd-b3c7-3c0f154965a4.sst.crc │ │ │ │ │ │ │ │ ├── 000008-c10ffbfa-cdf0-4e28-b213-fac5e0bc17e6.sst │ │ │ │ │ │ │ │ └── 000009-66339210-614b-4efd-b3c7-3c0f154965a4.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_78ced041-0750-48e5-b2fa-36b8b6f8fa26.changelog.crc │ │ │ │ │ │ │ ├── .2_3af3c8f3-7549-4981-8084-253c807897f6.changelog.crc │ │ │ │ │ │ │ ├── .2_3af3c8f3-7549-4981-8084-253c807897f6.zip.crc │ │ │ │ │ │ │ ├── .3_36d60395-522a-4129-a324-dd41beebad34.changelog.crc │ │ │ │ │ │ │ ├── .4_61ab3c53-bbc9-44ee-b397-5622fc3e19be.changelog.crc │ │ │ │ │ │ │ ├── .4_61ab3c53-bbc9-44ee-b397-5622fc3e19be.zip.crc │ │ │ │ │ │ │ ├── .5_570cf616-6ae9-4f6d-932e-053fa820166c.changelog.crc │ │ │ │ │ │ │ ├── 1_78ced041-0750-48e5-b2fa-36b8b6f8fa26.changelog │ │ │ │ │ │ │ ├── 2_3af3c8f3-7549-4981-8084-253c807897f6.changelog │ │ │ │ │ │ │ ├── 2_3af3c8f3-7549-4981-8084-253c807897f6.zip │ │ │ │ │ │ │ ├── 3_36d60395-522a-4129-a324-dd41beebad34.changelog │ │ │ │ │ │ │ ├── 4_61ab3c53-bbc9-44ee-b397-5622fc3e19be.changelog │ │ │ │ │ │ │ ├── 4_61ab3c53-bbc9-44ee-b397-5622fc3e19be.zip │ │ │ │ │ │ │ ├── 5_570cf616-6ae9-4f6d-932e-053fa820166c.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-83e443ca-3070-4a5e-b83e-541f847e6891.sst.crc │ │ │ │ │ │ │ ├── .000009-b71420b2-2462-4e8a-a3ce-86cbf54cb3ee.sst.crc │ │ │ │ │ │ │ ├── 000008-83e443ca-3070-4a5e-b83e-541f847e6891.sst │ │ │ │ │ │ │ └── 000009-b71420b2-2462-4e8a-a3ce-86cbf54cb3ee.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── .1_0040b5e8-b186-4d97-b69a-e1d48d768d8f.changelog.crc │ │ │ │ │ │ │ ├── .2_dfea3958-bb40-48bc-bfa9-572dd76eedfd.changelog.crc │ │ │ │ │ │ │ ├── .2_dfea3958-bb40-48bc-bfa9-572dd76eedfd.zip.crc │ │ │ │ │ │ │ ├── .3_a01d7c5d-d373-4dc7-8a8f-25bf03849360.changelog.crc │ │ │ │ │ │ │ ├── .4_aeb92d41-0961-4b4c-bb6f-49b636ee728e.changelog.crc │ │ │ │ │ │ │ ├── .4_aeb92d41-0961-4b4c-bb6f-49b636ee728e.zip.crc │ │ │ │ │ │ │ ├── .5_9bd7274b-5353-4fc1-8a6b-a4a7bd1afe93.changelog.crc │ │ │ │ │ │ │ ├── 1_0040b5e8-b186-4d97-b69a-e1d48d768d8f.changelog │ │ │ │ │ │ │ ├── 2_dfea3958-bb40-48bc-bfa9-572dd76eedfd.changelog │ │ │ │ │ │ │ ├── 2_dfea3958-bb40-48bc-bfa9-572dd76eedfd.zip │ │ │ │ │ │ │ ├── 3_a01d7c5d-d373-4dc7-8a8f-25bf03849360.changelog │ │ │ │ │ │ │ ├── 4_aeb92d41-0961-4b4c-bb6f-49b636ee728e.changelog │ │ │ │ │ │ │ ├── 4_aeb92d41-0961-4b4c-bb6f-49b636ee728e.zip │ │ │ │ │ │ │ ├── 5_9bd7274b-5353-4fc1-8a6b-a4a7bd1afe93.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-935a9552-8457-47d4-a970-455d5c020652.sst.crc │ │ │ │ │ │ │ │ ├── .000009-19d0b0ea-5e91-4b32-bcfa-00d9bca85e7a.sst.crc │ │ │ │ │ │ │ │ ├── 000008-935a9552-8457-47d4-a970-455d5c020652.sst │ │ │ │ │ │ │ │ └── 000009-19d0b0ea-5e91-4b32-bcfa-00d9bca85e7a.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_469dcb5c-d2a0-4d96-805e-4460a4d4b5aa.changelog.crc │ │ │ │ │ │ │ ├── .2_b1e0c8aa-88b8-49b7-a734-bc9966161850.changelog.crc │ │ │ │ │ │ │ ├── .2_b1e0c8aa-88b8-49b7-a734-bc9966161850.zip.crc │ │ │ │ │ │ │ ├── .3_bceb4cde-7197-4db6-842d-04b3c5463505.changelog.crc │ │ │ │ │ │ │ ├── .4_5e37c9ad-9142-47cb-943c-4c2c231483c1.changelog.crc │ │ │ │ │ │ │ ├── .4_5e37c9ad-9142-47cb-943c-4c2c231483c1.zip.crc │ │ │ │ │ │ │ ├── .5_2fef25a0-611c-4bde-be77-84e6b7261698.changelog.crc │ │ │ │ │ │ │ ├── 1_469dcb5c-d2a0-4d96-805e-4460a4d4b5aa.changelog │ │ │ │ │ │ │ ├── 2_b1e0c8aa-88b8-49b7-a734-bc9966161850.changelog │ │ │ │ │ │ │ ├── 2_b1e0c8aa-88b8-49b7-a734-bc9966161850.zip │ │ │ │ │ │ │ ├── 3_bceb4cde-7197-4db6-842d-04b3c5463505.changelog │ │ │ │ │ │ │ ├── 4_5e37c9ad-9142-47cb-943c-4c2c231483c1.changelog │ │ │ │ │ │ │ ├── 4_5e37c9ad-9142-47cb-943c-4c2c231483c1.zip │ │ │ │ │ │ │ ├── 5_2fef25a0-611c-4bde-be77-84e6b7261698.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-90ff0b41-2ae4-407b-8c24-8c72b4b590f4.sst.crc │ │ │ │ │ │ │ │ ├── .000009-a9f7cde7-b941-4e5a-9f23-63d809f23377.sst.crc │ │ │ │ │ │ │ │ ├── 000008-90ff0b41-2ae4-407b-8c24-8c72b4b590f4.sst │ │ │ │ │ │ │ │ └── 000009-a9f7cde7-b941-4e5a-9f23-63d809f23377.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── .1_6f4596d1-cd7b-4881-8c8d-862d6db13b4e.changelog.crc │ │ │ │ │ │ │ ├── .2_09a46dfc-b60b-4888-b0d5-403df472a9bd.changelog.crc │ │ │ │ │ │ │ ├── .2_09a46dfc-b60b-4888-b0d5-403df472a9bd.zip.crc │ │ │ │ │ │ │ ├── .3_978ed7db-3984-4e58-9042-5bdd7f0ede44.changelog.crc │ │ │ │ │ │ │ ├── .4_de24c722-fc71-4201-83da-6b55390fe898.changelog.crc │ │ │ │ │ │ │ ├── .4_de24c722-fc71-4201-83da-6b55390fe898.zip.crc │ │ │ │ │ │ │ ├── .5_c4e584d8-814e-48ea-a413-13542733d8b7.changelog.crc │ │ │ │ │ │ │ ├── 1_6f4596d1-cd7b-4881-8c8d-862d6db13b4e.changelog │ │ │ │ │ │ │ ├── 2_09a46dfc-b60b-4888-b0d5-403df472a9bd.changelog │ │ │ │ │ │ │ ├── 2_09a46dfc-b60b-4888-b0d5-403df472a9bd.zip │ │ │ │ │ │ │ ├── 3_978ed7db-3984-4e58-9042-5bdd7f0ede44.changelog │ │ │ │ │ │ │ ├── 4_de24c722-fc71-4201-83da-6b55390fe898.changelog │ │ │ │ │ │ │ ├── 4_de24c722-fc71-4201-83da-6b55390fe898.zip │ │ │ │ │ │ │ ├── 5_c4e584d8-814e-48ea-a413-13542733d8b7.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── .000008-aae7e696-4af6-43e6-b5ca-59c18d6532c6.sst.crc │ │ │ │ │ │ │ │ ├── .000009-111105a8-7ccb-4fa9-8a45-2aedaedb5953.sst.crc │ │ │ │ │ │ │ │ ├── 000008-aae7e696-4af6-43e6-b5ca-59c18d6532c6.sst │ │ │ │ │ │ │ │ └── 000009-111105a8-7ccb-4fa9-8a45-2aedaedb5953.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── .1_bea10842-b3de-4eed-8cbb-483ce10864f7.changelog.crc │ │ │ │ │ │ │ ├── .2_17d9f074-f585-4dc6-9496-601853ae6537.changelog.crc │ │ │ │ │ │ │ ├── .2_17d9f074-f585-4dc6-9496-601853ae6537.zip.crc │ │ │ │ │ │ │ ├── .3_041cb4db-b9ab-4a99-b7b1-a114cd7544ad.changelog.crc │ │ │ │ │ │ │ ├── .4_ad8df34d-c475-47d6-ad60-3c22b00bcbb2.changelog.crc │ │ │ │ │ │ │ ├── .4_ad8df34d-c475-47d6-ad60-3c22b00bcbb2.zip.crc │ │ │ │ │ │ │ ├── .5_24c41882-0aef-4e18-a83c-dfaac502c893.changelog.crc │ │ │ │ │ │ │ ├── 1_bea10842-b3de-4eed-8cbb-483ce10864f7.changelog │ │ │ │ │ │ │ ├── 2_17d9f074-f585-4dc6-9496-601853ae6537.changelog │ │ │ │ │ │ │ ├── 2_17d9f074-f585-4dc6-9496-601853ae6537.zip │ │ │ │ │ │ │ ├── 3_041cb4db-b9ab-4a99-b7b1-a114cd7544ad.changelog │ │ │ │ │ │ │ ├── 4_ad8df34d-c475-47d6-ad60-3c22b00bcbb2.changelog │ │ │ │ │ │ │ ├── 4_ad8df34d-c475-47d6-ad60-3c22b00bcbb2.zip │ │ │ │ │ │ │ ├── 5_24c41882-0aef-4e18-a83c-dfaac502c893.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── .000008-fc81fc2d-9d9e-495e-ae26-141b4dadf556.sst.crc │ │ │ │ │ │ │ ├── .000009-68b31719-b7dd-4d86-95e1-5000960e0e5a.sst.crc │ │ │ │ │ │ │ ├── 000008-fc81fc2d-9d9e-495e-ae26-141b4dadf556.sst │ │ │ │ │ │ │ └── 000009-68b31719-b7dd-4d86-95e1-5000960e0e5a.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ │ └── metadata │ │ │ │ │ └── limit │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 2 │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .0.crc │ │ │ │ │ ├── .1.crc │ │ │ │ │ ├── .2.crc │ │ │ │ │ └── .3.crc │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 2 │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .0.crc │ │ │ │ │ ├── .1.crc │ │ │ │ │ ├── .2.crc │ │ │ │ │ └── .3.crc │ │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1_509acca3-4c04-47f8-b6f8-80294d4113ce.changelog.crc │ │ │ │ │ ├── .2_33a64dcb-1866-4b88-8786-4c7cebb5c7aa.changelog.crc │ │ │ │ │ ├── .2_33a64dcb-1866-4b88-8786-4c7cebb5c7aa.zip.crc │ │ │ │ │ ├── .3_405bdb41-2510-48a7-afae-ae16460cdf4a.changelog.crc │ │ │ │ │ ├── .4_3425a443-3db7-4f79-bbe0-0aa785c103c7.changelog.crc │ │ │ │ │ ├── .4_3425a443-3db7-4f79-bbe0-0aa785c103c7.zip.crc │ │ │ │ │ ├── 1_509acca3-4c04-47f8-b6f8-80294d4113ce.changelog │ │ │ │ │ ├── 2_33a64dcb-1866-4b88-8786-4c7cebb5c7aa.changelog │ │ │ │ │ ├── 2_33a64dcb-1866-4b88-8786-4c7cebb5c7aa.zip │ │ │ │ │ ├── 3_405bdb41-2510-48a7-afae-ae16460cdf4a.changelog │ │ │ │ │ ├── 4_3425a443-3db7-4f79-bbe0-0aa785c103c7.changelog │ │ │ │ │ ├── 4_3425a443-3db7-4f79-bbe0-0aa785c103c7.zip │ │ │ │ │ ├── SSTs │ │ │ │ │ │ ├── .000008-a09c535f-c77b-4499-82e8-c0f6cddad2e2.sst.crc │ │ │ │ │ │ ├── .000009-92c5d471-6c9f-4f2e-a86c-8b694be7eb8a.sst.crc │ │ │ │ │ │ ├── 000008-a09c535f-c77b-4499-82e8-c0f6cddad2e2.sst │ │ │ │ │ │ └── 000009-92c5d471-6c9f-4f2e-a86c-8b694be7eb8a.sst │ │ │ │ │ └── _metadata │ │ │ │ │ │ ├── .schema.crc │ │ │ │ │ │ └── schema │ │ │ │ │ └── _metadata │ │ │ │ │ ├── .metadata.crc │ │ │ │ │ └── metadata │ │ │ ├── checkpoint-version-4.0.0-tws-avro │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ ├── 2.changelog │ │ │ │ │ └── SSTs │ │ │ │ │ │ ├── .000008-7b1ee246-6831-4c62-9fd7-7741cb534368.sst.crc │ │ │ │ │ │ └── 000008-7b1ee246-6831-4c62-9fd7-7741cb534368.sst │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── 4 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── _metadata │ │ │ │ │ └── v2 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ └── .0.crc │ │ │ │ │ └── _stateSchema │ │ │ │ │ └── default │ │ │ │ │ ├── .0_6b12d3c5-57e6-4001-8321-3ae63d6be7a0.crc │ │ │ │ │ └── 0_6b12d3c5-57e6-4001-8321-3ae63d6be7a0 │ │ │ ├── checkpoint-version-4.0.0-tws-unsaferow │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .0.crc │ │ │ │ │ └── .1.crc │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ ├── 2.changelog │ │ │ │ │ └── SSTs │ │ │ │ │ │ ├── .000008-9b6e23ce-e7de-4df8-b320-2b0378b53e52.sst.crc │ │ │ │ │ │ └── 000008-9b6e23ce-e7de-4df8-b320-2b0378b53e52.sst │ │ │ │ │ ├── 1 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── 2 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── 3 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── 4 │ │ │ │ │ ├── .1.changelog.crc │ │ │ │ │ ├── .1.zip.crc │ │ │ │ │ ├── .2.changelog.crc │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 1.zip │ │ │ │ │ └── 2.changelog │ │ │ │ │ ├── _metadata │ │ │ │ │ └── v2 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ └── .0.crc │ │ │ │ │ └── _stateSchema │ │ │ │ │ └── default │ │ │ │ │ ├── .0_2e8e6b52-e3c3-4184-b8ef-8d391b75d751.crc │ │ │ │ │ └── 0_2e8e6b52-e3c3-4184-b8ef-8d391b75d751 │ │ │ ├── checkpoint-version-4.0.0 │ │ │ │ ├── hdfs │ │ │ │ │ ├── agg │ │ │ │ │ │ ├── commits │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ └── 3 │ │ │ │ │ │ ├── metadata │ │ │ │ │ │ ├── offsets │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ └── 3 │ │ │ │ │ │ └── state │ │ │ │ │ │ │ └── 0 │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── dedup │ │ │ │ │ │ ├── commits │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ └── 3 │ │ │ │ │ │ ├── metadata │ │ │ │ │ │ ├── offsets │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ └── 3 │ │ │ │ │ │ └── state │ │ │ │ │ │ │ └── 0 │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ └── 4.snapshot │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── join1 │ │ │ │ │ │ ├── commits │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ └── 4 │ │ │ │ │ │ ├── metadata │ │ │ │ │ │ ├── offsets │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ └── 4 │ │ │ │ │ │ └── state │ │ │ │ │ │ │ └── 0 │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── join2 │ │ │ │ │ │ ├── commits │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ └── 4 │ │ │ │ │ │ ├── metadata │ │ │ │ │ │ ├── offsets │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ └── 4 │ │ │ │ │ │ └── state │ │ │ │ │ │ │ └── 0 │ │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ ├── 5.delta │ │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ │ │ └── 5.delta │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── metadata │ │ │ │ │ └── limit │ │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ └── 3 │ │ │ │ │ │ ├── metadata │ │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ └── 3 │ │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1.delta │ │ │ │ │ │ ├── 2.delta │ │ │ │ │ │ ├── 2.snapshot │ │ │ │ │ │ ├── 3.delta │ │ │ │ │ │ ├── 4.delta │ │ │ │ │ │ ├── 4.snapshot │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── metadata │ │ │ │ └── rocksdb │ │ │ │ │ ├── agg │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ └── 3 │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ └── 3 │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-e414df11-1a90-4be8-807c-8d6f970b5f56.sst │ │ │ │ │ │ │ └── 000015-97d0e283-eed7-4af0-87d9-eded3afe15ca.sst │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-d6862a4a-f10f-4641-ba89-0ea25cd816b0.sst │ │ │ │ │ │ │ └── 000015-1e8225d7-793e-47df-aec6-fb47522e2494.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ └── 000008-637e442e-feb6-4022-a0b1-919d388073ae.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-0f086ebd-c188-4508-97d3-9282313b0a97.sst │ │ │ │ │ │ │ └── 000015-074aa977-f8df-4b58-8143-c5c4691cdb9a.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── dedup │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ └── 3 │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ └── 3 │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-3073b336-661b-4d30-984d-427402150d37.sst │ │ │ │ │ │ │ └── 000009-5669c494-2412-46c4-96ef-1bb9ab6b2710.sst │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ └── 000008-90e6688f-83a0-4917-ae32-9e107c002bcc.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ └── 000008-e115799d-89cb-4f4d-8e58-fe104d382c80.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-5f249adf-c98e-46a3-8217-e39a4360b624.sst │ │ │ │ │ │ │ └── 000009-0d1befcf-847e-43a5-b354-a4d11afeaaba.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── join1 │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ └── 4 │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ └── 4 │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ └── 000008-97286fb3-8d19-4e91-aecb-3f9647f6103f.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ └── 000008-44099692-68de-4b22-8238-3a8029f693ad.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-a9a5b2ba-3bff-402f-b750-b9232ac3d1b1.sst │ │ │ │ │ │ │ │ └── 000009-c5863121-41a9-4ffc-9c54-5f4c2a1139a2.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-a55c633d-a594-4cac-b6f2-c63907cb9581.sst │ │ │ │ │ │ │ └── 000009-f8390e48-d464-49b8-8a3b-6393448f907d.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-ad09ce4b-4be4-44ce-a620-4244a73f84f5.sst │ │ │ │ │ │ │ │ └── 000009-5561a93a-1e0b-46aa-98d5-685048b992fa.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-36205897-8ada-4516-b663-122c915754f0.sst │ │ │ │ │ │ │ │ └── 000009-bffa46f8-b6c7-431e-a579-d8725aec338b.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-f6d87143-b4d6-4c30-bd43-8e90c98704e9.sst │ │ │ │ │ │ │ │ └── 000009-64a8ab01-cdfe-4c82-94e3-5bc4c64b6671.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-50764781-b9d2-482d-a307-b2d1cab8c639.sst │ │ │ │ │ │ │ └── 000009-38fca8e3-893a-4d8b-8f4a-57366102a54c.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-fd11870f-bea5-4721-aedf-b14399b966bd.sst │ │ │ │ │ │ │ │ └── 000009-1ba9d77a-6c31-42e5-a18e-f66c0ef201b5.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-7fbc8ecb-8e90-4de6-a334-ce789dfe3dd5.sst │ │ │ │ │ │ │ │ └── 000009-05c7d657-5d52-4d9d-9e5e-d28daf8d6500.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-fb249fa1-17cf-4f28-99fa-e31932ec1caf.sst │ │ │ │ │ │ │ │ └── 000009-6dc46235-1157-4bb7-9af0-58aee4e2edf2.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-2695fe50-483f-4beb-a12d-770bfe63da9c.sst │ │ │ │ │ │ │ └── 000009-c819e3a7-826b-46d0-8667-1670b9b2d13c.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── metadata │ │ │ │ │ ├── join2 │ │ │ │ │ ├── commits │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ └── 4 │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ └── 4 │ │ │ │ │ └── state │ │ │ │ │ │ └── 0 │ │ │ │ │ │ ├── 0 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ │ └── schema │ │ │ │ │ │ ├── 1 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ └── 5.changelog │ │ │ │ │ │ ├── 2 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ └── 000008-bfd9de3b-a339-42ad-8270-343b70b3999e.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ └── 000008-daf5150d-98b0-4042-ac23-f6ffcb9eef2f.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-8de57e57-02b1-47fc-8150-eb984771e1ca.sst │ │ │ │ │ │ │ │ └── 000009-a8eb1b10-f5fe-4a44-94ab-545d1e33121c.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-4f4617f6-01ce-48f5-aaa9-c9d7007ac482.sst │ │ │ │ │ │ │ └── 000009-840bae7d-ff30-4aef-9672-bf70fa6943c4.sst │ │ │ │ │ │ ├── 3 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-e1bd2941-d044-4898-a841-7d6d094b7c30.sst │ │ │ │ │ │ │ │ └── 000009-e646f573-4a5b-408d-88da-85810aabe966.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-28cb1ac6-cf15-4f63-8c74-ea655f8ce669.sst │ │ │ │ │ │ │ │ └── 000009-5a4a38a3-8e5a-4436-b0b7-718fe7ed09a6.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-294ce63e-1e67-4bc5-98fa-67b6f40669ff.sst │ │ │ │ │ │ │ │ └── 000009-ad3aeaf9-d804-4237-91e5-e2d61f7c8338.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-e9c9dd20-a2b3-4eac-94e6-3336a8bf2953.sst │ │ │ │ │ │ │ └── 000009-7db59f7a-dabc-41f7-8878-87ca30afb09d.sst │ │ │ │ │ │ ├── 4 │ │ │ │ │ │ ├── left-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-a9c68839-18e4-4ef3-a329-432d2810b0c3.sst │ │ │ │ │ │ │ │ └── 000009-e91db969-62ec-45d7-a7da-a4301e129feb.sst │ │ │ │ │ │ ├── left-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-5e19d13c-8855-47c9-8d4b-f14964f7fdfa.sst │ │ │ │ │ │ │ │ └── 000009-a97d5e47-e4eb-4878-b62d-30cc77dac3b1.sst │ │ │ │ │ │ ├── right-keyToNumValues │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ │ ├── 000008-432ddd3b-981c-4a2b-a1e4-e06ecbc4a8a7.sst │ │ │ │ │ │ │ │ └── 000009-2e821d73-a2c6-4261-bcb6-d69e82e4c0d3.sst │ │ │ │ │ │ └── right-keyWithIndexToValue │ │ │ │ │ │ │ ├── 1.changelog │ │ │ │ │ │ │ ├── 2.changelog │ │ │ │ │ │ │ ├── 2.zip │ │ │ │ │ │ │ ├── 3.changelog │ │ │ │ │ │ │ ├── 4.changelog │ │ │ │ │ │ │ ├── 4.zip │ │ │ │ │ │ │ ├── 5.changelog │ │ │ │ │ │ │ └── SSTs │ │ │ │ │ │ │ ├── 000008-4e1c24f5-bbcb-4797-95d9-cfa4de1be09d.sst │ │ │ │ │ │ │ └── 000009-366ba158-6a59-4922-9cb0-df3e2b9aa789.sst │ │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── metadata │ │ │ │ │ └── limit │ │ │ │ │ ├── commits │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 2 │ │ │ │ │ └── 3 │ │ │ │ │ ├── metadata │ │ │ │ │ ├── offsets │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1 │ │ │ │ │ ├── 2 │ │ │ │ │ └── 3 │ │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.changelog │ │ │ │ │ ├── 2.changelog │ │ │ │ │ ├── 2.zip │ │ │ │ │ ├── 3.changelog │ │ │ │ │ ├── 4.changelog │ │ │ │ │ ├── 4.zip │ │ │ │ │ ├── SSTs │ │ │ │ │ │ ├── 000008-8f6e7567-9c70-4f55-9f28-8b6b497c85ae.sst │ │ │ │ │ │ └── 000009-71eca19b-ab68-4608-bcfa-897365067239.sst │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── schema │ │ │ │ │ └── _metadata │ │ │ │ │ └── metadata │ │ │ ├── checkpoint-version-4.0.1-dedup-spark-53942 │ │ │ │ ├── commits │ │ │ │ │ └── 0 │ │ │ │ ├── metadata │ │ │ │ ├── offsets │ │ │ │ │ └── 0 │ │ │ │ └── state │ │ │ │ │ └── 0 │ │ │ │ │ ├── 0 │ │ │ │ │ ├── 1.delta │ │ │ │ │ └── _metadata │ │ │ │ │ │ └── schema │ │ │ │ │ ├── 1 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 2 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 3 │ │ │ │ │ └── 1.delta │ │ │ │ │ ├── 4 │ │ │ │ │ └── 1.delta │ │ │ │ │ └── _metadata │ │ │ │ │ └── metadata │ │ │ ├── escaped-path-2.4.0 │ │ │ │ ├── chk%252520%252525@%252523chk │ │ │ │ │ ├── commits │ │ │ │ │ │ └── 0 │ │ │ │ │ ├── metadata │ │ │ │ │ └── offsets │ │ │ │ │ │ └── 0 │ │ │ │ ├── output %@#output │ │ │ │ │ └── part-00000-97f675a2-bb82-4201-8245-05f3dae4c372-c000.snappy.parquet │ │ │ │ └── output%20%25@%23output │ │ │ │ │ └── _spark_metadata │ │ │ │ │ └── 0 │ │ │ ├── file-sink-log-version-2.1.0 │ │ │ │ ├── 8 │ │ │ │ ├── 9 │ │ │ │ └── 7.compact │ │ │ ├── file-source-log-version-2.1.0 │ │ │ │ ├── 3 │ │ │ │ ├── 4 │ │ │ │ └── 2.compact │ │ │ ├── file-source-offset-version-2.1.0-json.txt │ │ │ ├── file-source-offset-version-2.1.0-long.txt │ │ │ ├── offset-log-version-2.1.0 │ │ │ │ └── 0 │ │ │ ├── offset-map │ │ │ │ ├── 0 │ │ │ │ ├── 1 │ │ │ │ ├── 2 │ │ │ │ └── 3 │ │ │ ├── partition-tests │ │ │ │ ├── randomSchemas │ │ │ │ └── rowsAndPartIds │ │ │ ├── query-event-logs-version-2.0.0.txt │ │ │ ├── query-event-logs-version-2.0.1.txt │ │ │ ├── query-event-logs-version-2.0.2.txt │ │ │ ├── query-metadata-logs-version-2.1.0.txt │ │ │ ├── testCommitLogV1 │ │ │ │ └── testCommitLog │ │ │ ├── testCommitLogV2-empty-unique-id │ │ │ │ └── testCommitLog │ │ │ └── testCommitLogV2 │ │ │ │ └── testCommitLog │ │ ├── test-data │ │ │ ├── TestStringDictionary.testRowIndex.orc │ │ │ ├── bad_after_good.csv │ │ │ ├── before_1582_date_v2_4.snappy.orc │ │ │ ├── before_1582_date_v2_4_5.snappy.parquet │ │ │ ├── before_1582_date_v2_4_6.snappy.parquet │ │ │ ├── before_1582_date_v3_2_0.snappy.parquet │ │ │ ├── before_1582_timestamp_int96_dict_v2_4_5.snappy.parquet │ │ │ ├── before_1582_timestamp_int96_dict_v2_4_6.snappy.parquet │ │ │ ├── before_1582_timestamp_int96_dict_v3_2_0.snappy.parquet │ │ │ ├── before_1582_timestamp_int96_plain_v2_4_5.snappy.parquet │ │ │ ├── before_1582_timestamp_int96_plain_v2_4_6.snappy.parquet │ │ │ ├── before_1582_timestamp_int96_plain_v3_2_0.snappy.parquet │ │ │ ├── before_1582_timestamp_micros_v2_4_5.snappy.parquet │ │ │ ├── before_1582_timestamp_micros_v2_4_6.snappy.parquet │ │ │ ├── before_1582_timestamp_micros_v3_2_0.snappy.parquet │ │ │ ├── before_1582_timestamp_millis_v2_4_5.snappy.parquet │ │ │ ├── before_1582_timestamp_millis_v2_4_6.snappy.parquet │ │ │ ├── before_1582_timestamp_millis_v3_2_0.snappy.parquet │ │ │ ├── before_1582_ts_v2_4.snappy.orc │ │ │ ├── bool.csv │ │ │ ├── cars-alternative.csv │ │ │ ├── cars-blank-column-name.csv │ │ │ ├── cars-crlf.csv │ │ │ ├── cars-empty-value.csv │ │ │ ├── cars-malformed.csv │ │ │ ├── cars-multichar-delim-crazy.csv │ │ │ ├── cars-multichar-delim.csv │ │ │ ├── cars-null.csv │ │ │ ├── cars-unbalanced-quotes.csv │ │ │ ├── cars.csv │ │ │ ├── cars.csv.hadoop.zst │ │ │ ├── cars.csv.zst │ │ │ ├── cars.tsv │ │ │ ├── cars_iso-8859-1.csv │ │ │ ├── char.csv │ │ │ ├── comments-whitespaces.csv │ │ │ ├── comments.csv │ │ │ ├── date-infer-schema.csv │ │ │ ├── dates.csv │ │ │ ├── dec-in-fixed-len.parquet │ │ │ ├── dec-in-i32.parquet │ │ │ ├── dec-in-i64.parquet │ │ │ ├── decimal.csv │ │ │ ├── decimal32-written-as-64-bit-dict.snappy.parquet │ │ │ ├── decimal32-written-as-64-bit.snappy.parquet │ │ │ ├── delta_length_byte_array.parquet │ │ │ ├── disable_comments.csv │ │ │ ├── empty.csv │ │ │ ├── group-field-with-enum-as-logical-annotation.parquet │ │ │ ├── impala_timestamp.parq │ │ │ ├── interval-using-fixed-len-byte-array.parquet │ │ │ ├── malformed-file-offset.parquet │ │ │ ├── malformedRow.csv │ │ │ ├── malformed_utf8.json │ │ │ ├── more-columns.csv │ │ │ ├── nested-array-struct.parquet │ │ │ ├── numbers.csv │ │ │ ├── old-repeated-int.parquet │ │ │ ├── old-repeated-message.parquet │ │ │ ├── packed-list-vectorized.parquet │ │ │ ├── parquet-1217.parquet │ │ │ ├── parquet-thrift-compat.snappy.parquet │ │ │ ├── percentile_approx-input.csv.bz2 │ │ │ ├── postgresql │ │ │ │ ├── agg.data │ │ │ │ ├── onek.data │ │ │ │ └── tenk.data │ │ │ ├── proto-repeated-string.parquet │ │ │ ├── proto-repeated-struct.parquet │ │ │ ├── proto-struct-with-array-many.parquet │ │ │ ├── proto-struct-with-array.parquet │ │ │ ├── simple_sparse.csv │ │ │ ├── tagged_int.parquet │ │ │ ├── tagged_long.parquet │ │ │ ├── test-archive.har │ │ │ │ ├── _index │ │ │ │ ├── _masterindex │ │ │ │ └── part-0 │ │ │ ├── text-partitioned │ │ │ │ ├── year=2014 │ │ │ │ │ └── data.txt │ │ │ │ └── year=2015 │ │ │ │ │ └── data.txt │ │ │ ├── text-suite.txt │ │ │ ├── text-suite2.txt │ │ │ ├── timemillis-in-i64.parquet │ │ │ ├── timestamp-nanos.parquet │ │ │ ├── timestamps.csv │ │ │ ├── unescaped-quotes.csv │ │ │ ├── utf16LE.json │ │ │ ├── utf16WithBOM.json │ │ │ ├── utf32BEWithBOM.json │ │ │ ├── value-malformed.csv │ │ │ ├── with-array-fields.json │ │ │ ├── with-map-fields.json │ │ │ └── xml-resources │ │ │ │ ├── ages-mixed-types.xml │ │ │ │ ├── ages-with-spaces.xml │ │ │ │ ├── ages.xml │ │ │ │ ├── attributes-case-sensitive.xml │ │ │ │ ├── attributesStartWithNewLine.xml │ │ │ │ ├── attributesStartWithNewLineCR.xml │ │ │ │ ├── attributesStartWithNewLineLF.xml │ │ │ │ ├── basket.xml │ │ │ │ ├── basket.xsd │ │ │ │ ├── basket_invalid.xml │ │ │ │ ├── basket_invalid_at_the_end.xml │ │ │ │ ├── basket_invalid_in_the_beginning.xml │ │ │ │ ├── basket_invalid_in_the_middle.xml │ │ │ │ ├── books-attributes-in-no-child.xml │ │ │ │ ├── books-complicated-null-attribute.xml │ │ │ │ ├── books-complicated.xml │ │ │ │ ├── books-malformed-attributes.xml │ │ │ │ ├── books-namespaces.xml │ │ │ │ ├── books-nested-array.xml │ │ │ │ ├── books-nested-object.xml │ │ │ │ ├── books-unicode-in-tag-name.xml │ │ │ │ ├── books.xml │ │ │ │ ├── cars-attribute.xml │ │ │ │ ├── cars-iso-8859-1.xml │ │ │ │ ├── cars-malformed.xml │ │ │ │ ├── cars-mixed-attr-no-child.xml │ │ │ │ ├── cars-no-indentation.xml │ │ │ │ ├── cars-unbalanced-elements.xml │ │ │ │ ├── cars.xml │ │ │ │ ├── cars.xml.bz2 │ │ │ │ ├── cars.xml.gz │ │ │ │ ├── cars.xml.zst │ │ │ │ ├── catalog.xsd │ │ │ │ ├── cdata-ending-eof.xml │ │ │ │ ├── cdata-no-close.xml │ │ │ │ ├── cdata-no-ignore.xml │ │ │ │ ├── choice.xsd │ │ │ │ ├── complex-content-extension.xsd │ │ │ │ ├── datatypes-valid-and-invalid.xml │ │ │ │ ├── date.xml │ │ │ │ ├── decimal-with-restriction.xsd │ │ │ │ ├── empty.xml │ │ │ │ ├── feed-with-spaces.xml │ │ │ │ ├── fias_house.large.xml │ │ │ │ ├── fias_house.large.xml.bz2 │ │ │ │ ├── fias_house.large.xml.gz │ │ │ │ ├── fias_house.xml │ │ │ │ ├── fias_house.xml.bz2 │ │ │ │ ├── fias_house.xml.gz │ │ │ │ ├── gps-empty-field.xml │ │ │ │ ├── ignored-rows.xml │ │ │ │ ├── include-example │ │ │ │ ├── first.xsd │ │ │ │ └── second.xsd │ │ │ │ ├── long.xsd │ │ │ │ ├── manual_schema_corrupt_record.xml │ │ │ │ ├── map-attribute.xml │ │ │ │ ├── mixed_children.xml │ │ │ │ ├── mixed_children_2.xml │ │ │ │ ├── mixed_children_as_string.xml │ │ │ │ ├── nested-element-with-attributes-and-name-of-parent.xml │ │ │ │ ├── nested-element-with-name-of-parent.xml │ │ │ │ ├── null-empty-string.xml │ │ │ │ ├── null-nested-struct-2.xml │ │ │ │ ├── null-nested-struct.xml │ │ │ │ ├── null-numbers-2.xml │ │ │ │ ├── null-numbers.xml │ │ │ │ ├── processing.xml │ │ │ │ ├── ref-attribute.xsd │ │ │ │ ├── root-level-value-none.xml │ │ │ │ ├── root-level-value.xml │ │ │ │ ├── self-closing-tag.xml │ │ │ │ ├── simple-nested-objects.xml │ │ │ │ ├── struct_with_optional_child.xml │ │ │ │ ├── textColumn.xml │ │ │ │ ├── time.xml │ │ │ │ ├── timestamps.xml │ │ │ │ ├── topics-namespaces.xml │ │ │ │ ├── twoelements.xsd │ │ │ │ ├── unclosed_tag.xml │ │ │ │ ├── whitespace_error.xml │ │ │ │ └── xsany.xsd │ │ ├── test_script.py │ │ ├── tpcds-modifiedQueries │ │ │ ├── q10.sql │ │ │ ├── q19.sql │ │ │ ├── q27.sql │ │ │ ├── q3.sql │ │ │ ├── q34.sql │ │ │ ├── q42.sql │ │ │ ├── q43.sql │ │ │ ├── q46.sql │ │ │ ├── q52.sql │ │ │ ├── q53.sql │ │ │ ├── q55.sql │ │ │ ├── q59.sql │ │ │ ├── q63.sql │ │ │ ├── q65.sql │ │ │ ├── q68.sql │ │ │ ├── q7.sql │ │ │ ├── q73.sql │ │ │ ├── q79.sql │ │ │ ├── q89.sql │ │ │ ├── q98.sql │ │ │ └── ss_max.sql │ │ ├── tpcds-plan-stability │ │ │ ├── approved-plans-modified │ │ │ │ ├── q10.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q10 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q19.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q19 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q27.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q27 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q3.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q3 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q34.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q34 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q42.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q42 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q43.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q43 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q46.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q46 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q52.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q52 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q53.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q53 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q55.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q55 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q59.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q59 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q63.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q63 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q65.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q65 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q68.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q68 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q7.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q7 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q73.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q73 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q79.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q79 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q89.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q89 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q98.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q98 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── ss_max.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ └── ss_max │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ ├── approved-plans-v1_4 │ │ │ │ ├── q1.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q1 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q10.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q10 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q11.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q11 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q12.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q12 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q13.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q13 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q14a.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q14a │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q14b.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q14b │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q15.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q15 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q16.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q16 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q17.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q17 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q18.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q18 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q19.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q19 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q2.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q2 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q20.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q20 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q21.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q21 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q22.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q22 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q23a.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q23a │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q23b.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q23b │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q24a.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q24a │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q24b.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q24b │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q25.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q25 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q26.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q26 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q27.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q27 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q28.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q28 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q29.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q29 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q3.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q3 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q30.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q30 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q31.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q31 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q32.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q32 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q33.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q33 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q34.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q34 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q35.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q35 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q36.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q36 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q37.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q37 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q38.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q38 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q39a.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q39a │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q39b.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q39b │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q4.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q4 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q40.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q40 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q41.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q41 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q42.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q42 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q43.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q43 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q44.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q44 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q45.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q45 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q46.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q46 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q47.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q47 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q48.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q48 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q49.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q49 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q5.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q5 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q50.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q50 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q51.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q51 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q52.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q52 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q53.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q53 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q54.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q54 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q55.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q55 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q56.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q56 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q57.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q57 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q58.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q58 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q59.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q59 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q6.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q6 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q60.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q60 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q61.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q61 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q62.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q62 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q63.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q63 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q64.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q64 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q65.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q65 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q66.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q66 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q67.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q67 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q68.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q68 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q69.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q69 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q7.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q7 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q70.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q70 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q71.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q71 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q72.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q72 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q73.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q73 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q74.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q74 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q75.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q75 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q76.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q76 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q77.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q77 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q78.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q78 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q79.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q79 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q8.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q8 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q80.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q80 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q81.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q81 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q82.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q82 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q83.ansi │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q83.sf100.ansi │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q83.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q83 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q84.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q84 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q85.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q85 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q86.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q86 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q87.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q87 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q88.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q88 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q89.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q89 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q9.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q9 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q90.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q90 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q91.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q91 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q92.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q92 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q93.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q93 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q94.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q94 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q95.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q95 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q96.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q96 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q97.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q97 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q98.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q98 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ ├── q99.sf100 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ │ └── q99 │ │ │ │ │ ├── explain.txt │ │ │ │ │ └── simplified.txt │ │ │ └── approved-plans-v2_7 │ │ │ │ ├── q10a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q10a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q11.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q11 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q12.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q12 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q14.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q14 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q14a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q14a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q18a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q18a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q20.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q20 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q22.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q22 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q22a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q22a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q24.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q24 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q27a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q27a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q34.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q34 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q35.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q35 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q35a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q35a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q36a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q36a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q47.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q47 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q49.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q49 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q51a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q51a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q57.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q57 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q5a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q5a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q6.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q6 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q64.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q64 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q67a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q67a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q70a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q70a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q72.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q72 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q74.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q74 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q75.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q75 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q77a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q77a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q78.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q78 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q80a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q80a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q86a.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q86a │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ ├── q98.sf100 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ │ └── q98 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ ├── tpcds-query-results │ │ │ ├── v1_4 │ │ │ │ ├── q1.sql.out │ │ │ │ ├── q10.sql.out │ │ │ │ ├── q11.sql.out │ │ │ │ ├── q12.sql.out │ │ │ │ ├── q13.sql.out │ │ │ │ ├── q14a.sql.out │ │ │ │ ├── q14b.sql.out │ │ │ │ ├── q15.sql.out │ │ │ │ ├── q16.sql.out │ │ │ │ ├── q17.sql.out │ │ │ │ ├── q18.sql.out │ │ │ │ ├── q19.sql.out │ │ │ │ ├── q2.sql.out │ │ │ │ ├── q20.sql.out │ │ │ │ ├── q21.sql.out │ │ │ │ ├── q22.sql.out │ │ │ │ ├── q23a.sql.out │ │ │ │ ├── q23b.sql.out │ │ │ │ ├── q24a.sql.out │ │ │ │ ├── q24b.sql.out │ │ │ │ ├── q25.sql.out │ │ │ │ ├── q26.sql.out │ │ │ │ ├── q27.sql.out │ │ │ │ ├── q28.sql.out │ │ │ │ ├── q29.sql.out │ │ │ │ ├── q3.sql.out │ │ │ │ ├── q30.sql.out │ │ │ │ ├── q31.sql.out │ │ │ │ ├── q32.sql.out │ │ │ │ ├── q33.sql.out │ │ │ │ ├── q34.sql.out │ │ │ │ ├── q35.sql.out │ │ │ │ ├── q36.sql.out │ │ │ │ ├── q37.sql.out │ │ │ │ ├── q38.sql.out │ │ │ │ ├── q39a.sql.out │ │ │ │ ├── q39b.sql.out │ │ │ │ ├── q4.sql.out │ │ │ │ ├── q40.sql.out │ │ │ │ ├── q41.sql.out │ │ │ │ ├── q42.sql.out │ │ │ │ ├── q43.sql.out │ │ │ │ ├── q44.sql.out │ │ │ │ ├── q45.sql.out │ │ │ │ ├── q46.sql.out │ │ │ │ ├── q47.sql.out │ │ │ │ ├── q48.sql.out │ │ │ │ ├── q49.sql.out │ │ │ │ ├── q5.sql.out │ │ │ │ ├── q50.sql.out │ │ │ │ ├── q51.sql.out │ │ │ │ ├── q52.sql.out │ │ │ │ ├── q53.sql.out │ │ │ │ ├── q54.sql.out │ │ │ │ ├── q55.sql.out │ │ │ │ ├── q56.sql.out │ │ │ │ ├── q57.sql.out │ │ │ │ ├── q58.sql.out │ │ │ │ ├── q59.sql.out │ │ │ │ ├── q60.sql.out │ │ │ │ ├── q61.sql.out │ │ │ │ ├── q62.sql.out │ │ │ │ ├── q63.sql.out │ │ │ │ ├── q64.sql.out │ │ │ │ ├── q65.sql.out │ │ │ │ ├── q66.sql.out │ │ │ │ ├── q67.sql.out │ │ │ │ ├── q68.sql.out │ │ │ │ ├── q69.sql.out │ │ │ │ ├── q7.sql.out │ │ │ │ ├── q70.sql.out │ │ │ │ ├── q71.sql.out │ │ │ │ ├── q72.sql.out │ │ │ │ ├── q73.sql.out │ │ │ │ ├── q74.sql.out │ │ │ │ ├── q76.sql.out │ │ │ │ ├── q77.sql.out │ │ │ │ ├── q78.sql.out │ │ │ │ ├── q79.sql.out │ │ │ │ ├── q8.sql.out │ │ │ │ ├── q80.sql.out │ │ │ │ ├── q81.sql.out │ │ │ │ ├── q82.sql.out │ │ │ │ ├── q83.sql.out │ │ │ │ ├── q84.sql.out │ │ │ │ ├── q85.sql.out │ │ │ │ ├── q86.sql.out │ │ │ │ ├── q87.sql.out │ │ │ │ ├── q88.sql.out │ │ │ │ ├── q89.sql.out │ │ │ │ ├── q9.sql.out │ │ │ │ ├── q90.sql.out │ │ │ │ ├── q91.sql.out │ │ │ │ ├── q92.sql.out │ │ │ │ ├── q93.sql.out │ │ │ │ ├── q94.sql.out │ │ │ │ ├── q95.sql.out │ │ │ │ ├── q96.sql.out │ │ │ │ ├── q97.sql.out │ │ │ │ ├── q98.sql.out │ │ │ │ └── q99.sql.out │ │ │ └── v2_7 │ │ │ │ ├── q10a.sql.out │ │ │ │ ├── q11.sql.out │ │ │ │ ├── q12.sql.out │ │ │ │ ├── q14.sql.out │ │ │ │ ├── q14a.sql.out │ │ │ │ ├── q18a.sql.out │ │ │ │ ├── q20.sql.out │ │ │ │ ├── q22.sql.out │ │ │ │ ├── q22a.sql.out │ │ │ │ ├── q24.sql.out │ │ │ │ ├── q27a.sql.out │ │ │ │ ├── q34.sql.out │ │ │ │ ├── q35.sql.out │ │ │ │ ├── q35a.sql.out │ │ │ │ ├── q36a.sql.out │ │ │ │ ├── q47.sql.out │ │ │ │ ├── q49.sql.out │ │ │ │ ├── q51a.sql.out │ │ │ │ ├── q57.sql.out │ │ │ │ ├── q5a.sql.out │ │ │ │ ├── q6.sql.out │ │ │ │ ├── q64.sql.out │ │ │ │ ├── q67a.sql.out │ │ │ │ ├── q70a.sql.out │ │ │ │ ├── q72.sql.out │ │ │ │ ├── q74.sql.out │ │ │ │ ├── q75.sql.out │ │ │ │ ├── q77a.sql.out │ │ │ │ ├── q78.sql.out │ │ │ │ ├── q80a.sql.out │ │ │ │ ├── q86a.sql.out │ │ │ │ └── q98.sql.out │ │ ├── tpcds-v2.7.0 │ │ │ ├── q10a.sql │ │ │ ├── q11.sql │ │ │ ├── q12.sql │ │ │ ├── q14.sql │ │ │ ├── q14a.sql │ │ │ ├── q18a.sql │ │ │ ├── q20.sql │ │ │ ├── q22.sql │ │ │ ├── q22a.sql │ │ │ ├── q24.sql │ │ │ ├── q27a.sql │ │ │ ├── q34.sql │ │ │ ├── q35.sql │ │ │ ├── q35a.sql │ │ │ ├── q36a.sql │ │ │ ├── q47.sql │ │ │ ├── q49.sql │ │ │ ├── q51a.sql │ │ │ ├── q57.sql │ │ │ ├── q5a.sql │ │ │ ├── q6.sql │ │ │ ├── q64.sql │ │ │ ├── q67a.sql │ │ │ ├── q70a.sql │ │ │ ├── q72.sql │ │ │ ├── q74.sql │ │ │ ├── q75.sql │ │ │ ├── q77a.sql │ │ │ ├── q78.sql │ │ │ ├── q80a.sql │ │ │ ├── q86a.sql │ │ │ └── q98.sql │ │ ├── tpcds │ │ │ ├── q1.sql │ │ │ ├── q10.sql │ │ │ ├── q11.sql │ │ │ ├── q12.sql │ │ │ ├── q13.sql │ │ │ ├── q14a.sql │ │ │ ├── q14b.sql │ │ │ ├── q15.sql │ │ │ ├── q16.sql │ │ │ ├── q17.sql │ │ │ ├── q18.sql │ │ │ ├── q19.sql │ │ │ ├── q2.sql │ │ │ ├── q20.sql │ │ │ ├── q21.sql │ │ │ ├── q22.sql │ │ │ ├── q23a.sql │ │ │ ├── q23b.sql │ │ │ ├── q24a.sql │ │ │ ├── q24b.sql │ │ │ ├── q25.sql │ │ │ ├── q26.sql │ │ │ ├── q27.sql │ │ │ ├── q28.sql │ │ │ ├── q29.sql │ │ │ ├── q3.sql │ │ │ ├── q30.sql │ │ │ ├── q31.sql │ │ │ ├── q32.sql │ │ │ ├── q33.sql │ │ │ ├── q34.sql │ │ │ ├── q35.sql │ │ │ ├── q36.sql │ │ │ ├── q37.sql │ │ │ ├── q38.sql │ │ │ ├── q39a.sql │ │ │ ├── q39b.sql │ │ │ ├── q4.sql │ │ │ ├── q40.sql │ │ │ ├── q41.sql │ │ │ ├── q42.sql │ │ │ ├── q43.sql │ │ │ ├── q44.sql │ │ │ ├── q45.sql │ │ │ ├── q46.sql │ │ │ ├── q47.sql │ │ │ ├── q48.sql │ │ │ ├── q49.sql │ │ │ ├── q5.sql │ │ │ ├── q50.sql │ │ │ ├── q51.sql │ │ │ ├── q52.sql │ │ │ ├── q53.sql │ │ │ ├── q54.sql │ │ │ ├── q55.sql │ │ │ ├── q56.sql │ │ │ ├── q57.sql │ │ │ ├── q58.sql │ │ │ ├── q59.sql │ │ │ ├── q6.sql │ │ │ ├── q60.sql │ │ │ ├── q61.sql │ │ │ ├── q62.sql │ │ │ ├── q63.sql │ │ │ ├── q64.sql │ │ │ ├── q65.sql │ │ │ ├── q66.sql │ │ │ ├── q67.sql │ │ │ ├── q68.sql │ │ │ ├── q69.sql │ │ │ ├── q7.sql │ │ │ ├── q70.sql │ │ │ ├── q71.sql │ │ │ ├── q72.sql │ │ │ ├── q73.sql │ │ │ ├── q74.sql │ │ │ ├── q75.sql │ │ │ ├── q76.sql │ │ │ ├── q77.sql │ │ │ ├── q78.sql │ │ │ ├── q79.sql │ │ │ ├── q8.sql │ │ │ ├── q80.sql │ │ │ ├── q81.sql │ │ │ ├── q82.sql │ │ │ ├── q83.sql │ │ │ ├── q84.sql │ │ │ ├── q85.sql │ │ │ ├── q86.sql │ │ │ ├── q87.sql │ │ │ ├── q88.sql │ │ │ ├── q89.sql │ │ │ ├── q9.sql │ │ │ ├── q90.sql │ │ │ ├── q91.sql │ │ │ ├── q92.sql │ │ │ ├── q93.sql │ │ │ ├── q94.sql │ │ │ ├── q95.sql │ │ │ ├── q96.sql │ │ │ ├── q97.sql │ │ │ ├── q98.sql │ │ │ └── q99.sql │ │ ├── tpch-plan-stability │ │ │ ├── q1 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q10 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q11 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q12 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q13 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q14 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q15 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q16 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q17 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q18 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q19 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q2 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q20 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q21 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q22 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q3 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q4 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q5 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q6 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q7 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ ├── q8 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ │ └── q9 │ │ │ │ ├── explain.txt │ │ │ │ └── simplified.txt │ │ └── tpch │ │ │ ├── q1.sql │ │ │ ├── q10.sql │ │ │ ├── q11.sql │ │ │ ├── q12.sql │ │ │ ├── q13.sql │ │ │ ├── q14.sql │ │ │ ├── q15.sql │ │ │ ├── q16.sql │ │ │ ├── q17.sql │ │ │ ├── q18.sql │ │ │ ├── q19.sql │ │ │ ├── q2.sql │ │ │ ├── q20.sql │ │ │ ├── q21.sql │ │ │ ├── q22.sql │ │ │ ├── q3.sql │ │ │ ├── q4.sql │ │ │ ├── q5.sql │ │ │ ├── q6.sql │ │ │ ├── q7.sql │ │ │ ├── q8.sql │ │ │ └── q9.sql │ │ ├── scala │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── deploy │ │ │ └── history │ │ │ │ └── Utils.scala │ │ │ ├── sql │ │ │ ├── AddMetadataColumnsSuite.scala │ │ │ ├── AggregateHashMapSuite.scala │ │ │ ├── AlwaysPersistedConfigsSuite.scala │ │ │ ├── ApproxCountDistinctForIntervalsQuerySuite.scala │ │ │ ├── ApproxTopKSuite.scala │ │ │ ├── ApproximatePercentileQuerySuite.scala │ │ │ ├── BenchmarkQueryTest.scala │ │ │ ├── BitmapExpressionsQuerySuite.scala │ │ │ ├── BloomFilterAggregateQuerySuite.scala │ │ │ ├── CTEHintSuite.scala │ │ │ ├── CTEInlineSuite.scala │ │ │ ├── CacheManagerSuite.scala │ │ │ ├── CacheTableInKryoSuite.scala │ │ │ ├── CachedTableSuite.scala │ │ │ ├── CharVarcharTestSuite.scala │ │ │ ├── ColumnExpressionSuite.scala │ │ │ ├── ComplexTypesSuite.scala │ │ │ ├── ConfigBehaviorSuite.scala │ │ │ ├── CountMinSketchAggQuerySuite.scala │ │ │ ├── CsvFunctionsSuite.scala │ │ │ ├── DataFrameAggregateSuite.scala │ │ │ ├── DataFrameAsOfJoinSuite.scala │ │ │ ├── DataFrameComplexTypeSuite.scala │ │ │ ├── DataFrameFunctionsSuite.scala │ │ │ ├── DataFrameHintSuite.scala │ │ │ ├── DataFrameImplicitsSuite.scala │ │ │ ├── DataFrameJoinSuite.scala │ │ │ ├── DataFrameNaFunctionsSuite.scala │ │ │ ├── DataFramePivotSuite.scala │ │ │ ├── DataFrameRangeSuite.scala │ │ │ ├── DataFrameSelfJoinSuite.scala │ │ │ ├── DataFrameSessionWindowingSuite.scala │ │ │ ├── DataFrameSetOperationsSuite.scala │ │ │ ├── DataFrameShowSuite.scala │ │ │ ├── DataFrameStatSuite.scala │ │ │ ├── DataFrameSubquerySuite.scala │ │ │ ├── DataFrameSuite.scala │ │ │ ├── DataFrameTableValuedFunctionsSuite.scala │ │ │ ├── DataFrameTimeWindowingSuite.scala │ │ │ ├── DataFrameToSchemaSuite.scala │ │ │ ├── DataFrameTransposeSuite.scala │ │ │ ├── DataFrameTungstenSuite.scala │ │ │ ├── DataFrameWindowFramesSuite.scala │ │ │ ├── DataFrameWindowFunctionsSuite.scala │ │ │ ├── DataFrameWriterV2Suite.scala │ │ │ ├── DatasetAggregatorSuite.scala │ │ │ ├── DatasetBenchmark.scala │ │ │ ├── DatasetCacheSuite.scala │ │ │ ├── DatasetOptimizationSuite.scala │ │ │ ├── DatasetPrimitiveSuite.scala │ │ │ ├── DatasetSerializerRegistratorSuite.scala │ │ │ ├── DatasetSuite.scala │ │ │ ├── DatasetUnpivotSuite.scala │ │ │ ├── DateFunctionsSuite.scala │ │ │ ├── DeprecatedAPISuite.scala │ │ │ ├── DeprecatedDatasetAggregatorSuite.scala │ │ │ ├── DynamicPartitionPruningSuite.scala │ │ │ ├── EmptyInSuite.scala │ │ │ ├── ExplainSuite.scala │ │ │ ├── ExpressionsSchemaSuite.scala │ │ │ ├── ExtraStrategiesSuite.scala │ │ │ ├── FileBasedDataSourceSuite.scala │ │ │ ├── FileScanSuite.scala │ │ │ ├── GenTPCDSData.scala │ │ │ ├── GeneratorFunctionSuite.scala │ │ │ ├── GeographyDataFrameSuite.scala │ │ │ ├── GeometryDataFrameSuite.scala │ │ │ ├── ICUCollationsMapSuite.scala │ │ │ ├── InjectRuntimeFilterSuite.scala │ │ │ ├── InlineTableParsingImprovementsSuite.scala │ │ │ ├── IntegratedUDFTestUtils.scala │ │ │ ├── IntervalFunctionsSuite.scala │ │ │ ├── JoinHintSuite.scala │ │ │ ├── JoinSuite.scala │ │ │ ├── JsonFunctionsSuite.scala │ │ │ ├── LateralColumnAliasSuite.scala │ │ │ ├── LegacyParameterSubstitutionSuite.scala │ │ │ ├── LocalSparkSession.scala │ │ │ ├── LogQuerySuite.scala │ │ │ ├── MapStatusEndToEndSuite.scala │ │ │ ├── MathFunctionsSuite.scala │ │ │ ├── MetadataCacheSuite.scala │ │ │ ├── MiscFunctionsSuite.scala │ │ │ ├── NestedDataSourceSuite.scala │ │ │ ├── ParametersSuite.scala │ │ │ ├── PercentileQuerySuite.scala │ │ │ ├── PlanMergeSuite.scala │ │ │ ├── PlanStabilitySuite.scala │ │ │ ├── ProcessingTimeSuite.scala │ │ │ ├── ProductAggSuite.scala │ │ │ ├── QueryGeneratorHelper.scala │ │ │ ├── QueryTest.scala │ │ │ ├── ReplaceIntegerLiteralsWithOrdinalsDataframeSuite.scala │ │ │ ├── ReplaceIntegerLiteralsWithOrdinalsSqlSuite.scala │ │ │ ├── ReplaceNullWithFalseInPredicateEndToEndSuite.scala │ │ │ ├── ResolveDefaultColumnsSuite.scala │ │ │ ├── RowSuite.scala │ │ │ ├── RuntimeConfigSuite.scala │ │ │ ├── RuntimeNullChecksV2Writes.scala │ │ │ ├── SQLInsertTestSuite.scala │ │ │ ├── SQLQuerySuite.scala │ │ │ ├── SQLQueryTestHelper.scala │ │ │ ├── SQLQueryTestSuite.scala │ │ │ ├── SSBQuerySuite.scala │ │ │ ├── STExpressionsSuite.scala │ │ │ ├── STFunctionsSuite.scala │ │ │ ├── ScalaReflectionRelationSuite.scala │ │ │ ├── SerializationSuite.scala │ │ │ ├── SessionStateSuite.scala │ │ │ ├── SetCommandSuite.scala │ │ │ ├── SparkSessionBuilderSuite.scala │ │ │ ├── SparkSessionExtensionSuite.scala │ │ │ ├── SparkSessionJobTaggingAndCancellationSuite.scala │ │ │ ├── StatisticsCollectionSuite.scala │ │ │ ├── StatisticsCollectionTestBase.scala │ │ │ ├── StringFunctionsSuite.scala │ │ │ ├── StringLiteralCoalescingSuite.scala │ │ │ ├── SubqueryHintPropagationSuite.scala │ │ │ ├── SubquerySuite.scala │ │ │ ├── TPCBase.scala │ │ │ ├── TPCDSBase.scala │ │ │ ├── TPCDSCollationQueryTestSuite.scala │ │ │ ├── TPCDSQuerySuite.scala │ │ │ ├── TPCDSQueryTestSuite.scala │ │ │ ├── TPCDSSchema.scala │ │ │ ├── TPCDSTableStats.scala │ │ │ ├── TPCHBase.scala │ │ │ ├── TPCHQuerySuite.scala │ │ │ ├── TableOptionsConstantFoldingSuite.scala │ │ │ ├── TestQueryExecutionListener.scala │ │ │ ├── TimeFunctionsSuiteBase.scala │ │ │ ├── TypedImperativeAggregateSuite.scala │ │ │ ├── UDFSuite.scala │ │ │ ├── UDTRegistrationSuite.scala │ │ │ ├── UnsafeRowChecksumSuite.scala │ │ │ ├── UnsafeRowSuite.scala │ │ │ ├── UnwrapCastInComparisonEndToEndSuite.scala │ │ │ ├── UpdateFieldsBenchmark.scala │ │ │ ├── UrlFunctionsSuite.scala │ │ │ ├── UserDefinedTypeSuite.scala │ │ │ ├── VariantEndToEndSuite.scala │ │ │ ├── VariantShreddingSuite.scala │ │ │ ├── VariantSuite.scala │ │ │ ├── VariantWriteShreddingSuite.scala │ │ │ ├── XPathFunctionsSuite.scala │ │ │ ├── XmlFunctionsSuite.scala │ │ │ ├── analysis │ │ │ │ ├── AnalysisConfOverrideSuite.scala │ │ │ │ └── resolver │ │ │ │ │ ├── AggregateExpressionResolverSuite.scala │ │ │ │ │ ├── AggregateResolverSuite.scala │ │ │ │ │ ├── AliasResolverSuite.scala │ │ │ │ │ ├── DeepResolutionSuite.scala │ │ │ │ │ ├── ExplicitlyUnsupportedResolverFeatureSuite.scala │ │ │ │ │ ├── ExpressionIdAssignerSuite.scala │ │ │ │ │ ├── HybridAnalyzerSuite.scala │ │ │ │ │ ├── IdentifierAndCteSubstitutorSuite.scala │ │ │ │ │ ├── MetadataResolverSuite.scala │ │ │ │ │ ├── NameScopeSuite.scala │ │ │ │ │ ├── ResolverGuardSuite.scala │ │ │ │ │ ├── ResolverSuite.scala │ │ │ │ │ └── ViewResolverSuite.scala │ │ │ ├── api │ │ │ │ ├── python │ │ │ │ │ └── PythonSQLUtilsSuite.scala │ │ │ │ └── r │ │ │ │ │ └── SQLUtilsSuite.scala │ │ │ ├── artifact │ │ │ │ ├── ArtifactManagerSuite.scala │ │ │ │ └── StubClassLoaderSuite.scala │ │ │ ├── catalyst │ │ │ │ └── expressions │ │ │ │ │ └── ValidateExternalTypeSuite.scala │ │ │ ├── classic │ │ │ │ ├── ColumnNodeToExpressionConverterSuite.scala │ │ │ │ ├── SQLContextSuite.scala │ │ │ │ └── SparkSessionBuilderImplementationBindingSuite.scala │ │ │ ├── collation │ │ │ │ ├── CollatedFilterPushDownToParquetSuite.scala │ │ │ │ ├── CollationAggregationSuite.scala │ │ │ │ ├── CollationExpressionWalkerSuite.scala │ │ │ │ ├── CollationSQLFunctionsSuite.scala │ │ │ │ ├── CollationSQLRegexpSuite.scala │ │ │ │ ├── CollationSuite.scala │ │ │ │ ├── CollationTypePrecedenceSuite.scala │ │ │ │ ├── DefaultCollationTestSuite.scala │ │ │ │ └── IndeterminateCollationTestSuite.scala │ │ │ ├── connector │ │ │ │ ├── AlterTableTests.scala │ │ │ │ ├── DataSourcePushdownTestUtils.scala │ │ │ │ ├── DataSourceV2DataFrameSessionCatalogSuite.scala │ │ │ │ ├── DataSourceV2DataFrameSuite.scala │ │ │ │ ├── DataSourceV2FunctionSuite.scala │ │ │ │ ├── DataSourceV2MetricsSuite.scala │ │ │ │ ├── DataSourceV2OptionSuite.scala │ │ │ │ ├── DataSourceV2SQLSessionCatalogSuite.scala │ │ │ │ ├── DataSourceV2SQLSuite.scala │ │ │ │ ├── DataSourceV2Suite.scala │ │ │ │ ├── DataSourceV2UtilsSuite.scala │ │ │ │ ├── DatasourceV2SQLBase.scala │ │ │ │ ├── DeleteFromTableSuiteBase.scala │ │ │ │ ├── DeleteFromTests.scala │ │ │ │ ├── DeltaBasedDeleteFromTableSuite.scala │ │ │ │ ├── DeltaBasedMergeIntoTableSuite.scala │ │ │ │ ├── DeltaBasedMergeIntoTableSuiteBase.scala │ │ │ │ ├── DeltaBasedMergeIntoTableUpdateAsDeleteAndInsertSuite.scala │ │ │ │ ├── DeltaBasedUpdateAsDeleteAndInsertTableSuite.scala │ │ │ │ ├── DeltaBasedUpdateTableSuite.scala │ │ │ │ ├── DeltaBasedUpdateTableSuiteBase.scala │ │ │ │ ├── DistributionAndOrderingSuiteBase.scala │ │ │ │ ├── FakeV2Provider.scala │ │ │ │ ├── FileDataSourceV2FallBackSuite.scala │ │ │ │ ├── GroupBasedDeleteFromTableSuite.scala │ │ │ │ ├── GroupBasedMergeIntoTableSuite.scala │ │ │ │ ├── GroupBasedUpdateTableSuite.scala │ │ │ │ ├── InsertIntoTests.scala │ │ │ │ ├── KeyGroupedPartitioningSuite.scala │ │ │ │ ├── LocalScanSuite.scala │ │ │ │ ├── MergeIntoDataFrameSuite.scala │ │ │ │ ├── MergeIntoTableSuiteBase.scala │ │ │ │ ├── MetadataColumnSuite.scala │ │ │ │ ├── ProcedureSuite.scala │ │ │ │ ├── PushablePredicateSuite.scala │ │ │ │ ├── RowLevelOperationSuiteBase.scala │ │ │ │ ├── SimpleWritableDataSource.scala │ │ │ │ ├── StaticProcedureSuite.scala │ │ │ │ ├── SupportsCatalogOptionsSuite.scala │ │ │ │ ├── TableCapabilityCheckSuite.scala │ │ │ │ ├── TestV2SessionCatalogBase.scala │ │ │ │ ├── UpdateTableSuiteBase.scala │ │ │ │ ├── V1ReadFallbackSuite.scala │ │ │ │ ├── V1WriteFallbackSuite.scala │ │ │ │ ├── V2CommandsCaseSensitivitySuite.scala │ │ │ │ ├── WriteDistributionAndOrderingSuite.scala │ │ │ │ ├── catalog │ │ │ │ │ └── functions │ │ │ │ │ │ └── transformFunctions.scala │ │ │ │ └── functions │ │ │ │ │ └── V2FunctionBenchmark.scala │ │ │ ├── errors │ │ │ │ ├── QueryCompilationErrorsDSv2Suite.scala │ │ │ │ ├── QueryCompilationErrorsSuite.scala │ │ │ │ ├── QueryContextSuite.scala │ │ │ │ ├── QueryExecutionAnsiErrorsSuite.scala │ │ │ │ ├── QueryExecutionErrorsSuite.scala │ │ │ │ └── QueryParsingErrorsSuite.scala │ │ │ ├── execution │ │ │ │ ├── AggregatingAccumulatorSuite.scala │ │ │ │ ├── BaseScriptTransformationSuite.scala │ │ │ │ ├── BroadcastExchangeSuite.scala │ │ │ │ ├── CoGroupedIteratorSuite.scala │ │ │ │ ├── CoalesceShufflePartitionsSuite.scala │ │ │ │ ├── ColumnarRulesSuite.scala │ │ │ │ ├── DataSourceScanExecRedactionSuite.scala │ │ │ │ ├── DeprecatedWholeStageCodegenSuite.scala │ │ │ │ ├── ExchangeSuite.scala │ │ │ │ ├── ExecuteImmediateEndToEndSuite.scala │ │ │ │ ├── ExternalAppendOnlyUnsafeRowArrayBenchmark.scala │ │ │ │ ├── ExternalAppendOnlyUnsafeRowArraySuite.scala │ │ │ │ ├── GlobalTempViewSuite.scala │ │ │ │ ├── GroupedIteratorSuite.scala │ │ │ │ ├── HiveResultSuite.scala │ │ │ │ ├── InsertSortForLimitAndOffsetSuite.scala │ │ │ │ ├── LogicalPlanTagInSparkPlanSuite.scala │ │ │ │ ├── OptimizeMetadataOnlyQuerySuite.scala │ │ │ │ ├── PlannerSuite.scala │ │ │ │ ├── ProjectedOrderingAndPartitioningSuite.scala │ │ │ │ ├── QueryExecutionSuite.scala │ │ │ │ ├── QueryPlanningTrackerEndToEndSuite.scala │ │ │ │ ├── ReferenceSort.scala │ │ │ │ ├── RemoveRedundantProjectsSuite.scala │ │ │ │ ├── RemoveRedundantSortsSuite.scala │ │ │ │ ├── RemoveRedundantWindowGroupLimitsSuite.scala │ │ │ │ ├── ReplaceHashWithSortAggSuite.scala │ │ │ │ ├── ReuseExchangeAndSubquerySuite.scala │ │ │ │ ├── RowToColumnConverterSuite.scala │ │ │ │ ├── SQLExecutionSuite.scala │ │ │ │ ├── SQLFunctionSuite.scala │ │ │ │ ├── SQLJsonProtocolSuite.scala │ │ │ │ ├── SQLViewSuite.scala │ │ │ │ ├── SQLViewTestSuite.scala │ │ │ │ ├── SQLWindowFunctionSuite.scala │ │ │ │ ├── SameResultSuite.scala │ │ │ │ ├── ShowNamespacesParserSuite.scala │ │ │ │ ├── ShufflePartitionsUtilSuite.scala │ │ │ │ ├── SortSuite.scala │ │ │ │ ├── SparkPlanSuite.scala │ │ │ │ ├── SparkPlanTest.scala │ │ │ │ ├── SparkPlannerSuite.scala │ │ │ │ ├── SparkScriptTransformationSuite.scala │ │ │ │ ├── SparkSqlParserSuite.scala │ │ │ │ ├── SubExprEliminationBenchmark.scala │ │ │ │ ├── TakeOrderedAndProjectSuite.scala │ │ │ │ ├── TestUncaughtExceptionHandler.scala │ │ │ │ ├── UnsafeFixedWidthAggregationMapSuite.scala │ │ │ │ ├── UnsafeKVExternalSorterSuite.scala │ │ │ │ ├── UnsafeRowSerializerSuite.scala │ │ │ │ ├── WholeStageCodegenSparkSubmitSuite.scala │ │ │ │ ├── WholeStageCodegenSuite.scala │ │ │ │ ├── adaptive │ │ │ │ │ ├── AdaptiveQueryExecSuite.scala │ │ │ │ │ └── AdaptiveTestUtils.scala │ │ │ │ ├── aggregate │ │ │ │ │ └── SortBasedAggregationStoreSuite.scala │ │ │ │ ├── arrow │ │ │ │ │ ├── ArrowConvertersSuite.scala │ │ │ │ │ ├── ArrowFileReadWriteSuite.scala │ │ │ │ │ └── ArrowWriterSuite.scala │ │ │ │ ├── benchmark │ │ │ │ │ ├── AggregateBenchmark.scala │ │ │ │ │ ├── AnsiIntervalSortBenchmark.scala │ │ │ │ │ ├── Base64Benchmark.scala │ │ │ │ │ ├── BloomFilterBenchmark.scala │ │ │ │ │ ├── BuiltInDataSourceWriteBenchmark.scala │ │ │ │ │ ├── ByteArrayBenchmark.scala │ │ │ │ │ ├── CharVarcharBenchmark.scala │ │ │ │ │ ├── CollationBenchmark.scala │ │ │ │ │ ├── ConstantColumnVectorBenchmark.scala │ │ │ │ │ ├── DataSourceReadBenchmark.scala │ │ │ │ │ ├── DataSourceWriteBenchmark.scala │ │ │ │ │ ├── DateTimeBenchmark.scala │ │ │ │ │ ├── DateTimeRebaseBenchmark.scala │ │ │ │ │ ├── EncodeBenchmark.scala │ │ │ │ │ ├── ExtractBenchmark.scala │ │ │ │ │ ├── FilterPushdownBenchmark.scala │ │ │ │ │ ├── GenerateExecBenchmark.scala │ │ │ │ │ ├── HashedRelationMetricsBenchmark.scala │ │ │ │ │ ├── InExpressionBenchmark.scala │ │ │ │ │ ├── InsertTableWithDynamicPartitionsBenchmark.scala │ │ │ │ │ ├── IntervalBenchmark.scala │ │ │ │ │ ├── JoinBenchmark.scala │ │ │ │ │ ├── LargeRowBenchmark.scala │ │ │ │ │ ├── MakeDateTimeBenchmark.scala │ │ │ │ │ ├── MetadataStructBenchmark.scala │ │ │ │ │ ├── MiscBenchmark.scala │ │ │ │ │ ├── NestedSchemaPruningBenchmark.scala │ │ │ │ │ ├── OrcNestedSchemaPruningBenchmark.scala │ │ │ │ │ ├── OrcV2NestedSchemaPruningBenchmark.scala │ │ │ │ │ ├── ParquetNestedPredicatePushDownBenchmark.scala │ │ │ │ │ ├── ParquetNestedSchemaPruningBenchmark.scala │ │ │ │ │ ├── PrimitiveArrayBenchmark.scala │ │ │ │ │ ├── RangeBenchmark.scala │ │ │ │ │ ├── RecursiveCTEBenchmark.scala │ │ │ │ │ ├── SetOperationsBenchmark.scala │ │ │ │ │ ├── SortBenchmark.scala │ │ │ │ │ ├── SqlBasedBenchmark.scala │ │ │ │ │ ├── StateStoreBasicOperationsBenchmark.scala │ │ │ │ │ ├── StringFunctionsBenchmark.scala │ │ │ │ │ ├── TPCDSQueryBenchmark.scala │ │ │ │ │ ├── TPCDSQueryBenchmarkArguments.scala │ │ │ │ │ ├── TakeOrderedAndProjectBenchmark.scala │ │ │ │ │ ├── TopKBenchmark.scala │ │ │ │ │ ├── UDFBenchmark.scala │ │ │ │ │ ├── UnsafeArrayDataBenchmark.scala │ │ │ │ │ ├── WideSchemaBenchmark.scala │ │ │ │ │ └── WideTableBenchmark.scala │ │ │ │ ├── bucketing │ │ │ │ │ └── CoalesceBucketsInJoinSuite.scala │ │ │ │ ├── columnar │ │ │ │ │ ├── CachedBatchSerializerSuite.scala │ │ │ │ │ ├── ColumnStatsSuite.scala │ │ │ │ │ ├── ColumnTypeSuite.scala │ │ │ │ │ ├── ColumnarDataTypeUtils.scala │ │ │ │ │ ├── ColumnarTestUtils.scala │ │ │ │ │ ├── InMemoryColumnarBenchmark.scala │ │ │ │ │ ├── InMemoryColumnarQuerySuite.scala │ │ │ │ │ ├── InMemoryRelationSuite.scala │ │ │ │ │ ├── NullableColumnAccessorSuite.scala │ │ │ │ │ ├── NullableColumnBuilderSuite.scala │ │ │ │ │ ├── PartitionBatchPruningSuite.scala │ │ │ │ │ ├── RefCountedTestCachedBatchSerializerSuite.scala │ │ │ │ │ └── compression │ │ │ │ │ │ ├── BooleanBitSetSuite.scala │ │ │ │ │ │ ├── CompressionSchemeBenchmark.scala │ │ │ │ │ │ ├── DictionaryEncodingSuite.scala │ │ │ │ │ │ ├── IntegralDeltaSuite.scala │ │ │ │ │ │ ├── PassThroughEncodingSuite.scala │ │ │ │ │ │ ├── RunLengthEncodingSuite.scala │ │ │ │ │ │ └── TestCompressibleColumnBuilder.scala │ │ │ │ ├── command │ │ │ │ │ ├── AlignAssignmentsSuiteBase.scala │ │ │ │ │ ├── AlignMergeAssignmentsSuite.scala │ │ │ │ │ ├── AlignUpdateAssignmentsSuite.scala │ │ │ │ │ ├── AlterNamespaceSetLocationParserSuite.scala │ │ │ │ │ ├── AlterNamespaceSetLocationSuiteBase.scala │ │ │ │ │ ├── AlterNamespaceSetPropertiesParserSuite.scala │ │ │ │ │ ├── AlterNamespaceSetPropertiesSuiteBase.scala │ │ │ │ │ ├── AlterNamespaceUnsetPropertiesParserSuite.scala │ │ │ │ │ ├── AlterNamespaceUnsetPropertiesSuiteBase.scala │ │ │ │ │ ├── AlterTableAddColumnsSuiteBase.scala │ │ │ │ │ ├── AlterTableAddPartitionParserSuite.scala │ │ │ │ │ ├── AlterTableAddPartitionSuiteBase.scala │ │ │ │ │ ├── AlterTableClusterByParserSuite.scala │ │ │ │ │ ├── AlterTableClusterBySuiteBase.scala │ │ │ │ │ ├── AlterTableDropColumnParserSuite.scala │ │ │ │ │ ├── AlterTableDropColumnSuiteBase.scala │ │ │ │ │ ├── AlterTableDropConstraintParseSuite.scala │ │ │ │ │ ├── AlterTableDropPartitionParserSuite.scala │ │ │ │ │ ├── AlterTableDropPartitionSuiteBase.scala │ │ │ │ │ ├── AlterTableRecoverPartitionsParserSuite.scala │ │ │ │ │ ├── AlterTableRecoverPartitionsSuiteBase.scala │ │ │ │ │ ├── AlterTableRenameColumnParserSuite.scala │ │ │ │ │ ├── AlterTableRenameColumnSuiteBase.scala │ │ │ │ │ ├── AlterTableRenameParserSuite.scala │ │ │ │ │ ├── AlterTableRenamePartitionParserSuite.scala │ │ │ │ │ ├── AlterTableRenamePartitionSuiteBase.scala │ │ │ │ │ ├── AlterTableRenameSuiteBase.scala │ │ │ │ │ ├── AlterTableReplaceColumnsSuiteBase.scala │ │ │ │ │ ├── AlterTableSetLocationParserSuite.scala │ │ │ │ │ ├── AlterTableSetLocationSuiteBase.scala │ │ │ │ │ ├── AlterTableSetSerdeParserSuite.scala │ │ │ │ │ ├── AlterTableSetSerdeSuiteBase.scala │ │ │ │ │ ├── AlterTableSetTblPropertiesParserSuite.scala │ │ │ │ │ ├── AlterTableSetTblPropertiesSuiteBase.scala │ │ │ │ │ ├── AlterTableUnsetTblPropertiesParserSuite.scala │ │ │ │ │ ├── AlterTableUnsetTblPropertiesSuiteBase.scala │ │ │ │ │ ├── CharVarcharDDLTestBase.scala │ │ │ │ │ ├── CheckConstraintParseSuite.scala │ │ │ │ │ ├── CommandUtilsSuite.scala │ │ │ │ │ ├── ConstraintParseSuiteBase.scala │ │ │ │ │ ├── CreateNamespaceParserSuite.scala │ │ │ │ │ ├── CreateNamespaceSuiteBase.scala │ │ │ │ │ ├── CreatePipelineDatasetAsSelectParserSuiteBase.scala │ │ │ │ │ ├── CreateSQLFunctionParserSuite.scala │ │ │ │ │ ├── CreateTableClusterBySuiteBase.scala │ │ │ │ │ ├── DDLCommandTestUtils.scala │ │ │ │ │ ├── DDLParserSuite.scala │ │ │ │ │ ├── DDLSuite.scala │ │ │ │ │ ├── DeclareVariableParserSuite.scala │ │ │ │ │ ├── DescribeNamespaceParserSuite.scala │ │ │ │ │ ├── DescribeNamespaceSuiteBase.scala │ │ │ │ │ ├── DescribeTableParserSuite.scala │ │ │ │ │ ├── DescribeTableSuiteBase.scala │ │ │ │ │ ├── DropNamespaceParserSuite.scala │ │ │ │ │ ├── DropNamespaceSuiteBase.scala │ │ │ │ │ ├── DropTableParserSuite.scala │ │ │ │ │ ├── DropTableSuiteBase.scala │ │ │ │ │ ├── DropVariableParserSuite.scala │ │ │ │ │ ├── ForeignKeyConstraintParseSuite.scala │ │ │ │ │ ├── MsckRepairTableParserSuite.scala │ │ │ │ │ ├── MsckRepairTableSuiteBase.scala │ │ │ │ │ ├── PlanResolutionSuite.scala │ │ │ │ │ ├── PrimaryKeyConstraintParseSuite.scala │ │ │ │ │ ├── ShowColumnsParserSuite.scala │ │ │ │ │ ├── ShowColumnsSuiteBase.scala │ │ │ │ │ ├── ShowCreateTableParserSuite.scala │ │ │ │ │ ├── ShowCreateTableSuiteBase.scala │ │ │ │ │ ├── ShowFunctionsParserSuite.scala │ │ │ │ │ ├── ShowFunctionsSuiteBase.scala │ │ │ │ │ ├── ShowNamespacesSuiteBase.scala │ │ │ │ │ ├── ShowPartitionsParserSuite.scala │ │ │ │ │ ├── ShowPartitionsSuiteBase.scala │ │ │ │ │ ├── ShowTablesParserSuite.scala │ │ │ │ │ ├── ShowTablesSuiteBase.scala │ │ │ │ │ ├── ShowTblPropertiesParserSuite.scala │ │ │ │ │ ├── ShowTblPropertiesSuiteBase.scala │ │ │ │ │ ├── TestsV1AndV2Commands.scala │ │ │ │ │ ├── TruncateTableParserSuite.scala │ │ │ │ │ ├── TruncateTableSuiteBase.scala │ │ │ │ │ ├── UniqueConstraintParseSuite.scala │ │ │ │ │ ├── v1 │ │ │ │ │ │ ├── AlterNamespaceSetLocationSuite.scala │ │ │ │ │ │ ├── AlterNamespaceSetPropertiesSuite.scala │ │ │ │ │ │ ├── AlterNamespaceUnsetPropertiesSuiteBase.scala │ │ │ │ │ │ ├── AlterTableAddColumnsSuite.scala │ │ │ │ │ │ ├── AlterTableAddPartitionSuite.scala │ │ │ │ │ │ ├── AlterTableClusterBySuite.scala │ │ │ │ │ │ ├── AlterTableDropColumnSuite.scala │ │ │ │ │ │ ├── AlterTableDropPartitionSuite.scala │ │ │ │ │ │ ├── AlterTableRecoverPartitionsSuite.scala │ │ │ │ │ │ ├── AlterTableRenameColumnSuite.scala │ │ │ │ │ │ ├── AlterTableRenamePartitionSuite.scala │ │ │ │ │ │ ├── AlterTableRenameSuite.scala │ │ │ │ │ │ ├── AlterTableSetLocationSuite.scala │ │ │ │ │ │ ├── AlterTableSetSerdeSuite.scala │ │ │ │ │ │ ├── AlterTableSetTblPropertiesSuite.scala │ │ │ │ │ │ ├── AlterTableUnsetTblPropertiesSuite.scala │ │ │ │ │ │ ├── CommandSuiteBase.scala │ │ │ │ │ │ ├── CreateNamespaceSuite.scala │ │ │ │ │ │ ├── CreateTableClusterBySuite.scala │ │ │ │ │ │ ├── DescribeNamespaceSuite.scala │ │ │ │ │ │ ├── DescribeTableSuite.scala │ │ │ │ │ │ ├── DropNamespaceSuite.scala │ │ │ │ │ │ ├── DropTableSuite.scala │ │ │ │ │ │ ├── MsckRepairTableSuite.scala │ │ │ │ │ │ ├── ShowColumnsSuite.scala │ │ │ │ │ │ ├── ShowCreateTableSuite.scala │ │ │ │ │ │ ├── ShowFunctionsSuite.scala │ │ │ │ │ │ ├── ShowNamespacesSuite.scala │ │ │ │ │ │ ├── ShowPartitionsSuite.scala │ │ │ │ │ │ ├── ShowTablesSuite.scala │ │ │ │ │ │ ├── ShowTblPropertiesSuite.scala │ │ │ │ │ │ └── TruncateTableSuite.scala │ │ │ │ │ └── v2 │ │ │ │ │ │ ├── AlterNamespaceSetLocationSuite.scala │ │ │ │ │ │ ├── AlterNamespaceSetPropertiesSuite.scala │ │ │ │ │ │ ├── AlterNamespaceUnsetPropertiesSuite.scala │ │ │ │ │ │ ├── AlterTableAddColumnsSuite.scala │ │ │ │ │ │ ├── AlterTableAddPartitionSuite.scala │ │ │ │ │ │ ├── AlterTableClusterBySuite.scala │ │ │ │ │ │ ├── AlterTableDropColumnSuite.scala │ │ │ │ │ │ ├── AlterTableDropPartitionSuite.scala │ │ │ │ │ │ ├── AlterTableRecoverPartitionsSuite.scala │ │ │ │ │ │ ├── AlterTableRenameColumnSuite.scala │ │ │ │ │ │ ├── AlterTableRenamePartitionSuite.scala │ │ │ │ │ │ ├── AlterTableRenameSuite.scala │ │ │ │ │ │ ├── AlterTableReplaceColumnsSuite.scala │ │ │ │ │ │ ├── AlterTableSetLocationSuite.scala │ │ │ │ │ │ ├── AlterTableSetSerdeSuite.scala │ │ │ │ │ │ ├── AlterTableSetTblPropertiesSuite.scala │ │ │ │ │ │ ├── AlterTableUnsetTblPropertiesSuite.scala │ │ │ │ │ │ ├── CheckConstraintSuite.scala │ │ │ │ │ │ ├── CommandSuiteBase.scala │ │ │ │ │ │ ├── CreateFlowCommandSuite.scala │ │ │ │ │ │ ├── CreateMaterializedViewAsSelectParserSuite.scala │ │ │ │ │ │ ├── CreateNamespaceSuite.scala │ │ │ │ │ │ ├── CreateStreamingTableAsSelectParserSuite.scala │ │ │ │ │ │ ├── CreateStreamingTableParserSuite.scala │ │ │ │ │ │ ├── CreateTableClusterBySuite.scala │ │ │ │ │ │ ├── DescribeNamespaceSuite.scala │ │ │ │ │ │ ├── DescribeTableSuite.scala │ │ │ │ │ │ ├── DropConstraintSuite.scala │ │ │ │ │ │ ├── DropNamespaceSuite.scala │ │ │ │ │ │ ├── DropTableSuite.scala │ │ │ │ │ │ ├── ForeignKeyConstraintSuite.scala │ │ │ │ │ │ ├── MsckRepairTableSuite.scala │ │ │ │ │ │ ├── PrimaryKeyConstraintSuite.scala │ │ │ │ │ │ ├── ShowColumnsSuite.scala │ │ │ │ │ │ ├── ShowCreateTableSuite.scala │ │ │ │ │ │ ├── ShowFunctionsSuite.scala │ │ │ │ │ │ ├── ShowNamespacesSuite.scala │ │ │ │ │ │ ├── ShowPartitionsSuite.scala │ │ │ │ │ │ ├── ShowTablesSuite.scala │ │ │ │ │ │ ├── ShowTblPropertiesSuite.scala │ │ │ │ │ │ ├── TruncateTableSuite.scala │ │ │ │ │ │ └── UniqueConstraintSuite.scala │ │ │ │ ├── datasources │ │ │ │ │ ├── BasicWriteJobStatsTrackerMetricSuite.scala │ │ │ │ │ ├── BasicWriteTaskStatsTrackerSuite.scala │ │ │ │ │ ├── BucketingUtilsSuite.scala │ │ │ │ │ ├── CommonFileDataSourceSuite.scala │ │ │ │ │ ├── CustomWriteTaskStatsTrackerSuite.scala │ │ │ │ │ ├── DataSourceManagerSuite.scala │ │ │ │ │ ├── DataSourceResolverSuite.scala │ │ │ │ │ ├── DataSourceStrategySuite.scala │ │ │ │ │ ├── DataSourceSuite.scala │ │ │ │ │ ├── FileBasedDataSourceTest.scala │ │ │ │ │ ├── FileFormatWriterSuite.scala │ │ │ │ │ ├── FileIndexSuite.scala │ │ │ │ │ ├── FileMetadataStructSuite.scala │ │ │ │ │ ├── FileResolverSuite.scala │ │ │ │ │ ├── FileSourceAggregatePushDownSuite.scala │ │ │ │ │ ├── FileSourceCodecSuite.scala │ │ │ │ │ ├── FileSourceCustomMetadataStructSuite.scala │ │ │ │ │ ├── FileSourceStrategySuite.scala │ │ │ │ │ ├── HadoopFileLinesReaderSuite.scala │ │ │ │ │ ├── InMemoryTableMetricSuite.scala │ │ │ │ │ ├── PathFilterStrategySuite.scala │ │ │ │ │ ├── PathFilterSuite.scala │ │ │ │ │ ├── PruneFileSourcePartitionsSuite.scala │ │ │ │ │ ├── PrunePartitionSuiteBase.scala │ │ │ │ │ ├── PushVariantIntoScanSuite.scala │ │ │ │ │ ├── ReadNestedSchemaTest.scala │ │ │ │ │ ├── ReadSchemaSuite.scala │ │ │ │ │ ├── ReadSchemaTest.scala │ │ │ │ │ ├── RowDataSourceStrategySuite.scala │ │ │ │ │ ├── SaveIntoDataSourceCommandSuite.scala │ │ │ │ │ ├── SchemaPruningSuite.scala │ │ │ │ │ ├── TableLocationSuite.scala │ │ │ │ │ ├── V1WriteCommandSuite.scala │ │ │ │ │ ├── binaryfile │ │ │ │ │ │ └── BinaryFileFormatSuite.scala │ │ │ │ │ ├── csv │ │ │ │ │ │ ├── CSVBenchmark.scala │ │ │ │ │ │ ├── CSVParsingOptionsSuite.scala │ │ │ │ │ │ ├── CSVSuite.scala │ │ │ │ │ │ └── TestCsvData.scala │ │ │ │ │ ├── jdbc │ │ │ │ │ │ ├── DriverRegistrySuite.scala │ │ │ │ │ │ ├── JdbcUtilsSuite.scala │ │ │ │ │ │ └── connection │ │ │ │ │ │ │ ├── BasicConnectionProviderSuite.scala │ │ │ │ │ │ │ ├── ConnectionProviderSuite.scala │ │ │ │ │ │ │ ├── ConnectionProviderSuiteBase.scala │ │ │ │ │ │ │ ├── DB2ConnectionProviderSuite.scala │ │ │ │ │ │ │ ├── IntentionallyFaultyConnectionProvider.scala │ │ │ │ │ │ │ ├── MSSQLConnectionProviderSuite.scala │ │ │ │ │ │ │ ├── MariaDBConnectionProviderSuite.scala │ │ │ │ │ │ │ ├── OracleConnectionProviderSuite.scala │ │ │ │ │ │ │ ├── PostgresConnectionProviderSuite.scala │ │ │ │ │ │ │ └── TestDriver.scala │ │ │ │ │ ├── json │ │ │ │ │ │ ├── JsonBenchmark.scala │ │ │ │ │ │ ├── JsonParsingOptionsSuite.scala │ │ │ │ │ │ ├── JsonSuite.scala │ │ │ │ │ │ └── TestJsonData.scala │ │ │ │ │ ├── noop │ │ │ │ │ │ ├── NoopStreamSuite.scala │ │ │ │ │ │ └── NoopSuite.scala │ │ │ │ │ ├── orc │ │ │ │ │ │ ├── OrcColumnarBatchReaderSuite.scala │ │ │ │ │ │ ├── OrcEncryptionSuite.scala │ │ │ │ │ │ ├── OrcFilterSuite.scala │ │ │ │ │ │ ├── OrcPartitionDiscoverySuite.scala │ │ │ │ │ │ ├── OrcQuerySuite.scala │ │ │ │ │ │ ├── OrcSourceSuite.scala │ │ │ │ │ │ ├── OrcTest.scala │ │ │ │ │ │ ├── OrcV1FilterSuite.scala │ │ │ │ │ │ ├── OrcV1SchemaPruningSuite.scala │ │ │ │ │ │ └── OrcV2SchemaPruningSuite.scala │ │ │ │ │ ├── parquet │ │ │ │ │ │ ├── ParquetAvroCompatibilitySuite.scala │ │ │ │ │ │ ├── ParquetColumnIndexSuite.scala │ │ │ │ │ │ ├── ParquetCommitterSuite.scala │ │ │ │ │ │ ├── ParquetCompatibilityTest.scala │ │ │ │ │ │ ├── ParquetCompressionCodecPrecedenceSuite.scala │ │ │ │ │ │ ├── ParquetDeltaByteArrayEncodingSuite.scala │ │ │ │ │ │ ├── ParquetDeltaEncodingSuite.scala │ │ │ │ │ │ ├── ParquetDeltaLengthByteArrayEncodingSuite.scala │ │ │ │ │ │ ├── ParquetEncodingSuite.scala │ │ │ │ │ │ ├── ParquetFieldIdIOSuite.scala │ │ │ │ │ │ ├── ParquetFieldIdSchemaSuite.scala │ │ │ │ │ │ ├── ParquetFileFormatSuite.scala │ │ │ │ │ │ ├── ParquetFileMetadataStructRowIndexSuite.scala │ │ │ │ │ │ ├── ParquetFilterSuite.scala │ │ │ │ │ │ ├── ParquetIOSuite.scala │ │ │ │ │ │ ├── ParquetInteroperabilitySuite.scala │ │ │ │ │ │ ├── ParquetPartitionDiscoverySuite.scala │ │ │ │ │ │ ├── ParquetProtobufCompatibilitySuite.scala │ │ │ │ │ │ ├── ParquetQuerySuite.scala │ │ │ │ │ │ ├── ParquetRebaseDatetimeSuite.scala │ │ │ │ │ │ ├── ParquetRowIndexSuite.scala │ │ │ │ │ │ ├── ParquetSchemaPruningSuite.scala │ │ │ │ │ │ ├── ParquetSchemaSuite.scala │ │ │ │ │ │ ├── ParquetTest.scala │ │ │ │ │ │ ├── ParquetThriftCompatibilitySuite.scala │ │ │ │ │ │ ├── ParquetTypeWideningSuite.scala │ │ │ │ │ │ ├── ParquetVariantShreddingSuite.scala │ │ │ │ │ │ ├── ParquetVectorizedSuite.scala │ │ │ │ │ │ └── VariantInferShreddingSuite.scala │ │ │ │ │ ├── text │ │ │ │ │ │ ├── TextSuite.scala │ │ │ │ │ │ └── WholeTextFileSuite.scala │ │ │ │ │ ├── v2 │ │ │ │ │ │ ├── DSV2JoinPushDownAliasGenerationSuite.scala │ │ │ │ │ │ ├── DataSourceV2StrategySuite.scala │ │ │ │ │ │ ├── FileTableSuite.scala │ │ │ │ │ │ ├── FileWriterFactorySuite.scala │ │ │ │ │ │ ├── V2PredicateSuite.scala │ │ │ │ │ │ ├── V2SessionCatalogSuite.scala │ │ │ │ │ │ ├── jdbc │ │ │ │ │ │ │ ├── DerbyTableCatalogSuite.scala │ │ │ │ │ │ │ └── JDBCTableCatalogSuite.scala │ │ │ │ │ │ └── state │ │ │ │ │ │ │ ├── StateDataSourceChangeDataReadSuite.scala │ │ │ │ │ │ │ ├── StateDataSourceReadSuite.scala │ │ │ │ │ │ │ ├── StateDataSourceTestBase.scala │ │ │ │ │ │ │ ├── StateDataSourceTransformWithStateSuite.scala │ │ │ │ │ │ │ └── StatePartitionAllColumnFamiliesReaderSuite.scala │ │ │ │ │ └── xml │ │ │ │ │ │ ├── TestUtils.scala │ │ │ │ │ │ ├── TestXmlData.scala │ │ │ │ │ │ ├── XmlInferSchemaSuite.scala │ │ │ │ │ │ ├── XmlPartitioningSuite.scala │ │ │ │ │ │ ├── XmlSuite.scala │ │ │ │ │ │ ├── XmlVariantSuite.scala │ │ │ │ │ │ ├── parsers │ │ │ │ │ │ ├── StaxXmlGeneratorSuite.scala │ │ │ │ │ │ └── StaxXmlParserUtilsSuite.scala │ │ │ │ │ │ └── util │ │ │ │ │ │ └── XSDToSchemaSuite.scala │ │ │ │ ├── debug │ │ │ │ │ └── DebuggingSuite.scala │ │ │ │ ├── exchange │ │ │ │ │ ├── EnsureRequirementsSuite.scala │ │ │ │ │ └── ValidateRequirementsSuite.scala │ │ │ │ ├── history │ │ │ │ │ ├── SQLEventFilterBuilderSuite.scala │ │ │ │ │ └── SQLLiveEntitiesEventFilterSuite.scala │ │ │ │ ├── joins │ │ │ │ │ ├── BroadcastJoinSuite.scala │ │ │ │ │ ├── ExistenceJoinSuite.scala │ │ │ │ │ ├── HashedRelationSuite.scala │ │ │ │ │ ├── InnerJoinSuite.scala │ │ │ │ │ ├── OuterJoinSuite.scala │ │ │ │ │ └── SingleJoinSuite.scala │ │ │ │ ├── metric │ │ │ │ │ ├── CustomMetricsSuite.scala │ │ │ │ │ ├── SQLMetricsSuite.scala │ │ │ │ │ └── SQLMetricsTestUtils.scala │ │ │ │ ├── python │ │ │ │ │ ├── BatchEvalPythonExecSuite.scala │ │ │ │ │ ├── ExtractPythonUDFsSuite.scala │ │ │ │ │ ├── PythonDataSourceSuite.scala │ │ │ │ │ ├── PythonUDFSuite.scala │ │ │ │ │ ├── PythonUDTFSuite.scala │ │ │ │ │ ├── PythonWorkerLogsSuite.scala │ │ │ │ │ ├── RowQueueSuite.scala │ │ │ │ │ └── streaming │ │ │ │ │ │ ├── BaseStreamingArrowWriterSuite.scala │ │ │ │ │ │ ├── PythonForeachWriterSuite.scala │ │ │ │ │ │ ├── PythonStreamingDataSourceSuite.scala │ │ │ │ │ │ └── TransformWithStateInPySparkStateServerSuite.scala │ │ │ │ ├── streaming │ │ │ │ │ ├── AsyncProgressTrackingMicroBatchExecutionSuite.scala │ │ │ │ │ ├── CheckpointFileManagerSuite.scala │ │ │ │ │ ├── ChecksumCheckpointFileManagerSuite.scala │ │ │ │ │ ├── CompactibleFileStreamLogSuite.scala │ │ │ │ │ ├── EventTimeWatermarkWithWatermarkDefInSelectSuite.scala │ │ │ │ │ ├── FileStreamSinkLogSuite.scala │ │ │ │ │ ├── HDFSMetadataLogSuite.scala │ │ │ │ │ ├── MemorySinkSuite.scala │ │ │ │ │ ├── MergingSessionsIteratorSuite.scala │ │ │ │ │ ├── MergingSortWithSessionWindowStateIteratorSuite.scala │ │ │ │ │ ├── MicroBatchExecutionSuite.scala │ │ │ │ │ ├── OffsetSeqLogSuite.scala │ │ │ │ │ ├── ProcessingTimeExecutorSuite.scala │ │ │ │ │ ├── StreamMetadataSuite.scala │ │ │ │ │ ├── StreamRelationSuite.scala │ │ │ │ │ ├── UpdatingSessionsIteratorSuite.scala │ │ │ │ │ ├── WatermarkTrackerSuite.scala │ │ │ │ │ ├── sources │ │ │ │ │ │ ├── ConsoleWriteSupportSuite.scala │ │ │ │ │ │ ├── ContinuousMemorySuite.scala │ │ │ │ │ │ ├── ForeachBatchSinkSuite.scala │ │ │ │ │ │ ├── ForeachWriterSuite.scala │ │ │ │ │ │ ├── RatePerMicroBatchProviderSuite.scala │ │ │ │ │ │ ├── RateStreamProviderSuite.scala │ │ │ │ │ │ └── TextSocketStreamSuite.scala │ │ │ │ │ └── state │ │ │ │ │ │ ├── AutoSnapshotLoaderSuite.scala │ │ │ │ │ │ ├── FailureInjectionCheckpointFileManager.scala │ │ │ │ │ │ ├── FlatMapGroupsWithStateExecHelperSuite.scala │ │ │ │ │ │ ├── ListStateSuite.scala │ │ │ │ │ │ ├── MapStateSuite.scala │ │ │ │ │ │ ├── MemoryStateStore.scala │ │ │ │ │ │ ├── OfflineStateRepartitionSuite.scala │ │ │ │ │ │ ├── OperatorStateMetadataSuite.scala │ │ │ │ │ │ ├── RocksDBCheckpointFailureInjectionSuite.scala │ │ │ │ │ │ ├── RocksDBLineageSuite.scala │ │ │ │ │ │ ├── RocksDBStateStoreCheckpointFormatV2Suite.scala │ │ │ │ │ │ ├── RocksDBStateStoreIntegrationSuite.scala │ │ │ │ │ │ ├── RocksDBStateStoreLockHardeningSuite.scala │ │ │ │ │ │ ├── RocksDBStateStoreSuite.scala │ │ │ │ │ │ ├── RocksDBSuite.scala │ │ │ │ │ │ ├── StateSchemaCompatibilityCheckerSuite.scala │ │ │ │ │ │ ├── StateStoreCompatibilitySuite.scala │ │ │ │ │ │ ├── StateStoreCoordinatorSuite.scala │ │ │ │ │ │ ├── StateStoreInstanceMetricSuite.scala │ │ │ │ │ │ ├── StateStoreRDDSuite.scala │ │ │ │ │ │ ├── StateStoreRowChecksumSuite.scala │ │ │ │ │ │ ├── StateStoreSuite.scala │ │ │ │ │ │ ├── StatefulProcessorHandleSuite.scala │ │ │ │ │ │ ├── StreamingAggregationStateManagerSuite.scala │ │ │ │ │ │ ├── StreamingSessionWindowStateManagerSuite.scala │ │ │ │ │ │ ├── SymmetricHashJoinStateManagerSuite.scala │ │ │ │ │ │ ├── TimerSuite.scala │ │ │ │ │ │ └── ValueStateSuite.scala │ │ │ │ ├── ui │ │ │ │ │ ├── AllExecutionsPageSuite.scala │ │ │ │ │ ├── MetricsAggregationBenchmark.scala │ │ │ │ │ ├── SQLAppStatusListenerSuite.scala │ │ │ │ │ ├── SparkPlanGraphSuite.scala │ │ │ │ │ ├── SparkPlanInfoSuite.scala │ │ │ │ │ └── UISeleniumSuite.scala │ │ │ │ └── vectorized │ │ │ │ │ ├── ColumnVectorSuite.scala │ │ │ │ │ ├── ColumnVectorUtilsSuite.scala │ │ │ │ │ ├── ColumnarBatchBenchmark.scala │ │ │ │ │ ├── ColumnarBatchSuite.scala │ │ │ │ │ └── ConstantColumnVectorSuite.scala │ │ │ ├── expressions │ │ │ │ ├── ExpressionInfoSuite.scala │ │ │ │ └── ReduceAggregatorSuite.scala │ │ │ ├── internal │ │ │ │ ├── CatalogSuite.scala │ │ │ │ ├── ColumnNodeSuite.scala │ │ │ │ ├── DeprecatedCreateExternalTableSuite.scala │ │ │ │ ├── ExecutorSideSQLConfSuite.scala │ │ │ │ ├── SQLConfEntrySuite.scala │ │ │ │ ├── SQLConfGetterSuite.scala │ │ │ │ ├── SQLConfSuite.scala │ │ │ │ ├── SharedStateSuite.scala │ │ │ │ ├── VariableSubstitutionSuite.scala │ │ │ │ └── types │ │ │ │ │ └── SpatialReferenceSystemMapperSuite.java │ │ │ ├── jdbc │ │ │ │ ├── DummyDatabaseDialect.scala │ │ │ │ ├── JDBCMetricsSuite.scala │ │ │ │ ├── JDBCNestedDataSourceSuite.scala │ │ │ │ ├── JDBCSuite.scala │ │ │ │ ├── JDBCV2Suite.scala │ │ │ │ ├── JDBCWriteSuite.scala │ │ │ │ └── v2 │ │ │ │ │ ├── JDBCV2JoinPushdownIntegrationSuiteBase.scala │ │ │ │ │ └── JDBCV2JoinPushdownSuite.scala │ │ │ ├── scripting │ │ │ │ ├── SqlScriptingE2eSuite.scala │ │ │ │ ├── SqlScriptingExecutionNodeSuite.scala │ │ │ │ ├── SqlScriptingExecutionSuite.scala │ │ │ │ ├── SqlScriptingInterpreterSuite.scala │ │ │ │ └── SqlScriptingTestUtils.scala │ │ │ ├── sources │ │ │ │ ├── BucketedReadSuite.scala │ │ │ │ ├── BucketedWriteSuite.scala │ │ │ │ ├── CreateTableAsSelectSuite.scala │ │ │ │ ├── DDLSourceLoadSuite.scala │ │ │ │ ├── DataSourceAnalysisSuite.scala │ │ │ │ ├── DataSourceTest.scala │ │ │ │ ├── DisableUnnecessaryBucketedScanSuite.scala │ │ │ │ ├── ExternalCommandRunnerSuite.scala │ │ │ │ ├── FilteredScanSuite.scala │ │ │ │ ├── FiltersSuite.scala │ │ │ │ ├── InsertSuite.scala │ │ │ │ ├── PartitionedWriteSuite.scala │ │ │ │ ├── PathOptionSuite.scala │ │ │ │ ├── PrunedScanSuite.scala │ │ │ │ ├── ResolvedDataSourceSuite.scala │ │ │ │ ├── SaveLoadSuite.scala │ │ │ │ ├── TableScanSuite.scala │ │ │ │ └── fakeExternalSources.scala │ │ │ ├── streaming │ │ │ │ ├── AcceptsLatestSeenOffsetSuite.scala │ │ │ │ ├── CommitLogSuite.scala │ │ │ │ ├── DeprecatedStreamingAggregationSuite.scala │ │ │ │ ├── EventTimeWatermarkSuite.scala │ │ │ │ ├── FileStreamSinkSuite.scala │ │ │ │ ├── FileStreamSourceSuite.scala │ │ │ │ ├── FileStreamStressSuite.scala │ │ │ │ ├── FlatMapGroupsInPandasWithStateDistributionSuite.scala │ │ │ │ ├── FlatMapGroupsInPandasWithStateSuite.scala │ │ │ │ ├── FlatMapGroupsWithStateDistributionSuite.scala │ │ │ │ ├── FlatMapGroupsWithStateSuite.scala │ │ │ │ ├── FlatMapGroupsWithStateWithInitialStateSuite.scala │ │ │ │ ├── GroupStateSuite.scala │ │ │ │ ├── MemorySourceStressSuite.scala │ │ │ │ ├── MultiStatefulOperatorsSuite.scala │ │ │ │ ├── OffsetSuite.scala │ │ │ │ ├── ReportSinkMetricsSuite.scala │ │ │ │ ├── RocksDBStateStoreTest.scala │ │ │ │ ├── StateStoreMetricsTest.scala │ │ │ │ ├── StreamRealTimeModeAllowlistSuite.scala │ │ │ │ ├── StreamRealTimeModeSuite.scala │ │ │ │ ├── StreamRealTimeModeSuiteBase.scala │ │ │ │ ├── StreamSuite.scala │ │ │ │ ├── StreamTest.scala │ │ │ │ ├── StreamingAggregationDistributionSuite.scala │ │ │ │ ├── StreamingAggregationSuite.scala │ │ │ │ ├── StreamingDeduplicationDistributionSuite.scala │ │ │ │ ├── StreamingDeduplicationSuite.scala │ │ │ │ ├── StreamingDeduplicationWithinWatermarkSuite.scala │ │ │ │ ├── StreamingJoinSuite.scala │ │ │ │ ├── StreamingQueryHashPartitionVerifySuite.scala │ │ │ │ ├── StreamingQueryListenerSuite.scala │ │ │ │ ├── StreamingQueryListenersConfSuite.scala │ │ │ │ ├── StreamingQueryManagerSuite.scala │ │ │ │ ├── StreamingQueryOptimizationCorrectnessSuite.scala │ │ │ │ ├── StreamingQueryStatusAndProgressSuite.scala │ │ │ │ ├── StreamingQuerySuite.scala │ │ │ │ ├── StreamingSelfUnionSuite.scala │ │ │ │ ├── StreamingSessionWindowDistributionSuite.scala │ │ │ │ ├── StreamingSessionWindowSuite.scala │ │ │ │ ├── StreamingStateStoreFormatCompatibilitySuite.scala │ │ │ │ ├── StreamingSymmetricHashJoinHelperSuite.scala │ │ │ │ ├── TransformWithListStateSuite.scala │ │ │ │ ├── TransformWithListStateTTLSuite.scala │ │ │ │ ├── TransformWithMapStateSuite.scala │ │ │ │ ├── TransformWithMapStateTTLSuite.scala │ │ │ │ ├── TransformWithStateAvroSuite.scala │ │ │ │ ├── TransformWithStateChainingSuite.scala │ │ │ │ ├── TransformWithStateClusterSuite.scala │ │ │ │ ├── TransformWithStateInitialStateSuite.scala │ │ │ │ ├── TransformWithStateSuite.scala │ │ │ │ ├── TransformWithStateTTLTest.scala │ │ │ │ ├── TransformWithStateUnsafeRowSuite.scala │ │ │ │ ├── TransformWithValueStateTTLSuite.scala │ │ │ │ ├── TriggerAvailableNowSuite.scala │ │ │ │ ├── continuous │ │ │ │ │ ├── ContinuousQueryStatusAndProgressSuite.scala │ │ │ │ │ ├── ContinuousQueuedDataReaderSuite.scala │ │ │ │ │ ├── ContinuousSuite.scala │ │ │ │ │ └── EpochCoordinatorSuite.scala │ │ │ │ ├── sources │ │ │ │ │ └── StreamingDataSourceV2Suite.scala │ │ │ │ ├── test │ │ │ │ │ ├── DataStreamReaderWriterSuite.scala │ │ │ │ │ └── DataStreamTableAPISuite.scala │ │ │ │ ├── ui │ │ │ │ │ ├── StreamingQueryHistorySuite.scala │ │ │ │ │ ├── StreamingQueryPageSuite.scala │ │ │ │ │ ├── StreamingQueryStatusListenerSuite.scala │ │ │ │ │ ├── UISeleniumSuite.scala │ │ │ │ │ └── UIUtilsSuite.scala │ │ │ │ └── util │ │ │ │ │ ├── BlockOnStopSource.scala │ │ │ │ │ ├── BlockingSource.scala │ │ │ │ │ ├── GlobalSingletonManualClock.scala │ │ │ │ │ ├── MockSourceProvider.scala │ │ │ │ │ ├── StatefulOpClusteredDistributionTestHelper.scala │ │ │ │ │ └── StreamManualClock.scala │ │ │ ├── test │ │ │ │ ├── DataFrameReaderWriterSuite.scala │ │ │ │ ├── GenericFlatSpecSuite.scala │ │ │ │ ├── GenericFunSpecSuite.scala │ │ │ │ ├── GenericWordSpecSuite.scala │ │ │ │ ├── SQLTestData.scala │ │ │ │ ├── SQLTestUtils.scala │ │ │ │ ├── SharedSparkSession.scala │ │ │ │ ├── TestSQLContext.scala │ │ │ │ └── TestSparkSessionSuite.scala │ │ │ ├── types │ │ │ │ ├── GeographyTypeSuite.scala │ │ │ │ ├── GeometryTypeSuite.scala │ │ │ │ ├── JavaGeographyTypeSuite.java │ │ │ │ └── JavaGeometryTypeSuite.java │ │ │ ├── util │ │ │ │ ├── DataFrameCallbackSuite.scala │ │ │ │ ├── ExecutionListenerManagerSuite.scala │ │ │ │ └── MapperRowCounterSuite.scala │ │ │ └── vectorized │ │ │ │ └── ArrowColumnVectorSuite.scala │ │ │ └── status │ │ │ ├── api │ │ │ └── v1 │ │ │ │ └── sql │ │ │ │ ├── SqlResourceSuite.scala │ │ │ │ └── SqlResourceWithActualMetricsSuite.scala │ │ │ └── protobuf │ │ │ └── sql │ │ │ └── KVStoreProtobufSerializerSuite.scala │ │ ├── scripts │ │ ├── gen-avro.sh │ │ └── gen-thrift.sh │ │ └── thrift │ │ └── parquet-compat.thrift ├── create-docs.sh ├── gen-sql-api-docs.py ├── gen-sql-config-docs.py ├── gen-sql-functions-docs.py ├── hive-thriftserver │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── hive │ │ │ │ └── service │ │ │ │ ├── AbstractService.java │ │ │ │ ├── BreakableService.java │ │ │ │ ├── CompositeService.java │ │ │ │ ├── CookieSigner.java │ │ │ │ ├── FilterService.java │ │ │ │ ├── Service.java │ │ │ │ ├── ServiceException.java │ │ │ │ ├── ServiceOperations.java │ │ │ │ ├── ServiceStateChangeListener.java │ │ │ │ ├── ServiceUtils.java │ │ │ │ ├── auth │ │ │ │ ├── AnonymousAuthenticationProviderImpl.java │ │ │ │ ├── AuthenticationProviderFactory.java │ │ │ │ ├── CustomAuthenticationProviderImpl.java │ │ │ │ ├── HiveAuthFactory.java │ │ │ │ ├── HttpAuthUtils.java │ │ │ │ ├── HttpAuthenticationException.java │ │ │ │ ├── KerberosSaslHelper.java │ │ │ │ ├── LdapAuthenticationProviderImpl.java │ │ │ │ ├── PamAuthenticationProviderImpl.java │ │ │ │ ├── PasswdAuthenticationProvider.java │ │ │ │ ├── PlainSaslHelper.java │ │ │ │ ├── PlainSaslServer.java │ │ │ │ ├── SaslQOP.java │ │ │ │ ├── TSetIpAddressProcessor.java │ │ │ │ └── TSubjectAssumingTransport.java │ │ │ │ ├── cli │ │ │ │ ├── CLIService.java │ │ │ │ ├── CLIServiceClient.java │ │ │ │ ├── CLIServiceUtils.java │ │ │ │ ├── ColumnBasedSet.java │ │ │ │ ├── ColumnDescriptor.java │ │ │ │ ├── ColumnValue.java │ │ │ │ ├── FetchOrientation.java │ │ │ │ ├── FetchType.java │ │ │ │ ├── GetInfoType.java │ │ │ │ ├── GetInfoValue.java │ │ │ │ ├── Handle.java │ │ │ │ ├── HandleIdentifier.java │ │ │ │ ├── HiveSQLException.java │ │ │ │ ├── ICLIService.java │ │ │ │ ├── OperationHandle.java │ │ │ │ ├── OperationState.java │ │ │ │ ├── OperationStatus.java │ │ │ │ ├── OperationType.java │ │ │ │ ├── RowBasedSet.java │ │ │ │ ├── RowSet.java │ │ │ │ ├── RowSetFactory.java │ │ │ │ ├── SessionHandle.java │ │ │ │ ├── TableSchema.java │ │ │ │ ├── TypeDescriptor.java │ │ │ │ ├── TypeQualifiers.java │ │ │ │ ├── operation │ │ │ │ │ ├── ClassicTableTypeMapping.java │ │ │ │ │ ├── ExecuteStatementOperation.java │ │ │ │ │ ├── GetCatalogsOperation.java │ │ │ │ │ ├── GetColumnsOperation.java │ │ │ │ │ ├── GetCrossReferenceOperation.java │ │ │ │ │ ├── GetFunctionsOperation.java │ │ │ │ │ ├── GetPrimaryKeysOperation.java │ │ │ │ │ ├── GetSchemasOperation.java │ │ │ │ │ ├── GetTableTypesOperation.java │ │ │ │ │ ├── GetTablesOperation.java │ │ │ │ │ ├── GetTypeInfoOperation.java │ │ │ │ │ ├── HiveTableTypeMapping.java │ │ │ │ │ ├── LogDivertAppender.java │ │ │ │ │ ├── MetadataOperation.java │ │ │ │ │ ├── Operation.java │ │ │ │ │ ├── OperationManager.java │ │ │ │ │ ├── TableTypeMapping.java │ │ │ │ │ └── TableTypeMappingFactory.java │ │ │ │ ├── session │ │ │ │ │ ├── HiveSession.java │ │ │ │ │ ├── HiveSessionBase.java │ │ │ │ │ ├── HiveSessionHookContext.java │ │ │ │ │ ├── HiveSessionHookContextImpl.java │ │ │ │ │ ├── HiveSessionImpl.java │ │ │ │ │ ├── HiveSessionImplwithUGI.java │ │ │ │ │ ├── HiveSessionProxy.java │ │ │ │ │ └── SessionManager.java │ │ │ │ └── thrift │ │ │ │ │ ├── TServlet.java │ │ │ │ │ ├── ThriftBinaryCLIService.java │ │ │ │ │ ├── ThriftCLIService.java │ │ │ │ │ ├── ThriftCLIServiceClient.java │ │ │ │ │ ├── ThriftHttpCLIService.java │ │ │ │ │ └── ThriftHttpServlet.java │ │ │ │ └── server │ │ │ │ ├── HiveServer2.java │ │ │ │ ├── ThreadFactoryWithGarbageCleanup.java │ │ │ │ └── ThreadWithGarbageCleanup.java │ │ ├── resources │ │ │ └── META-INF │ │ │ │ └── services │ │ │ │ └── org.apache.spark.status.AppHistoryServerPlugin │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── hive │ │ │ └── thriftserver │ │ │ ├── FetchIterator.scala │ │ │ ├── HiveThriftServer2.scala │ │ │ ├── HiveThriftServerErrors.scala │ │ │ ├── ReflectionUtils.scala │ │ │ ├── RowSetUtils.scala │ │ │ ├── SparkExecuteStatementOperation.scala │ │ │ ├── SparkGetCatalogsOperation.scala │ │ │ ├── SparkGetColumnsOperation.scala │ │ │ ├── SparkGetFunctionsOperation.scala │ │ │ ├── SparkGetSchemasOperation.scala │ │ │ ├── SparkGetTableTypesOperation.scala │ │ │ ├── SparkGetTablesOperation.scala │ │ │ ├── SparkGetTypeInfoOperation.scala │ │ │ ├── SparkOperation.scala │ │ │ ├── SparkSQLCLIDriver.scala │ │ │ ├── SparkSQLCLIService.scala │ │ │ ├── SparkSQLDriver.scala │ │ │ ├── SparkSQLEnv.scala │ │ │ ├── SparkSQLSessionManager.scala │ │ │ ├── server │ │ │ └── SparkSQLOperationManager.scala │ │ │ └── ui │ │ │ ├── HiveThriftServer2AppStatusStore.scala │ │ │ ├── HiveThriftServer2EventManager.scala │ │ │ ├── HiveThriftServer2HistoryServerPlugin.scala │ │ │ ├── HiveThriftServer2Listener.scala │ │ │ ├── ThriftServerPage.scala │ │ │ ├── ThriftServerSessionPage.scala │ │ │ ├── ThriftServerTab.scala │ │ │ └── ToolTips.scala │ │ └── test │ │ ├── noclasspath │ │ └── hive-site.xml │ │ ├── resources │ │ ├── TestUDTF.jar │ │ ├── data │ │ │ └── files │ │ │ │ ├── small_kv.txt │ │ │ │ └── small_kv_with_null.txt │ │ └── log4j2.properties │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ └── hive │ │ ├── HiveMetastoreLazyInitializationSuite.scala │ │ └── thriftserver │ │ ├── CliSuite.scala │ │ ├── DummyListeners.scala │ │ ├── FetchIteratorSuite.scala │ │ ├── GetCatalogsOperationMock.scala │ │ ├── HiveCliSessionStateSuite.scala │ │ ├── HiveSessionImplSuite.scala │ │ ├── HiveThriftServer2Suites.scala │ │ ├── SharedThriftServer.scala │ │ ├── SparkExecuteStatementOperationSuite.scala │ │ ├── SparkMetadataOperationSuite.scala │ │ ├── SparkSQLEnvSuite.scala │ │ ├── SparkThriftServerProtocolVersionsSuite.scala │ │ ├── ThriftServerQueryTestSuite.scala │ │ ├── ThriftServerWithSparkContextSuite.scala │ │ ├── UISeleniumSuite.scala │ │ └── ui │ │ ├── HiveThriftServer2ListenerSuite.scala │ │ └── ThriftServerPageSuite.scala ├── hive │ ├── benchmarks │ │ ├── InsertIntoHiveTableBenchmark-hive2.3-results.txt │ │ ├── InsertIntoHiveTableBenchmark-jdk21-hive2.3-results.txt │ │ ├── ObjectHashAggregateExecBenchmark-jdk21-results.txt │ │ ├── ObjectHashAggregateExecBenchmark-results.txt │ │ ├── OrcReadBenchmark-jdk21-results.txt │ │ └── OrcReadBenchmark-results.txt │ ├── compatibility │ │ └── src │ │ │ └── test │ │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── hive │ │ │ └── execution │ │ │ ├── HiveCompatibilitySuite.scala │ │ │ └── HiveWindowFunctionQuerySuite.scala │ ├── pom.xml │ └── src │ │ ├── main │ │ ├── java │ │ │ └── org │ │ │ │ └── apache │ │ │ │ └── hadoop │ │ │ │ └── hive │ │ │ │ └── ql │ │ │ │ ├── exec │ │ │ │ ├── HiveFunctionRegistryUtils.java │ │ │ │ ├── SparkDefaultUDAFEvaluatorResolver.java │ │ │ │ └── SparkDefaultUDFMethodResolver.java │ │ │ │ ├── io │ │ │ │ ├── DelegateSymlinkTextInputFormat.java │ │ │ │ └── orc │ │ │ │ │ └── SparkOrcNewRecordReader.java │ │ │ │ └── udf │ │ │ │ └── generic │ │ │ │ └── SparkGenericUDAFBridge.java │ │ ├── resources │ │ │ └── META-INF │ │ │ │ └── services │ │ │ │ ├── org.apache.spark.security.HadoopDelegationTokenProvider │ │ │ │ └── org.apache.spark.sql.sources.DataSourceRegister │ │ └── scala │ │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── hive │ │ │ ├── HiveContext.scala │ │ │ ├── HiveExternalCatalog.scala │ │ │ ├── HiveInspectors.scala │ │ │ ├── HiveMetastoreCatalog.scala │ │ │ ├── HiveSessionCatalog.scala │ │ │ ├── HiveSessionStateBuilder.scala │ │ │ ├── HiveShim.scala │ │ │ ├── HiveStrategies.scala │ │ │ ├── HiveTableRelationResolver.scala │ │ │ ├── HiveUtils.scala │ │ │ ├── TableReader.scala │ │ │ ├── client │ │ │ ├── HiveClient.scala │ │ │ ├── HiveClientImpl.scala │ │ │ ├── HiveShim.scala │ │ │ ├── IsolatedClientLoader.scala │ │ │ └── package.scala │ │ │ ├── execution │ │ │ ├── CreateHiveTableAsSelectCommand.scala │ │ │ ├── HiveFileFormat.scala │ │ │ ├── HiveOptions.scala │ │ │ ├── HiveScriptTransformationExec.scala │ │ │ ├── HiveTableScanExec.scala │ │ │ ├── HiveTempPath.scala │ │ │ ├── InsertIntoHiveDirCommand.scala │ │ │ ├── InsertIntoHiveTable.scala │ │ │ ├── PruneHiveTablePartitions.scala │ │ │ ├── SaveAsHiveFile.scala │ │ │ └── V1WritesHiveUtils.scala │ │ │ ├── hiveUDFEvaluators.scala │ │ │ ├── hiveUDFs.scala │ │ │ ├── orc │ │ │ ├── OrcFileFormat.scala │ │ │ └── OrcFileOperator.scala │ │ │ ├── package-info.java │ │ │ ├── package.scala │ │ │ └── security │ │ │ └── HiveDelegationTokenProvider.scala │ │ └── test │ │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ └── sql │ │ │ └── hive │ │ │ ├── JavaDataFrameSuite.java │ │ │ ├── JavaMetastoreDataSourcesSuite.java │ │ │ ├── execution │ │ │ ├── UDAFEmpty.java │ │ │ ├── UDFCatchException.java │ │ │ ├── UDFIntegerToString.java │ │ │ ├── UDFListListInt.java │ │ │ ├── UDFListString.java │ │ │ ├── UDFRawList.java │ │ │ ├── UDFRawMap.java │ │ │ ├── UDFStringString.java │ │ │ ├── UDFThrowException.java │ │ │ ├── UDFToIntIntMap.java │ │ │ ├── UDFToListInt.java │ │ │ ├── UDFToListMapStringListInt.java │ │ │ ├── UDFToListString.java │ │ │ ├── UDFToStringIntMap.java │ │ │ ├── UDFTwoListList.java │ │ │ └── UDFWildcardList.java │ │ │ └── test │ │ │ └── Complex.java │ │ ├── noclasspath │ │ ├── README │ │ └── hive-test-udfs.jar │ │ ├── resources │ │ ├── SPARK-21101-1.0.jar │ │ ├── TestUDTF.jar │ │ ├── avroDecimal │ │ │ └── decimal.avro │ │ ├── data │ │ │ ├── conf │ │ │ │ └── hive-site.xml │ │ │ ├── files │ │ │ │ ├── ProxyAuth.res │ │ │ │ ├── SortCol1Col2.txt │ │ │ │ ├── SortCol2Col1.txt │ │ │ │ ├── SortDescCol1Col2.txt │ │ │ │ ├── SortDescCol2Col1.txt │ │ │ │ ├── T1.txt │ │ │ │ ├── T2.txt │ │ │ │ ├── T3.txt │ │ │ │ ├── TestSerDe.jar │ │ │ │ ├── UserVisits.dat │ │ │ │ ├── alltypes.txt │ │ │ │ ├── alltypes2.txt │ │ │ │ ├── alltypesorc │ │ │ │ ├── apache.access.2.log │ │ │ │ ├── apache.access.log │ │ │ │ ├── archive_corrupt.rc │ │ │ │ ├── array_table.txt │ │ │ │ ├── binary.txt │ │ │ │ ├── bool.txt │ │ │ │ ├── char_varchar_udf.txt │ │ │ │ ├── complex.seq │ │ │ │ ├── covar_tab.txt │ │ │ │ ├── create_nested_type.txt │ │ │ │ ├── csv.txt │ │ │ │ ├── datatypes.txt │ │ │ │ ├── decimal.txt │ │ │ │ ├── decimal_1_1.txt │ │ │ │ ├── dept.txt │ │ │ │ ├── dim-data.txt │ │ │ │ ├── doctors.avro │ │ │ │ ├── docurl.txt │ │ │ │ ├── double.txt │ │ │ │ ├── emp.txt │ │ │ │ ├── employee.dat │ │ │ │ ├── employee2.dat │ │ │ │ ├── employee_part.txt │ │ │ │ ├── empty1.txt │ │ │ │ ├── empty2.txt │ │ │ │ ├── episodes.avro │ │ │ │ ├── escapetest.txt │ │ │ │ ├── exported_table │ │ │ │ │ ├── _metadata │ │ │ │ │ └── data │ │ │ │ │ │ └── data │ │ │ │ ├── ext_test │ │ │ │ │ └── test.dat │ │ │ │ ├── ext_test_space │ │ │ │ │ └── folder+with space │ │ │ │ │ │ └── data.txt │ │ │ │ ├── fact-data.txt │ │ │ │ ├── flights_join.txt │ │ │ │ ├── flights_tiny.txt │ │ │ │ ├── flights_tiny.txt.1 │ │ │ │ ├── futurama_episodes.avro │ │ │ │ ├── groupby_groupingid.txt │ │ │ │ ├── grouping_sets.txt │ │ │ │ ├── grouping_sets1.txt │ │ │ │ ├── grouping_sets2.txt │ │ │ │ ├── header_footer_table_1 │ │ │ │ │ ├── 0001.txt │ │ │ │ │ ├── 0002.txt │ │ │ │ │ └── 0003.txt │ │ │ │ ├── header_footer_table_2 │ │ │ │ │ └── 2012 │ │ │ │ │ │ └── 01 │ │ │ │ │ │ ├── 01 │ │ │ │ │ │ └── 0001.txt │ │ │ │ │ │ ├── 02 │ │ │ │ │ │ └── 0002.txt │ │ │ │ │ │ └── 03 │ │ │ │ │ │ └── 0003.txt │ │ │ │ ├── header_footer_table_3 │ │ │ │ │ ├── empty1.txt │ │ │ │ │ └── empty2.txt │ │ │ │ ├── hive_626_bar.txt │ │ │ │ ├── hive_626_count.txt │ │ │ │ ├── hive_626_foo.txt │ │ │ │ ├── in1.txt │ │ │ │ ├── in2.txt │ │ │ │ ├── in3.txt │ │ │ │ ├── in4.txt │ │ │ │ ├── in5.txt │ │ │ │ ├── in6.txt │ │ │ │ ├── in7.txt │ │ │ │ ├── in8.txt │ │ │ │ ├── in9.txt │ │ │ │ ├── infer_const_type.txt │ │ │ │ ├── input.txt │ │ │ │ ├── int.txt │ │ │ │ ├── issue-4077-data.txt │ │ │ │ ├── json.txt │ │ │ │ ├── keystore.jks │ │ │ │ ├── kv1.seq │ │ │ │ ├── kv1.string-sorted.txt │ │ │ │ ├── kv1.txt │ │ │ │ ├── kv1.val.sorted.txt │ │ │ │ ├── kv1_broken.seq │ │ │ │ ├── kv1_cb.txt │ │ │ │ ├── kv1_cc.txt │ │ │ │ ├── kv1kv2.cogroup.txt │ │ │ │ ├── kv2.txt │ │ │ │ ├── kv3.txt │ │ │ │ ├── kv4.txt │ │ │ │ ├── kv5.txt │ │ │ │ ├── kv6.txt │ │ │ │ ├── kv7.txt │ │ │ │ ├── kv8.txt │ │ │ │ ├── kv9.txt │ │ │ │ ├── leftsemijoin_mr_t1.txt │ │ │ │ ├── leftsemijoin_mr_t2.txt │ │ │ │ ├── lineitem.txt │ │ │ │ ├── loc.txt │ │ │ │ ├── lt100.sorted.txt │ │ │ │ ├── lt100.txt │ │ │ │ ├── lt100.txt.deflate │ │ │ │ ├── map_table.txt │ │ │ │ ├── nested_complex.txt │ │ │ │ ├── non_ascii_tbl.txt │ │ │ │ ├── null.txt │ │ │ │ ├── nullfile.txt │ │ │ │ ├── nulls.txt │ │ │ │ ├── orc_create.txt │ │ │ │ ├── orc_create_people.txt │ │ │ │ ├── orc_split_elim.orc │ │ │ │ ├── over10k │ │ │ │ ├── over1k │ │ │ │ ├── parquet_create.txt │ │ │ │ ├── parquet_partitioned.txt │ │ │ │ ├── parquet_types.txt │ │ │ │ ├── part.rc │ │ │ │ ├── part.seq │ │ │ │ ├── part_tiny.txt │ │ │ │ ├── person age.txt │ │ │ │ ├── person+age.txt │ │ │ │ ├── posexplode_data.txt │ │ │ │ ├── primitive_type_arrays.txt │ │ │ │ ├── pw17.txt │ │ │ │ ├── sales.txt │ │ │ │ ├── sample-queryplan-in-history.txt │ │ │ │ ├── sample-queryplan.txt │ │ │ │ ├── sample.json │ │ │ │ ├── smallsrcsortbucket1outof4.txt │ │ │ │ ├── smallsrcsortbucket2outof4.txt │ │ │ │ ├── smallsrcsortbucket3outof4.txt │ │ │ │ ├── smallsrcsortbucket4outof4.txt │ │ │ │ ├── smb_bucket_input.rc │ │ │ │ ├── smb_bucket_input.txt │ │ │ │ ├── smbbucket_1.rc │ │ │ │ ├── smbbucket_1.txt │ │ │ │ ├── smbbucket_2.rc │ │ │ │ ├── smbbucket_2.txt │ │ │ │ ├── smbbucket_3.rc │ │ │ │ ├── smbbucket_3.txt │ │ │ │ ├── source.txt │ │ │ │ ├── srcbucket0.txt │ │ │ │ ├── srcbucket1.txt │ │ │ │ ├── srcbucket20.txt │ │ │ │ ├── srcbucket21.txt │ │ │ │ ├── srcbucket22.txt │ │ │ │ ├── srcbucket23.txt │ │ │ │ ├── srcsortbucket1outof4.txt │ │ │ │ ├── srcsortbucket2outof4.txt │ │ │ │ ├── srcsortbucket3outof4.txt │ │ │ │ ├── srcsortbucket4outof4.txt │ │ │ │ ├── string.txt │ │ │ │ ├── symlink1.txt │ │ │ │ ├── symlink2.txt │ │ │ │ ├── tbl.txt │ │ │ │ ├── test.dat │ │ │ │ ├── test2.dat │ │ │ │ ├── testUDF │ │ │ │ │ └── part-00000 │ │ │ │ ├── text-en.txt │ │ │ │ ├── things.txt │ │ │ │ ├── things2.txt │ │ │ │ ├── tiny_a.txt │ │ │ │ ├── tiny_b.txt │ │ │ │ ├── truststore.jks │ │ │ │ ├── types │ │ │ │ │ └── primitives │ │ │ │ │ │ ├── 090101.txt │ │ │ │ │ │ ├── 090201.txt │ │ │ │ │ │ ├── 090301.txt │ │ │ │ │ │ └── 090401.txt │ │ │ │ ├── union_input.txt │ │ │ │ ├── v1.txt │ │ │ │ ├── v2.txt │ │ │ │ ├── vc1.txt │ │ │ │ ├── x.txt │ │ │ │ ├── y.txt │ │ │ │ └── z.txt │ │ │ ├── metadb │ │ │ │ └── .gitignore │ │ │ └── scripts │ │ │ │ ├── cat.py │ │ │ │ ├── cat_error.py │ │ │ │ ├── doubleescapedtab.py │ │ │ │ ├── dumpdata_script.py │ │ │ │ ├── error_script │ │ │ │ ├── escapedcarriagereturn.py │ │ │ │ ├── escapednewline.py │ │ │ │ ├── escapedtab.py │ │ │ │ ├── input20_script │ │ │ │ ├── input20_script.py │ │ │ │ ├── newline.py │ │ │ │ ├── q_test_cleanup.sql │ │ │ │ ├── q_test_init.sql │ │ │ │ ├── test_init_file.sql │ │ │ │ └── test_transform.py │ │ ├── golden │ │ │ ├── ! operator-0-81d1a187c7f4a6337baf081510a5dc5e │ │ │ ├── ! operator-0-ee7f6a60a9792041b85b18cda56429bf │ │ │ ├── '1' + '1'-0-77504a9f3d712143beb52f3c25a904cb │ │ │ ├── '1' + 1-0-130514c6116c311d808590a075b187b │ │ │ ├── '1' + 1.0-0-404b0ea20c125c9648b7919a8f41add3 │ │ │ ├── '1' + 1L-0-657763a2cfaa4fe3f73c5b68bc84a548 │ │ │ ├── '1' + 1S-0-c3a1c44bebcde38c4d43bd73e3849630 │ │ │ ├── '1' + 1Y-0-aa608227a4f07c5cb98fcafe1e20488a │ │ │ ├── 1 + '1'-0-4d39227e4121e2dc9a25f21fa27f89a │ │ │ ├── 1 + 1-0-83de1c24fd6dee00409e8fdd99306ed6 │ │ │ ├── 1 + 1.0-0-77ca48f121bd2ef41efb9ee3bc28418 │ │ │ ├── 1 + 1L-0-917a033ac7f8f8b3a2e8e961dc91f35e │ │ │ ├── 1 + 1S-0-2e99da48f67f588c9e632a57c713522e │ │ │ ├── 1 + 1Y-0-1ff4db1fdac05de5b092095c2402fc5f │ │ │ ├── 1.0 + '1'-0-6beb1ef5178117a9fd641008ed5ebb80 │ │ │ ├── 1.0 + 1-0-bec2842d2b009973b4d4b8f10b5554f8 │ │ │ ├── 1.0 + 1.0-0-eafdfdbb14980ee517c388dc117d91a8 │ │ │ ├── 1.0 + 1L-0-ef273f05968cd0e91af8c76949c73798 │ │ │ ├── 1.0 + 1S-0-9f93538c38920d52b322bfc40cc2f31a │ │ │ ├── 1.0 + 1Y-0-9e354e022b1b423f366bf79ed7522f2a │ │ │ ├── 1L + '1'-0-6e39c7be301f3846efa9b4c939815b4a │ │ │ ├── 1L + 1-0-1864a260554255a09e4f28b8551eef9d │ │ │ ├── 1L + 1.0-0-9b0510d0bb3e9ee6a7698369b008a280 │ │ │ ├── 1L + 1L-0-e54a673c779f31597acdc5bd7d315d9f │ │ │ ├── 1L + 1S-0-b8e70f71c32aac77e2683ba20ab99688 │ │ │ ├── 1L + 1Y-0-55de31e21660fa7d213b1f68d636cbf9 │ │ │ ├── 1S + '1'-0-c3cf30b2c4bffc76100e7b43e7b2aec5 │ │ │ ├── 1S + 1-0-c378b0b2a57c54b3815e8a64686756d3 │ │ │ ├── 1S + 1.0-0-c3d54e5b6034b7796ed16896a434d1ba │ │ │ ├── 1S + 1L-0-9d3ff8b5d4883a4a5a1dc0dd4f0c1116 │ │ │ ├── 1S + 1S-0-5054df6e72be611d6ee2a4e135bd949e │ │ │ ├── 1S + 1Y-0-e59bc8279cd364224476ffc504c7685b │ │ │ ├── 1Y + '1'-0-bdc0f1c52b94a852b595e54997eb9dfb │ │ │ ├── 1Y + 1-0-a4541db51882b19503649138fbb295f │ │ │ ├── 1Y + 1.0-0-7b54e1d367c2ed1f5c181298ee5470d0 │ │ │ ├── 1Y + 1L-0-2aa9a7b23c741d78032def0641a21cb1 │ │ │ ├── 1Y + 1S-0-93a44c4952c4d343d3885edfc95b4b80 │ │ │ ├── 1Y + 1Y-0-3d9619d963e7f1cb4ab3e8b5e24ff0d5 │ │ │ ├── CTE feature #1-0-eedabbfe6ba8799f7b7782fb47a82768 │ │ │ ├── CTE feature #2-0-aa03d104251f97e36bc52279cb9931c9 │ │ │ ├── CTE feature #3-0-b5d4bf3c0ee92b2fda0ca24f422383f2 │ │ │ ├── Cast Timestamp to Timestamp in UDF-0-db6d4503454e4dbb9edcbab9a8718d7f │ │ │ ├── Column pruning - filter alias in-lining - query test-0-cb0737d268260da971487a8ac5e3d8be │ │ │ ├── Column pruning - non-trivial top project with aliases - query test-0-515e406ffb23f6fd0d8cd34c2b25fbe6 │ │ │ ├── Column pruning - non-trivial top project with aliases - query test-0-c89dcddb8539bae211ea28cd1e695e35 │ │ │ ├── Column pruning - projects alias substituting - query test-0-9589ac54d6de575083765ee64051ebaa │ │ │ ├── Column pruning - simple top project without aliases - query test-0-d6d2726928df920ab99078015b8ff494 │ │ │ ├── Column pruning - with multiple projects - query test-0-cfe78c68302bd143d989c383c3b0477 │ │ │ ├── Column pruning - with non-partitioned table - query test-0-358525951e893ed9686c46bf1f7447ee │ │ │ ├── Column pruning - with partitioned table - query test-0-d9d50146537344742300ce7b52c18c91 │ │ │ ├── Column pruning - without filters - query test-0-c25cdafe7d85c42a9d9cd559d88a6049 │ │ │ ├── Constant Folding Optimization for AVG_SUM_COUNT-0-c60b6075da793b826db5eb4b08d7bab9 │ │ │ ├── DISTINCT-0-3af674dcb5dd91ad17722d2022a8d59a │ │ │ ├── Date comparison test 1-0-bde89be08a12361073ff658fef768b7e │ │ │ ├── Escape sequences-0-2f25c33d97c43f3276171624d988a286 │ │ │ ├── IgnoreExplain-0-85d398864d4aa1d0e10ffd668fdf1a59 │ │ │ ├── LIKE-0-8a6078c9da5f15ea95ba3682fd66e672 │ │ │ ├── NaN to Decimal-0-6ca781bc343025635d72321ef0a9d425 │ │ │ ├── Partition pruning - all partitions pruned - query test-0-63ab78355dbc6fa0d7619c8a35b0f7a7 │ │ │ ├── Partition pruning - left only 1 partition - query test-0-3adc3a7f76b2abd059904ba81a595db3 │ │ │ ├── Partition pruning - non-partitioned table - query test-0-681332efaff7b12e3ca12d9f021cd344 │ │ │ ├── Partition pruning - non-partitioned, non-trivial project - query test-0-3893ec7a86062215d9f817f1495a69bb │ │ │ ├── Partition pruning - non-partitioned, non-trivial project - query test-0-eabbebd5c1d127b1605bfec52d7b7f3f │ │ │ ├── Partition pruning - pruning with both column key and partition key - query test-0-75148567b91227053f728d72f7dc7c10 │ │ │ ├── Partition pruning - with filter containing non-deterministic condition - query test-0-56a1c59bd13c2a83a91eb0ec658fcecc │ │ │ ├── Partition pruning - with filter on int partition key - query test-0-4e4d2651e1e6e3c224242078d0201190 │ │ │ ├── Partition pruning - with filter on string partition key - query test-0-b6e59464383591f02408f8765ac6a5d5 │ │ │ ├── Read Partitioned with AvroSerDe-0-e4501461c855cc9071a872a64186c3de │ │ │ ├── Read and write with LazySimpleSerDe (tab separated)-0-779101eb00fd8bb9f08908ab29e90c03 │ │ │ ├── Read with AvroSerDe-0-805f15ffbb03db90ec5757b328666d04 │ │ │ ├── Read with RegexSerDe-0-9b96fab8d55a0e19fae00d8adb57ffaa │ │ │ ├── SPARK-10484 Optimize the Cartesian (Cross) Join with broadcast based JOIN #1-0-abfc0b99ee357f71639f6162345fe8e │ │ │ ├── SPARK-10484 Optimize the Cartesian (Cross) Join with broadcast based JOIN #2-0-8412a39ee57885ccb0aaf848db8ef1dd │ │ │ ├── SPARK-10484 Optimize the Cartesian (Cross) Join with broadcast based JOIN #3-0-e8a0427dbde35eea6011144443e5ffb4 │ │ │ ├── SPARK-10484 Optimize the Cartesian (Cross) Join with broadcast based JOIN #4-0-45f8602d257655322b7d18cad09f6a0f │ │ │ ├── SPARK-9034 Reflect field names defined in GenericUDTF #1-0-ff502d8c06f4b32f57aa45057b7fab0e │ │ │ ├── SPARK-9034 Reflect field names defined in GenericUDTF #2-0-d6d0def30a7fad5f90fd835361820c30 │ │ │ ├── Simple Average + 1 with group-0-f52ca483a3e5eadc1b20ba8320d029a7 │ │ │ ├── Simple Average + 1-0-5e296b921c470f0f0b5d099f28bd5935 │ │ │ ├── Simple Average-0-c197ea78c4d8f85f1a317805b6da07e5 │ │ │ ├── Specify the udtf output-0-d1f244bce64f22b34ad5bf9fd360b632 │ │ │ ├── Test UDTF.close in Lateral Views-0-ac5c96224a534f07b49462ad76620678 │ │ │ ├── Test UDTF.close in SELECT-0-517f834fef35b896ec64399f42b2a151 │ │ │ ├── add_part_exist-0-e58d09864bc6898e44fae80abe328702 │ │ │ ├── add_part_exist-1-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-10-ecb27eb754e731429659224b5b6ac583 │ │ │ ├── add_part_exist-11-9c36cac1372650b703400c60dd29042c │ │ │ ├── add_part_exist-12-2900a5065dd3adbb0b56a712bf848750 │ │ │ ├── add_part_exist-13-d69279050a0f44c3f8b775698fd29be0 │ │ │ ├── add_part_exist-14-9c36cac1372650b703400c60dd29042c │ │ │ ├── add_part_exist-15-e58d09864bc6898e44fae80abe328702 │ │ │ ├── add_part_exist-16-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-17-3432935e802ae46c6b2151cc4ebf783b │ │ │ ├── add_part_exist-18-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-19-83cecdbfddb070a417050f9a18fff752 │ │ │ ├── add_part_exist-2-3432935e802ae46c6b2151cc4ebf783b │ │ │ ├── add_part_exist-20-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-21-2df4b20f67e7f15d3f4150bcfea43b0f │ │ │ ├── add_part_exist-22-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-23-a3859b63665ce3bbfd19683e6e694dcb │ │ │ ├── add_part_exist-24-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-3-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-4-83cecdbfddb070a417050f9a18fff752 │ │ │ ├── add_part_exist-5-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-6-2df4b20f67e7f15d3f4150bcfea43b0f │ │ │ ├── add_part_exist-7-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_exist-8-a3859b63665ce3bbfd19683e6e694dcb │ │ │ ├── add_part_exist-9-d824f22606f48dfca48ce241a7505f5b │ │ │ ├── add_part_multiple-0-9c55143a4c92f0cfe7669f7681d7aa98 │ │ │ ├── add_part_multiple-1-4d9d4efbabc9fffef8841cc049f479c1 │ │ │ ├── add_part_multiple-2-187930e0daa44eed17e092e961ab7955 │ │ │ ├── add_part_multiple-3-59fb141ee5c3e8f9463fe0478dbfd7ef │ │ │ ├── add_part_multiple-4-7950c676506564b085b41426ed41747c │ │ │ ├── add_partition_no_whitelist-0-3806584ff765bca682594008b90fc304 │ │ │ ├── add_partition_no_whitelist-1-22eb96fe7d338e488182b5755c90d5af │ │ │ ├── add_partition_no_whitelist-2-923fa18234ae73103c43722f70e000c0 │ │ │ ├── add_partition_no_whitelist-3-b7c0bb09609fabad407feb6fdf2c748f │ │ │ ├── add_partition_with_whitelist-0-3c23ae800b2f6fb93620890da2dba196 │ │ │ ├── add_partition_with_whitelist-1-67a0dbca9fecb7d34cceeecf2184c484 │ │ │ ├── add_partition_with_whitelist-2-e6a91be97431de63e372088d370c6d36 │ │ │ ├── add_partition_with_whitelist-3-b9a6b4e8acbfea5e1938eda085c4b893 │ │ │ ├── alias.attr-0-42104e7e35985f4504c6d9a79b1bb4b8 │ │ │ ├── alias.star-0-7bdb861d11e895aaea545810cdac316d │ │ │ ├── alias_casted_column-0-f69b60c6e896fcd1a69d9525fd988c66 │ │ │ ├── alias_casted_column-1-4432aec015f9423ed991b08cfb2af0e1 │ │ │ ├── alter2-0-85e494848d1525843a3ff9b2b77f92 │ │ │ ├── alter2-1-aac9c2c7033fd7264c9a107a88ff591 │ │ │ ├── alter2-10-2d1f665a92fe72bd253ae57c46d7b9da │ │ │ ├── alter2-11-aac9c2c7033fd7264c9a107a88ff591 │ │ │ ├── alter2-12-75a213649242c2410ea6846f08c91d75 │ │ │ ├── alter2-13-ca51e03a3de391983429b6ad877e573c │ │ │ ├── alter2-14-aac9c2c7033fd7264c9a107a88ff591 │ │ │ ├── alter2-15-75a213649242c2410ea6846f08c91d75 │ │ │ ├── alter2-16-77500c83ffcece95511a4b21d67382dd │ │ │ ├── alter2-17-aac9c2c7033fd7264c9a107a88ff591 │ │ │ ├── alter2-18-75a213649242c2410ea6846f08c91d75 │ │ │ ├── alter2-19-3d80bb2d1c541460b5b17c4124fa647 │ │ │ ├── alter2-2-75a213649242c2410ea6846f08c91d75 │ │ │ ├── alter2-20-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter2-21-a6ea9efed3b9c680fca93588019ac5e3 │ │ │ ├── alter2-22-ea07b8f664208f93a1a8b97fd486d226 │ │ │ ├── alter2-23-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter2-24-775d69742a1c07df8da87e8a017d955 │ │ │ ├── alter2-25-4ef75e12575453225738ea167c4617e5 │ │ │ ├── alter2-26-63f13c364546ddce5d2176c6604a948f │ │ │ ├── alter2-27-ba521286c12ba29329bfa71bb185c62f │ │ │ ├── alter2-28-4ef75e12575453225738ea167c4617e5 │ │ │ ├── alter2-29-63f13c364546ddce5d2176c6604a948f │ │ │ ├── alter2-3-ca51e03a3de391983429b6ad877e573c │ │ │ ├── alter2-30-a336adf1d0ff00633c53600fc75ca3ae │ │ │ ├── alter2-31-4ef75e12575453225738ea167c4617e5 │ │ │ ├── alter2-32-63f13c364546ddce5d2176c6604a948f │ │ │ ├── alter2-33-1934026d0228967097280eed35551f74 │ │ │ ├── alter2-34-23b00f9c0101348e87da8a339b9da8b │ │ │ ├── alter2-35-4ef75e12575453225738ea167c4617e5 │ │ │ ├── alter2-36-63f13c364546ddce5d2176c6604a948f │ │ │ ├── alter2-37-ba521286c12ba29329bfa71bb185c62f │ │ │ ├── alter2-38-4ef75e12575453225738ea167c4617e5 │ │ │ ├── alter2-39-63f13c364546ddce5d2176c6604a948f │ │ │ ├── alter2-4-aac9c2c7033fd7264c9a107a88ff591 │ │ │ ├── alter2-40-a336adf1d0ff00633c53600fc75ca3ae │ │ │ ├── alter2-41-4ef75e12575453225738ea167c4617e5 │ │ │ ├── alter2-42-63f13c364546ddce5d2176c6604a948f │ │ │ ├── alter2-43-1934026d0228967097280eed35551f74 │ │ │ ├── alter2-44-7a9e67189d3d4151f23b12c22bde06b5 │ │ │ ├── alter2-45-adbc01277c01cc5647e89c8a2430b8c │ │ │ ├── alter2-5-75a213649242c2410ea6846f08c91d75 │ │ │ ├── alter2-6-77500c83ffcece95511a4b21d67382dd │ │ │ ├── alter2-7-aac9c2c7033fd7264c9a107a88ff591 │ │ │ ├── alter2-8-75a213649242c2410ea6846f08c91d75 │ │ │ ├── alter2-9-1986a53bb1944fe5f43e3e65693e7b1e │ │ │ ├── alter3-0-1c1a75eeb97d4d8b9120d762aa0d2ade │ │ │ ├── alter3-1-47f70392b97b94cdb425b25bde204f58 │ │ │ ├── alter3-10-bd9604a8b7eaecd785bc1e5163ec53a1 │ │ │ ├── alter3-11-10e58aa21d9af1817c71d83ec8e3a4d8 │ │ │ ├── alter3-12-2fcb7fc251f682a584ad513fddfac506 │ │ │ ├── alter3-13-4d7fd1a73dc8dde03c5627fb5e1dc17b │ │ │ ├── alter3-14-3fa4d8a690a45cbf7b44cecfd352864f │ │ │ ├── alter3-15-5c6b489b14a4d8bc4ce9a26d8465d6f2 │ │ │ ├── alter3-16-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter3-17-a9908f67f97588cbf15c0e7caddcbb0b │ │ │ ├── alter3-18-581b65f9f467d0d4a33a16dda144a31d │ │ │ ├── alter3-19-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter3-2-5a67d369d700eb96f806f8320c04d61f │ │ │ ├── alter3-20-8114bed96bb7bff5b4fa18069c8d6d00 │ │ │ ├── alter3-21-91e32b3028ecc352dad8884829148311 │ │ │ ├── alter3-22-362c1a2c9cb223f05b33c3cc193a4d24 │ │ │ ├── alter3-23-7ad62b397f6c9341da6bf0e9361314e2 │ │ │ ├── alter3-24-9c23b682abda3841f01b4d9b750c68d9 │ │ │ ├── alter3-25-568a59760e5d3241b63d65cce595face │ │ │ ├── alter3-26-3c725018f74a69f4d859c66af2f5b11e │ │ │ ├── alter3-27-54ad133b447f67c6d1ed7d4c43803a87 │ │ │ ├── alter3-28-5332228ea451105c897d0c8c3c8f2773 │ │ │ ├── alter3-29-b8fba19b9009131caffbb5fe7468b67c │ │ │ ├── alter3-3-f031aa27bf7b494cb8de20a305be7064 │ │ │ ├── alter3-30-cd5c7d666fdea990be3cf66e43c7b8f4 │ │ │ ├── alter3-31-5a41cf8c1a828ac2c372536ee4afd962 │ │ │ ├── alter3-32-327744965ee8ed630f56fa3e4a3c5c65 │ │ │ ├── alter3-4-399fc26b344c98ababa104522601c0cc │ │ │ ├── alter3-5-bf2a8fd1884bb584059c848332e30c97 │ │ │ ├── alter3-6-fe6db2a539df10e4bc4715e2ed755135 │ │ │ ├── alter3-7-30be5698ca15c1fd836686e7ad48ad8 │ │ │ ├── alter3-8-8f0a466bd1d021e40690865b7ae52a43 │ │ │ ├── alter3-9-b8a2a12aeddb84f56c7a1f6346bae3d2 │ │ │ ├── alter4-0-c261e1fa9f838dd034d37af38305e9c6 │ │ │ ├── alter4-1-7ead71f9870ae36dd1cb50b51b41fad7 │ │ │ ├── alter4-10-7ead71f9870ae36dd1cb50b51b41fad7 │ │ │ ├── alter4-11-7db7af854e4e10fb6f0338b85d65549d │ │ │ ├── alter4-12-7ead71f9870ae36dd1cb50b51b41fad7 │ │ │ ├── alter4-13-e9879d6bebc109340bbeecc3ca77492f │ │ │ ├── alter4-14-7a9e67189d3d4151f23b12c22bde06b5 │ │ │ ├── alter4-15-63a545ee0e751a2729c8758a14712da5 │ │ │ ├── alter4-16-549981e00a3d95f03dd5a9ef6044aa20 │ │ │ ├── alter4-2-7db7af854e4e10fb6f0338b85d65549d │ │ │ ├── alter4-3-7ead71f9870ae36dd1cb50b51b41fad7 │ │ │ ├── alter4-4-cc9c0034efdeb0bf94ad774aeb703c39 │ │ │ ├── alter4-5-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter4-6-acd58e84952d310aeddf78579c36286 │ │ │ ├── alter4-7-8e6ec3396f25c124de5b212d8ce6c568 │ │ │ ├── alter4-8-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter4-9-c261e1fa9f838dd034d37af38305e9c6 │ │ │ ├── alter5-0-953553e14d835682fa47338dcfffe227 │ │ │ ├── alter5-1-cbad54fbd4a08fc8717708f93358ec3e │ │ │ ├── alter5-10-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter5-11-e63fa029ab22ac4f5c880f2848f1b956 │ │ │ ├── alter5-12-6b160869b8a9c846bc55a14f85bc5b52 │ │ │ ├── alter5-13-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter5-14-92fbb4bc42ef462dcb4a06442b0c4023 │ │ │ ├── alter5-15-cbad54fbd4a08fc8717708f93358ec3e │ │ │ ├── alter5-16-4b76b7ff0df6adeded64b2a2f305530d │ │ │ ├── alter5-17-9176dc5fb5206209fa907a289db1263d │ │ │ ├── alter5-18-2a9c8219c1468a1cf0534c665d1fcebf │ │ │ ├── alter5-19-2f6ab691e291c74ecc4305eeb30e3438 │ │ │ ├── alter5-2-4b76b7ff0df6adeded64b2a2f305530d │ │ │ ├── alter5-20-d1779a2fe5ccc205e0499fae4c3942b1 │ │ │ ├── alter5-21-2a9c8219c1468a1cf0534c665d1fcebf │ │ │ ├── alter5-3-2fc59e32c07186869811705c89aafadc │ │ │ ├── alter5-4-2a9c8219c1468a1cf0534c665d1fcebf │ │ │ ├── alter5-5-2f6ab691e291c74ecc4305eeb30e3438 │ │ │ ├── alter5-6-d1779a2fe5ccc205e0499fae4c3942b1 │ │ │ ├── alter5-7-2a9c8219c1468a1cf0534c665d1fcebf │ │ │ ├── alter5-8-89c414c65a129f2fc408b3124f292b29 │ │ │ ├── alter5-9-1e085f9741197e659413828c42386733 │ │ │ ├── alter_index-0-21bcf37075b02097f16c8fc8130a83b8 │ │ │ ├── alter_index-1-4c8f6b48c437bf0be109fc0be1dc840e │ │ │ ├── alter_index-2-f36cb2eed39691ca949b25182e2dd31 │ │ │ ├── alter_index-3-33474b65c86b949d266541e0385bc6bb │ │ │ ├── alter_index-4-f36cb2eed39691ca949b25182e2dd31 │ │ │ ├── alter_index-5-21bcf37075b02097f16c8fc8130a83b8 │ │ │ ├── alter_index-6-489b4ceb2f4301a7132628303f99240d │ │ │ ├── alter_merge_2-0-48044f1a60d3e15e4e17f8f95098d995 │ │ │ ├── alter_merge_2-1-3a102e7798dbcc7948223c18ddaa8cb5 │ │ │ ├── alter_merge_2-10-69fe9bb96263a49b9cca70cea7eb57e1 │ │ │ ├── alter_merge_2-11-efe4e50f2330d4f0a737183ea51836c │ │ │ ├── alter_merge_2-2-bf243aa10b608872b9e8286f89c5ff30 │ │ │ ├── alter_merge_2-3-bc9bb363f9a2026cfc70a31bb4551352 │ │ │ ├── alter_merge_2-4-d3bf7703ba00cf7c40f2a2dbb8ca7224 │ │ │ ├── alter_merge_2-5-6319bf26f3739260b1a77e2ea89ef147 │ │ │ ├── alter_merge_2-6-f2eeb518a957cece4250cc7558839e02 │ │ │ ├── alter_merge_2-7-69fe9bb96263a49b9cca70cea7eb57e1 │ │ │ ├── alter_merge_2-8-c1b9f23f413b1cceaeea94d3a86f09cc │ │ │ ├── alter_merge_2-9-f2eeb518a957cece4250cc7558839e02 │ │ │ ├── alter_partition_protect_mode-0-2a230c069b09232acdd0d556007be97f │ │ │ ├── alter_partition_protect_mode-1-e11f1476d2f30ab7a83f95013809f9e6 │ │ │ ├── alter_partition_protect_mode-10-d71b99098bdb7f13db278dfa299b820d │ │ │ ├── alter_partition_protect_mode-11-482182c9d90710fb16b6803d602a0d8b │ │ │ ├── alter_partition_protect_mode-12-b29d5391cda48aa2bd8f3bb37cc63750 │ │ │ ├── alter_partition_protect_mode-13-19ceced1d8238509f2416029ddfbbc4a │ │ │ ├── alter_partition_protect_mode-14-90d009f94408102945d43860e4a6c68a │ │ │ ├── alter_partition_protect_mode-15-7ab0e8f289c6846f9872edee0c40a628 │ │ │ ├── alter_partition_protect_mode-16-577e1c164866c3955a9d8587ef7918a4 │ │ │ ├── alter_partition_protect_mode-2-29b4b67965f24c40bcc426043efb892d │ │ │ ├── alter_partition_protect_mode-3-2100fc7853625d8c7dad5c0ee70d4690 │ │ │ ├── alter_partition_protect_mode-4-c3fa911536c75e87febf2874e7889879 │ │ │ ├── alter_partition_protect_mode-5-3cc094c5aa537b12f98895b95765329c │ │ │ ├── alter_partition_protect_mode-6-beb03691c7cc6cf1597d3ff16ef98d17 │ │ │ ├── alter_partition_protect_mode-7-5439426a18bb2d3918b91d589dbbd014 │ │ │ ├── alter_partition_protect_mode-8-71e8c12c533654c30e044a8f062598ed │ │ │ ├── alter_partition_protect_mode-9-d1b12be1d01eabaf244f41e74d902d9d │ │ │ ├── alter_partition_with_whitelist-0-3c23ae800b2f6fb93620890da2dba196 │ │ │ ├── alter_partition_with_whitelist-1-67a0dbca9fecb7d34cceeecf2184c484 │ │ │ ├── alter_partition_with_whitelist-2-e6a91be97431de63e372088d370c6d36 │ │ │ ├── alter_partition_with_whitelist-3-b9a6b4e8acbfea5e1938eda085c4b893 │ │ │ ├── alter_partition_with_whitelist-4-f42e9ca89ed2944213a5d994a587391c │ │ │ ├── alter_rename_partition-0-1ed18256c5230de3439fe75d925ea73 │ │ │ ├── alter_rename_partition-1-2f79bceed6fc8ada34a670396ee6aada │ │ │ ├── alter_rename_partition-10-e3d9a36d53d30de215b855095c58d0d7 │ │ │ ├── alter_rename_partition-11-bc84e38ccad173f5b47474d91db244d7 │ │ │ ├── alter_rename_partition-12-1ed18256c5230de3439fe75d925ea73 │ │ │ ├── alter_rename_partition-13-2f79bceed6fc8ada34a670396ee6aada │ │ │ ├── alter_rename_partition-14-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter_rename_partition-15-f3b7bcb5d95a356fee54c0ce7d60c611 │ │ │ ├── alter_rename_partition-16-611cf586cf3a1adc93c543d2da574c24 │ │ │ ├── alter_rename_partition-17-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter_rename_partition-18-bf6f780173f7b523b7ebd7925789372b │ │ │ ├── alter_rename_partition-19-d862c00e5a37ae841a6c8ec6c5d68e8c │ │ │ ├── alter_rename_partition-2-9c36cac1372650b703400c60dd29042c │ │ │ ├── alter_rename_partition-20-ee3ad861d109dd98db10bc86c5bf7105 │ │ │ ├── alter_rename_partition-21-d92bfe92d250f66b3df45cb4ab50c0e6 │ │ │ ├── alter_rename_partition-22-d50111b57d14f1ded1c47c773b0e0ac2 │ │ │ ├── alter_rename_partition-23-aedbaca33604c76b65137905fd42e98f │ │ │ ├── alter_rename_partition-24-21dd05d56ebba285a8eb5bde5904d6a3 │ │ │ ├── alter_rename_partition-25-9595f5b6ab31162c107076c35657c9f3 │ │ │ ├── alter_rename_partition-26-270655c514bb6f04acd4459df52dd77b │ │ │ ├── alter_rename_partition-3-b465c6126edd94e8d45f61e2a19d005b │ │ │ ├── alter_rename_partition-4-833254c8f7c5b1248e1a249560652627 │ │ │ ├── alter_rename_partition-5-6cc4e3014e34a862602a47357f4fb9f2 │ │ │ ├── alter_rename_partition-6-3324664e6500e2d256d0b8b3b8a14c24 │ │ │ ├── alter_rename_partition-7-e3d9a36d53d30de215b855095c58d0d7 │ │ │ ├── alter_rename_partition-8-d3ea111b1a37613bdda2c6eae13790c9 │ │ │ ├── alter_rename_partition-9-21dd05d56ebba285a8eb5bde5904d6a3 │ │ │ ├── alter_table_serde-0-35d2014351106b918c8e337a1919470c │ │ │ ├── alter_table_serde-1-5bc931a540f0fec54e852ff10f52f879 │ │ │ ├── alter_table_serde-10-ed0059ecd1cf948e8f75153593c8a5aa │ │ │ ├── alter_table_serde-11-6ee4b3a60659ec5496f06347eda232a8 │ │ │ ├── alter_table_serde-12-63a8168d2eae62132c3cd9b90b3cdbcc │ │ │ ├── alter_table_serde-13-6ee4b3a60659ec5496f06347eda232a8 │ │ │ ├── alter_table_serde-14-ab6d7ed387e6e2f1f8f32272e3d31def │ │ │ ├── alter_table_serde-15-6ee4b3a60659ec5496f06347eda232a8 │ │ │ ├── alter_table_serde-16-c6bb65a44a8b0ba1fa454218a31a2a44 │ │ │ ├── alter_table_serde-17-6ee4b3a60659ec5496f06347eda232a8 │ │ │ ├── alter_table_serde-18-1649ba756fd9238f0608e4cb3affa3c1 │ │ │ ├── alter_table_serde-2-ed0059ecd1cf948e8f75153593c8a5aa │ │ │ ├── alter_table_serde-3-5bc931a540f0fec54e852ff10f52f879 │ │ │ ├── alter_table_serde-4-63a8168d2eae62132c3cd9b90b3cdbcc │ │ │ ├── alter_table_serde-5-5bc931a540f0fec54e852ff10f52f879 │ │ │ ├── alter_table_serde-6-1649ba756fd9238f0608e4cb3affa3c1 │ │ │ ├── alter_table_serde-7-9ca4794d2e2cb6ae6f8e4f33f7ff290b │ │ │ ├── alter_table_serde-8-78d739d2409b59c0e01cde962451d295 │ │ │ ├── alter_table_serde-9-6ee4b3a60659ec5496f06347eda232a8 │ │ │ ├── alter_view_as_select-0-9f40bf1c2b92465189583446a6b40910 │ │ │ ├── alter_view_as_select-1-5ba1b5ca1199ad7281ff9b5b71105aad │ │ │ ├── alter_view_as_select-2-1ac845048a8c714a36a719ea8e4f570b │ │ │ ├── alter_view_as_select-3-9280ae6c369a9f30d3d021d00e435f01 │ │ │ ├── alter_view_as_select-4-1ac845048a8c714a36a719ea8e4f570b │ │ │ ├── alter_view_as_select-5-48b435d96e34065b03c6d7e4e891fbe2 │ │ │ ├── alter_view_as_select-6-1ac845048a8c714a36a719ea8e4f570b │ │ │ ├── ambiguous_col-0-e91e3e5a22029b9b979ccbbef97add66 │ │ │ ├── ambiguous_col-1-b4fe82679efdf6a15e9ecff53baf8d8d │ │ │ ├── ambiguous_col-2-dadfa3854356dead14b93c5a71a5d8ab │ │ │ ├── ambiguous_col-3-70509ccd2765d90b98666b6dff8afe1b │ │ │ ├── annotate_stats_join-0-2a0c41508e1e70eaedf9de99751c8fa9 │ │ │ ├── annotate_stats_join-1-84e7846d50fc15e836c83911ce039871 │ │ │ ├── annotate_stats_join-10-a59dc1c01d48c82d46a5beab759f618d │ │ │ ├── annotate_stats_join-11-3e0ade2476221f6396381f55a3b82e60 │ │ │ ├── annotate_stats_join-12-cef44682d339a67ba765f854da21f976 │ │ │ ├── annotate_stats_join-13-6292c27f0c4eaeab2a5e6c317e3afa2e │ │ │ ├── annotate_stats_join-14-4f3042b9feebd00c540ddac40e7254d1 │ │ │ ├── annotate_stats_join-15-a2f3b8a636e46e5df514df46c452855f │ │ │ ├── annotate_stats_join-16-a75699a21ea36d962a1ba45bd5a12f26 │ │ │ ├── annotate_stats_join-17-64380f94a431e3a1698aa2edd3d0a6b2 │ │ │ ├── annotate_stats_join-18-222d1fcce7420950436e00d3a1bba957 │ │ │ ├── annotate_stats_join-19-dea5f8f5c703583c7a3bdcb62cd3d589 │ │ │ ├── annotate_stats_join-2-40548ec2313af8dbdcbb8ad0477d8600 │ │ │ ├── annotate_stats_join-20-2d5e186b97166e3a625a169d0d73f9c8 │ │ │ ├── annotate_stats_join-21-ed73d4b01424287148347ccf721b37e2 │ │ │ ├── annotate_stats_join-22-2cf93da6bb0efdafeaa989c9df236701 │ │ │ ├── annotate_stats_join-23-fa90806f6137300311df032e28df3d4c │ │ │ ├── annotate_stats_join-24-4a6976344eeae35e059285ed78f9feb3 │ │ │ ├── annotate_stats_join-3-26f82fb6734d5bc6f7159b06c0949178 │ │ │ ├── annotate_stats_join-4-a598c93d86a646cfa6ea86da54bce9b8 │ │ │ ├── annotate_stats_join-5-d12ba848d20d1def95379c490068f050 │ │ │ ├── annotate_stats_join-6-96a4806e61c5d882affac57e115f285f │ │ │ ├── annotate_stats_join-7-38be41d6328f57350a78fb2097d1ebd2 │ │ │ ├── annotate_stats_join-8-eb11e867a36e2114ef0f0f001e01984c │ │ │ ├── annotate_stats_join-9-e0b7cb2226234fbea8ae11ea7d9d84bd │ │ │ ├── annotate_stats_limit-0-2a0c41508e1e70eaedf9de99751c8fa9 │ │ │ ├── annotate_stats_limit-1-26f82fb6734d5bc6f7159b06c0949178 │ │ │ ├── annotate_stats_limit-10-a89c94fd0de0cfc96725fea890987cc0 │ │ │ ├── annotate_stats_limit-2-eb11e867a36e2114ef0f0f001e01984c │ │ │ ├── annotate_stats_limit-3-e0b7cb2226234fbea8ae11ea7d9d84bd │ │ │ ├── annotate_stats_limit-4-4252006172a476fbc591eebee49bffa3 │ │ │ ├── annotate_stats_limit-5-a2f3b8a636e46e5df514df46c452855f │ │ │ ├── annotate_stats_limit-6-f1fd6c403a9787947877f48c772afe96 │ │ │ ├── annotate_stats_limit-7-69b422026fce4e2d2cde9a478d6aaa40 │ │ │ ├── annotate_stats_limit-8-72f5e55c1e244084eea255c32a6f58eb │ │ │ ├── annotate_stats_limit-9-9da67c62d5e3145d450ad7953b33361f │ │ │ ├── annotate_stats_part-0-2a0c41508e1e70eaedf9de99751c8fa9 │ │ │ ├── annotate_stats_part-1-3c29684bfd2df7439ee0551eb42cfa0 │ │ │ ├── annotate_stats_part-10-5ba0295bfe42deb678e59b3a330b14ff │ │ │ ├── annotate_stats_part-11-dbdbe2e04c5dad6c8af78b6386b329 │ │ │ ├── annotate_stats_part-12-2856fb4f4af8932804cb238429d9de6f │ │ │ ├── annotate_stats_part-13-4fa8b0f9fb0202ac0e82fb87538d6445 │ │ │ ├── annotate_stats_part-14-62c557bfb7bf70694a32ebceea329ebd │ │ │ ├── annotate_stats_part-15-f796cd035603726a5c4ce3e71194822b │ │ │ ├── annotate_stats_part-16-45eb5544124364714549f199f9c2b2ac │ │ │ ├── annotate_stats_part-17-ad61ebd912b6bef3778c4ff38c0be5ab │ │ │ ├── annotate_stats_part-18-b9f2dff7c7b57412cea44433ea810fa7 │ │ │ ├── annotate_stats_part-19-10cab43c2966718bb39e2f22365cd6c1 │ │ │ ├── annotate_stats_part-2-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── annotate_stats_part-20-51ec5046b50543899ed54c9fc2b885af │ │ │ ├── annotate_stats_part-21-d69cb7b7770b51bc4b99d5d0f74d4662 │ │ │ ├── annotate_stats_part-22-22f430881fbfe92736988c2a4184fe0c │ │ │ ├── annotate_stats_part-23-2719ee3f0b8b07f1e5c80f8329b9f87f │ │ │ ├── annotate_stats_part-24-1f7bdd816b83f45a6d53d08b6866109f │ │ │ ├── annotate_stats_part-25-d1599e385e8bad6cd62d564a6fd0536f │ │ │ ├── annotate_stats_part-26-ec26bcb2587f4638b364ba494ac373e0 │ │ │ ├── annotate_stats_part-27-7804e2e230a42a46d72546fa2381b423 │ │ │ ├── annotate_stats_part-28-40f2a1f06d181ef93edf42a591cbf15e │ │ │ ├── annotate_stats_part-3-16367c381d4b189b3640c92511244bfe │ │ │ ├── annotate_stats_part-4-397e834a25a20b68aed5e87d55ea6174 │ │ │ ├── annotate_stats_part-5-cef44682d339a67ba765f854da21f976 │ │ │ ├── annotate_stats_part-6-f4263aca1612c05cb08242448191ad05 │ │ │ ├── annotate_stats_part-7-b222533ddda09918c4f5acc408bf1a02 │ │ │ ├── annotate_stats_part-8-84e3979946de67779a9704a3adc2184f │ │ │ ├── annotate_stats_part-9-c6c38e93babafe56cd4f177a17d37b8 │ │ │ ├── annotate_stats_table-0-2a0c41508e1e70eaedf9de99751c8fa9 │ │ │ ├── annotate_stats_table-1-3c29684bfd2df7439ee0551eb42cfa0 │ │ │ ├── annotate_stats_table-10-a7419af512a6c0b60ec51e556608cdad │ │ │ ├── annotate_stats_table-11-4be11140c2e21b3a172224d103844785 │ │ │ ├── annotate_stats_table-12-84bc7cf67544461e9102820ed410dfb6 │ │ │ ├── annotate_stats_table-13-d2acfdf279aad035b31ed61e87bff6 │ │ │ ├── annotate_stats_table-14-60d1c44b8412c4983265e320ecfb25f0 │ │ │ ├── annotate_stats_table-15-7b185296b6a0c6ceff2df1f89fecc6b4 │ │ │ ├── annotate_stats_table-16-7cf8cb7d8d0fe3ea94d7b190a2e5ad3d │ │ │ ├── annotate_stats_table-17-cd84d629d569a09d139f38dae01e677c │ │ │ ├── annotate_stats_table-18-7012af4092c18075f4f3a00b80f491ee │ │ │ ├── annotate_stats_table-2-84e7846d50fc15e836c83911ce039871 │ │ │ ├── annotate_stats_table-3-a598c93d86a646cfa6ea86da54bce9b8 │ │ │ ├── annotate_stats_table-4-d12ba848d20d1def95379c490068f050 │ │ │ ├── annotate_stats_table-5-4a8ad142e57c5dce2623e92f5e5ad15a │ │ │ ├── annotate_stats_table-6-a59dc1c01d48c82d46a5beab759f618d │ │ │ ├── annotate_stats_table-7-6292c27f0c4eaeab2a5e6c317e3afa2e │ │ │ ├── annotate_stats_table-8-43cb040e2fe01904bc52e198fcae9b3d │ │ │ ├── annotate_stats_table-9-eadfdc61d22bd22bbf5a69370908a82e │ │ │ ├── annotate_stats_union-0-2a0c41508e1e70eaedf9de99751c8fa9 │ │ │ ├── annotate_stats_union-1-26f82fb6734d5bc6f7159b06c0949178 │ │ │ ├── annotate_stats_union-10-3aa3eb68d092ea0157c5426a5f2ca3f9 │ │ │ ├── annotate_stats_union-11-c1302094d7b4456550826535b529468b │ │ │ ├── annotate_stats_union-12-3af760f960a2e0995d1bc4afef0c5aa0 │ │ │ ├── annotate_stats_union-13-26f82fb6734d5bc6f7159b06c0949178 │ │ │ ├── annotate_stats_union-14-eb11e867a36e2114ef0f0f001e01984c │ │ │ ├── annotate_stats_union-15-e0b7cb2226234fbea8ae11ea7d9d84bd │ │ │ ├── annotate_stats_union-16-4252006172a476fbc591eebee49bffa3 │ │ │ ├── annotate_stats_union-17-a2f3b8a636e46e5df514df46c452855f │ │ │ ├── annotate_stats_union-18-58d55f8c8b2489726232a00254499144 │ │ │ ├── annotate_stats_union-19-70c851c23a7ac89f0366b9c26085cc3e │ │ │ ├── annotate_stats_union-2-eb11e867a36e2114ef0f0f001e01984c │ │ │ ├── annotate_stats_union-20-222d1fcce7420950436e00d3a1bba957 │ │ │ ├── annotate_stats_union-21-a5503df8f50e057415719bcfe4c69f13 │ │ │ ├── annotate_stats_union-22-a23089e5a76dc35df04d9936d60c4565 │ │ │ ├── annotate_stats_union-3-e0b7cb2226234fbea8ae11ea7d9d84bd │ │ │ ├── annotate_stats_union-4-4252006172a476fbc591eebee49bffa3 │ │ │ ├── annotate_stats_union-5-a2f3b8a636e46e5df514df46c452855f │ │ │ ├── annotate_stats_union-6-222d1fcce7420950436e00d3a1bba957 │ │ │ ├── annotate_stats_union-7-aab1a7b7e1fe4d061a580126d67dfd0a │ │ │ ├── annotate_stats_union-8-172e0d089bd5bcbaf54775a618d826bb │ │ │ ├── annotate_stats_union-9-69b422026fce4e2d2cde9a478d6aaa40 │ │ │ ├── attr-0-24e06ffd262f2a5a6eec3314445d83ba │ │ │ ├── auto_join0-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join0-1-383f34dec3ac939b7af2c9093a557641 │ │ │ ├── auto_join0-2-7bd04899197b027d81c24e45a99ad15c │ │ │ ├── auto_join1-0-443afb71720bad780b5dbfb6dbf4b51a │ │ │ ├── auto_join1-1-f1293ebf768eb04f2f0bfe6297c4509e │ │ │ ├── auto_join1-2-8a9624554e208e3d8fbe42908c715b92 │ │ │ ├── auto_join1-3-f6046c5229e3b0aa21498a3872f43b2 │ │ │ ├── auto_join1-4-ae1247a065c41ce0329ca6078ab586e │ │ │ ├── auto_join10-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join10-1-dc932cb87d4d1a90dc5733c544b6a3d0 │ │ │ ├── auto_join10-2-eef4ee52e0783b15fb5fe17378806b13 │ │ │ ├── auto_join11-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join11-1-82ea193ec76c2c6acd5f7178ef5ec417 │ │ │ ├── auto_join11-2-5496e81f60ba1d8a95d8375589c71e05 │ │ │ ├── auto_join12-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join12-1-c2efec9ea2ba761603b723afc0d5d145 │ │ │ ├── auto_join12-2-4df549c5f0b6bff0c843008fa35b1320 │ │ │ ├── auto_join13-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join13-1-f5e043288a21ea691c74fef2e39a52b4 │ │ │ ├── auto_join13-2-5ff417533a1243cd6fc556960fa170c9 │ │ │ ├── auto_join14-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join14-1-c85f3dcbab496811604ea0ab84d0e995 │ │ │ ├── auto_join14-2-9b141c1e5917ca82c6bc36a9a2950a1e │ │ │ ├── auto_join14-3-2b9ccaa793eae0e73bf76335d3d6880 │ │ │ ├── auto_join14-4-bab89dfffa77258e34a595e0e79986e3 │ │ │ ├── auto_join14-5-2454f1ce2e8d0d03a30c479f7dcd8153 │ │ │ ├── auto_join14-6-de39302191b63d7aa8f92885b089fe2 │ │ │ ├── auto_join14-7-5b5ded1412301eae5f8f705a39e6832 │ │ │ ├── auto_join14_hadoop20-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join14_hadoop20-1-98b7542190092fafcc8b1ad5b0024a22 │ │ │ ├── auto_join14_hadoop20-2-2b9ccaa793eae0e73bf76335d3d6880 │ │ │ ├── auto_join14_hadoop20-3-bab89dfffa77258e34a595e0e79986e3 │ │ │ ├── auto_join14_hadoop20-4-2454f1ce2e8d0d03a30c479f7dcd8153 │ │ │ ├── auto_join14_hadoop20-5-de39302191b63d7aa8f92885b089fe2 │ │ │ ├── auto_join14_hadoop20-6-5b5ded1412301eae5f8f705a39e6832 │ │ │ ├── auto_join15-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join15-1-e23b9aa655061fb5a70d1f8f28f170f5 │ │ │ ├── auto_join15-2-7bf2df40dd30fb2f8c4af9a0d09e24f9 │ │ │ ├── auto_join17-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join17-1-387dd86b1e13f788ec677a08dc162c97 │ │ │ ├── auto_join17-2-c2fd9f9c4cc80f21ea8c10edaaf03808 │ │ │ ├── auto_join17-3-478a9f270a5d70f6f82f81e6962fb251 │ │ │ ├── auto_join17-4-11d706a64d44a8b0d41b290c4671c29c │ │ │ ├── auto_join18-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join18-1-3839d176ee45fb0fc6702f4a7794ca1b │ │ │ ├── auto_join18-2-f633ade9577c8b0e89d89124194c8d0f │ │ │ ├── auto_join19-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join19-1-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── auto_join19-2-70f3756d8b44d637ac4596cbbd48dc77 │ │ │ ├── auto_join19-3-a3751c195480244a5ed497fd053cd433 │ │ │ ├── auto_join19-4-eaa70da463b92e85e1796277f016c18f │ │ │ ├── auto_join2-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join2-1-3d1692c4710db1ff716d35e921f2bcca │ │ │ ├── auto_join2-2-15d7a6cb2e2f21077de2447c656e7a34 │ │ │ ├── auto_join2-3-d4673c03d04084b838fcd8149f59ad9a │ │ │ ├── auto_join2-4-9d8144612cb3132ad9f7c8fa93586185 │ │ │ ├── auto_join20-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join20-1-2afb0510178c4b66876dd91c7ca441fd │ │ │ ├── auto_join20-2-903ee25e327188edaaf2040fec5a8e52 │ │ │ ├── auto_join20-3-cf1c52393ea3a7e21782a1c52b83f0ee │ │ │ ├── auto_join20-4-e48e08d5b94719d56a58284eaef757f2 │ │ │ ├── auto_join21-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join21-1-9dd59784ca1555b607df0137d2666fb8 │ │ │ ├── auto_join21-2-3536b7d78713e86ee67f5f6c9b88958f │ │ │ ├── auto_join22-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join22-1-4044be0e5116357bd88b4eda0f9ccaa8 │ │ │ ├── auto_join22-2-a4abc288c20edee53ede45d248cf3abb │ │ │ ├── auto_join23-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join23-1-b31437533a2b890788938455cb32f679 │ │ │ ├── auto_join23-2-6d2c5b58222f31658a0cf957e093a150 │ │ │ ├── auto_join24-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join24-1-721dfa03bfea05e55506c571b6c3585b │ │ │ ├── auto_join24-2-36de83b0ed6c9fdc03661b2f65b23a3d │ │ │ ├── auto_join24-3-fa8b2736440ff35687dadb1bcae32666 │ │ │ ├── auto_join24-4-d79325ef6494aa87843fdfd78de7c812 │ │ │ ├── auto_join25-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join25-1-a0fc12fc2b968d7e85e6c1e2fd70cd94 │ │ │ ├── auto_join25-10-f1293ebf768eb04f2f0bfe6297c4509e │ │ │ ├── auto_join25-11-f6046c5229e3b0aa21498a3872f43b2 │ │ │ ├── auto_join25-12-ae1247a065c41ce0329ca6078ab586e │ │ │ ├── auto_join25-2-8180638a57b64557e02815c863031755 │ │ │ ├── auto_join25-3-9aa914a687f1f63faf48eb500627855e │ │ │ ├── auto_join25-4-d83e6df8cd60d8ebeebd2100c51002d9 │ │ │ ├── auto_join25-5-a3751c195480244a5ed497fd053cd433 │ │ │ ├── auto_join25-6-eaa70da463b92e85e1796277f016c18f │ │ │ ├── auto_join25-7-3d1692c4710db1ff716d35e921f2bcca │ │ │ ├── auto_join25-8-d4673c03d04084b838fcd8149f59ad9a │ │ │ ├── auto_join25-9-9d8144612cb3132ad9f7c8fa93586185 │ │ │ ├── auto_join26-0-54a7280ab9eed0d2e3b33df35a721b66 │ │ │ ├── auto_join26-1-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join26-2-5ebef1af539734d0335dbe6aacae3e13 │ │ │ ├── auto_join26-3-fed383a65bd118b43de6b00be10fecb6 │ │ │ ├── auto_join26-4-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── auto_join27-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join27-1-c83f56f364b1da3def90d48953665fe5 │ │ │ ├── auto_join27-2-fceaa1ebd63334061d2d8daf961e935e │ │ │ ├── auto_join28-0-10a2c01dccc8980fe6aff1f9dd65042c │ │ │ ├── auto_join28-1-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join28-2-9dd59784ca1555b607df0137d2666fb8 │ │ │ ├── auto_join28-3-30739ff22c62b3becf56694642b7ae81 │ │ │ ├── auto_join28-4-c178253e7ce91b5aa35c2cc424bfa27 │ │ │ ├── auto_join28-5-142850e84341feb3f7f40dd4553f72e │ │ │ ├── auto_join3-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join3-1-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── auto_join3-2-6bed7d8089695e23914b29edaab2537d │ │ │ ├── auto_join3-3-e9f6d17b15064f953a588fb40aee2f90 │ │ │ ├── auto_join3-4-eaa70da463b92e85e1796277f016c18f │ │ │ ├── auto_join30-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join30-1-8cef272a7680529de5c6bd227a83cbc0 │ │ │ ├── auto_join30-10-820f36ed1bdf14c1deb383f508a5ed7a │ │ │ ├── auto_join30-11-53e43f2e48f605ec92c8a18c53e80620 │ │ │ ├── auto_join30-12-de6e26f52f6f9ea5ef9a4868e57d36d │ │ │ ├── auto_join30-13-9ee597656aa92e48475d6542339915ba │ │ │ ├── auto_join30-14-7a248488c218919ab50e072fdbdecb73 │ │ │ ├── auto_join30-15-47b7efabbd6046e2befcbbea7da62553 │ │ │ ├── auto_join30-16-f4f5bc179d84baf57e14cd2f8bd39436 │ │ │ ├── auto_join30-2-bc472f95600f47d5ea60fdeddc59dbc7 │ │ │ ├── auto_join30-3-57e5f7c770abbe1de38cbbcd5fd332a2 │ │ │ ├── auto_join30-4-f5083eca9c3df277988d8b345b8d43 │ │ │ ├── auto_join30-5-3916f4b640f3579035153f6940113ef2 │ │ │ ├── auto_join30-6-4a9144326fc7d066c9aadb13d1b95031 │ │ │ ├── auto_join30-7-f07b674c31ca9fdf837406cb9a96108e │ │ │ ├── auto_join30-8-8a27209399df7f9c4d15988b11753a61 │ │ │ ├── auto_join30-9-4ee48fa9bfeb818c81768b6de0517263 │ │ │ ├── auto_join31-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join31-1-5a2b4475d9a88e53a2b6ec29279253c0 │ │ │ ├── auto_join31-2-a64aa9cb44edc6b85ed945fb13ca9c2 │ │ │ ├── auto_join32-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_join32-1-2e533cf988f613d5fc3fbde67ffd9118 │ │ │ ├── auto_join32-10-2e8ccb343bce61564bae209a589cca85 │ │ │ ├── auto_join32-11-4d6fc319375b6962eca0aa63dfabfdc1 │ │ │ ├── auto_join32-12-4a7d51ed5c1d98c518ea74f73c6c7d6c │ │ │ ├── auto_join32-13-ee2dcaae78ae900ffce8d19fbadc3735 │ │ │ ├── auto_join32-14-7927c2ce644d1ce1de251405c8563e99 │ │ │ ├── auto_join32-15-4cd3b51861720ac06c6deb818c83670 │ │ │ ├── auto_join32-16-2e8ccb343bce61564bae209a589cca85 │ │ │ ├── auto_join32-17-4d6fc319375b6962eca0aa63dfabfdc1 │ │ │ ├── auto_join32-18-d1d78b19d484e55d9da8a320253ece0f │ │ │ ├── auto_join32-19-83b9df41bc46afbbafd0cd30cb982332 │ │ │ ├── auto_join32-2-865207407ff1acbccb47473d87e87e8d │ │ │ ├── auto_join32-20-693874ea8e06a8b155394ac27af2b1a7 │ │ │ ├── auto_join32-21-bf8a1bb0baaae9fbf1c3aa656f991f42 │ │ │ ├── auto_join32-22-3d14d63e996851f51a98f987995d8da6 │ │ │ ├── auto_join32-23-8b183ec2c164b3b530e802ffc880a5fa │ │ │ ├── auto_join32-24-cda0994eb851b57fdb80e16b033d1b73 │ │ │ ├── auto_join32-25-e46226186de575c81cfab296607e1b4b │ │ │ ├── auto_join32-26-97d265cd7defca44e488c38bac4c5b7a │ │ │ ├── auto_join32-27-b034eeb850810b5004ddff1f2a530bc │ │ │ ├── auto_join32-28-751550ac0550e6a7dd737cad01d6d82 │ │ │ ├── auto_join32-29-34ecfdabf9c769027706f53fa2d66ed3 │ │ │ ├── auto_join32-3-9ccdfe4052062a1dfc72c711179d9e43 │ │ │ ├── auto_join32-30-d3903985844b06c4af11334b72f383d1 │ │ │ ├── auto_join32-31-2415fd7a0c2e37b09679bb4c64f321bd │ │ │ ├── auto_join32-4-a28f563122d1f0debd04f74c534523cf │ │ │ ├── auto_join32-5-c23ea191ee4d60c0a6252ce763b1beed │ │ │ ├── auto_join32-6-442e69416faaea9309bb8c2a3eb73ef │ │ │ ├── auto_join32-7-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_join32-8-999683fa0291bf439b03557edec7dcee │ │ │ ├── auto_join32-9-1e6d4ec86f29d74828891c17986e84a │ │ │ ├── auto_join4-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join4-1-531e91e11b3891627c2675935fda14cd │ │ │ ├── auto_join4-2-4a36be16bcfa2bc35a8c33fb71ce2c7a │ │ │ ├── auto_join4-3-dc967001beb776f3a859e9360823c361 │ │ │ ├── auto_join4-4-998c3a307b074a6505bb7fcef276be04 │ │ │ ├── auto_join5-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join5-1-531e91e11b3891627c2675935fda14cd │ │ │ ├── auto_join5-2-a13b6523395e55c551ad42d92f9dbcd6 │ │ │ ├── auto_join5-3-b07bb1fdcd0eeeb62a8f7acb70cd2330 │ │ │ ├── auto_join5-4-998c3a307b074a6505bb7fcef276be04 │ │ │ ├── auto_join6-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join6-1-531e91e11b3891627c2675935fda14cd │ │ │ ├── auto_join6-2-46718fdfa123cc86fe288bff4185dc90 │ │ │ ├── auto_join6-3-bc6b6640b266ebe9b73702d3baf09c20 │ │ │ ├── auto_join6-4-998c3a307b074a6505bb7fcef276be04 │ │ │ ├── auto_join7-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join7-1-8f82881057bec4abf5a4d770a6f35838 │ │ │ ├── auto_join7-2-8a7f50dc7e382a11884f4e116041aa1e │ │ │ ├── auto_join7-3-56a30a1aa948bcf5ee54481897fc2208 │ │ │ ├── auto_join7-4-30d0c1a49784347fedbac21a69c3a899 │ │ │ ├── auto_join8-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join8-1-531e91e11b3891627c2675935fda14cd │ │ │ ├── auto_join8-2-cdb9885fe05daa90c228cf5b6550eeab │ │ │ ├── auto_join8-3-f1196bca86a749375da35f134206a8ca │ │ │ ├── auto_join8-4-998c3a307b074a6505bb7fcef276be04 │ │ │ ├── auto_join9-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join9-1-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── auto_join9-2-62638666bf7f60c0d298547ea5e93ea7 │ │ │ ├── auto_join9-3-971c44e81ce17eb0849850b72ebd20f1 │ │ │ ├── auto_join9-4-eaa70da463b92e85e1796277f016c18f │ │ │ ├── auto_join_filters-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join_filters-1-5644ab44e5ba9f2941216b8d5dc33a99 │ │ │ ├── auto_join_filters-10-b420f24d33b26cdf6c35eb702789904e │ │ │ ├── auto_join_filters-11-c06b548171893bae8def6bb348b70dc8 │ │ │ ├── auto_join_filters-12-42a4901e05e9ee92abcfcef008efaa65 │ │ │ ├── auto_join_filters-13-222c404c6265ed682579342113221e29 │ │ │ ├── auto_join_filters-14-ecd2885156f56973960d064211ee42f0 │ │ │ ├── auto_join_filters-15-11a471880f5e8fbad81e3869fe56ca4b │ │ │ ├── auto_join_filters-16-f26ad8c3537dc391ab1ca6a95470f75e │ │ │ ├── auto_join_filters-17-8e085f9886e5ee97334512f84bd7ab54 │ │ │ ├── auto_join_filters-18-d9438071b3c731dc3f6e3b7248a1042a │ │ │ ├── auto_join_filters-19-58355bd5c4b12e15cf1d3e2d8b308c9d │ │ │ ├── auto_join_filters-2-bee6095f42de6a16708c2f9addc1b9bd │ │ │ ├── auto_join_filters-20-486a302359aecff37a4567480264bd62 │ │ │ ├── auto_join_filters-21-8018df5b9572e89304b449e618fdbbf │ │ │ ├── auto_join_filters-22-f9a7bff2b42a03d21d8d3190d2702451 │ │ │ ├── auto_join_filters-23-2b5149e29c224a47af98ca10bc5c23b3 │ │ │ ├── auto_join_filters-24-a2161a58f512b8bdd836b48cd8e16668 │ │ │ ├── auto_join_filters-25-1b3177a066ba352539fd5473fbeda1a9 │ │ │ ├── auto_join_filters-26-ecfb8fe4bf85a05f321754d8ea8cbabd │ │ │ ├── auto_join_filters-27-ca73726ffaa5826a3db039cda440e6d9 │ │ │ ├── auto_join_filters-28-c21c2acf7f276c0a26f0c19e3234506 │ │ │ ├── auto_join_filters-29-6d8955591f62d9cfc6af17df63d3d88e │ │ │ ├── auto_join_filters-3-64615cc6839c697c8c028ef8bb1ac40e │ │ │ ├── auto_join_filters-30-23ab7ac8229a53d391195be7ca092429 │ │ │ ├── auto_join_filters-31-268d8fb3cb9b04eb269fe7ec40a24dfe │ │ │ ├── auto_join_filters-32-6dc6866a65c74d69538b776b41b06c16 │ │ │ ├── auto_join_filters-33-e884480a0f7273d3e2f2de2ba46b855c │ │ │ ├── auto_join_filters-34-98fd86aea9cacaa82d43c7468109dd33 │ │ │ ├── auto_join_filters-35-3e6612a89e9124592e790594775054b1 │ │ │ ├── auto_join_filters-36-60a5f56f33fc8854a2b687005f0d96ac │ │ │ ├── auto_join_filters-37-64cabe5164130a94f387288f37b62d71 │ │ │ ├── auto_join_filters-38-65c867e66bc773470f1487487086a180 │ │ │ ├── auto_join_filters-39-cc0cf9ff9ccbc44536b3187b27aa1ada │ │ │ ├── auto_join_filters-4-7df3e2e761c272ddb3654e4dd86bd131 │ │ │ ├── auto_join_filters-40-4dfa64337f711dc394a289adeac8666 │ │ │ ├── auto_join_filters-41-a905633bccd782f14115643b2d707b13 │ │ │ ├── auto_join_filters-42-ae4cc72ddbbbd748179e0abcc985726 │ │ │ ├── auto_join_filters-43-f64cec45b154c4ba5172afcdff623a2b │ │ │ ├── auto_join_filters-44-c552dcc9b931dff05cf8c0d712e22841 │ │ │ ├── auto_join_filters-45-b420f24d33b26cdf6c35eb702789904e │ │ │ ├── auto_join_filters-46-c06b548171893bae8def6bb348b70dc8 │ │ │ ├── auto_join_filters-47-42a4901e05e9ee92abcfcef008efaa65 │ │ │ ├── auto_join_filters-48-222c404c6265ed682579342113221e29 │ │ │ ├── auto_join_filters-49-ecd2885156f56973960d064211ee42f0 │ │ │ ├── auto_join_filters-5-87cf8865e2c35b680bba159b88b074bc │ │ │ ├── auto_join_filters-50-11a471880f5e8fbad81e3869fe56ca4b │ │ │ ├── auto_join_filters-51-f26ad8c3537dc391ab1ca6a95470f75e │ │ │ ├── auto_join_filters-52-8e085f9886e5ee97334512f84bd7ab54 │ │ │ ├── auto_join_filters-53-d9438071b3c731dc3f6e3b7248a1042a │ │ │ ├── auto_join_filters-54-58355bd5c4b12e15cf1d3e2d8b308c9d │ │ │ ├── auto_join_filters-55-486a302359aecff37a4567480264bd62 │ │ │ ├── auto_join_filters-56-8018df5b9572e89304b449e618fdbbf │ │ │ ├── auto_join_filters-57-f9a7bff2b42a03d21d8d3190d2702451 │ │ │ ├── auto_join_filters-58-2b5149e29c224a47af98ca10bc5c23b3 │ │ │ ├── auto_join_filters-59-a2161a58f512b8bdd836b48cd8e16668 │ │ │ ├── auto_join_filters-6-9362466c777fff7e677dd8da072f8744 │ │ │ ├── auto_join_filters-60-1b3177a066ba352539fd5473fbeda1a9 │ │ │ ├── auto_join_filters-61-ecfb8fe4bf85a05f321754d8ea8cbabd │ │ │ ├── auto_join_filters-62-ca73726ffaa5826a3db039cda440e6d9 │ │ │ ├── auto_join_filters-63-c21c2acf7f276c0a26f0c19e3234506 │ │ │ ├── auto_join_filters-7-ae4cc72ddbbbd748179e0abcc985726 │ │ │ ├── auto_join_filters-8-f64cec45b154c4ba5172afcdff623a2b │ │ │ ├── auto_join_filters-9-c552dcc9b931dff05cf8c0d712e22841 │ │ │ ├── auto_join_nulls-0-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── auto_join_nulls-1-5644ab44e5ba9f2941216b8d5dc33a99 │ │ │ ├── auto_join_nulls-10-ad7e37acbc658b5a822ca342fd4b9d01 │ │ │ ├── auto_join_nulls-11-141c550a314d15c4e200e5baeb246de2 │ │ │ ├── auto_join_nulls-12-8a65225a88da0169af26848c06cb981c │ │ │ ├── auto_join_nulls-13-e9c3ae95d7edd0c311c7d57e4cebdc80 │ │ │ ├── auto_join_nulls-14-2be327f5d98b6ca8a45a6e1d97948ec8 │ │ │ ├── auto_join_nulls-15-d2ff8e87c24e152107bba1ebf659d0c8 │ │ │ ├── auto_join_nulls-16-dbe244d2c21e477c3703c4ce1903e8af │ │ │ ├── auto_join_nulls-17-f3cf64fcd82d5f33d249ed64bfc13621 │ │ │ ├── auto_join_nulls-18-439a409bc50dfd86dee78c151c3de5eb │ │ │ ├── auto_join_nulls-19-92641e46934ebbf3d44e6e60de1882f4 │ │ │ ├── auto_join_nulls-2-75b1f5331b62fedb7dbbe6ac93a3c83f │ │ │ ├── auto_join_nulls-20-e34b2b210059a5f93c0a873d91859b5d │ │ │ ├── auto_join_nulls-21-c7aaa831acbd959c6d1793056e3c288a │ │ │ ├── auto_join_nulls-22-f5beafb0c5ed59a1852811c9710fe9a3 │ │ │ ├── auto_join_nulls-23-5805a41289a26139c06604a40bf5a6fa │ │ │ ├── auto_join_nulls-24-80991af26d5d37e0864ecc2c8ab0b984 │ │ │ ├── auto_join_nulls-3-f0befc0275bda075e4f3cd61eafcccc7 │ │ │ ├── auto_join_nulls-4-fc1128c86cd430db8cd4ff834be4562 │ │ │ ├── auto_join_nulls-5-2b5f38b7537ed5c40c0ad478b08fc1fc │ │ │ ├── auto_join_nulls-6-d256ec23d7b98e1517cacf5dae2f4124 │ │ │ ├── auto_join_nulls-7-8395fa78507105c2a018e88f717b95e2 │ │ │ ├── auto_join_nulls-8-fd992f2127a139aeb554d797e748ed54 │ │ │ ├── auto_join_nulls-9-e3a86622a437e910b7225d1e6108da9e │ │ │ ├── auto_join_reordering_values-0-1d8e3d660bb4b29287df5700bfe63b63 │ │ │ ├── auto_join_reordering_values-1-2bfb628930d072124636d21d82e3b462 │ │ │ ├── auto_join_reordering_values-10-f6d5bb38137da35b91da901ba310c2b8 │ │ │ ├── auto_join_reordering_values-2-3ce329282fc72110e9ed6c78fa914395 │ │ │ ├── auto_join_reordering_values-3-6e9d99d2a0cac78b7fe242dc1e43d3d8 │ │ │ ├── auto_join_reordering_values-4-11af6838bb9e04152c2f9a7e2044abe0 │ │ │ ├── auto_join_reordering_values-5-b5da89b0cb325cf684406b620eb9d8ee │ │ │ ├── auto_join_reordering_values-6-2c91dc4b7c00d5f09862119c12295532 │ │ │ ├── auto_join_reordering_values-7-99fcaa5203ed3debb52c9086028dc8c2 │ │ │ ├── auto_join_reordering_values-8-950af86c321a67ab3ed0fa5b63ea6aed │ │ │ ├── auto_join_reordering_values-9-ae02756bd46266ec7fd9cc809bc4757b │ │ │ ├── auto_smb_mapjoin_14-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_smb_mapjoin_14-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_smb_mapjoin_14-10-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_smb_mapjoin_14-11-906a582602602372e1d4776243abeab5 │ │ │ ├── auto_smb_mapjoin_14-12-94538bc7322522a5534cafc0551d2189 │ │ │ ├── auto_smb_mapjoin_14-13-1d603e61c2cb888499504ddab98ccc65 │ │ │ ├── auto_smb_mapjoin_14-14-d5183dfa8d9fb9175478fb1c2f2edb97 │ │ │ ├── auto_smb_mapjoin_14-15-758d5532083d6279e169b54fd69bb580 │ │ │ ├── auto_smb_mapjoin_14-16-2798f20aaf0fe5505c34b118e4b10bc5 │ │ │ ├── auto_smb_mapjoin_14-17-ca77b5fb54de526972c16ad6118e86d6 │ │ │ ├── auto_smb_mapjoin_14-18-21269869cd3aaf4ade2170d9017de018 │ │ │ ├── auto_smb_mapjoin_14-19-853c4fa5a2385b92fdb39d0ac2926973 │ │ │ ├── auto_smb_mapjoin_14-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_smb_mapjoin_14-20-4e0e8cd0626a84b21ca7d2f633623578 │ │ │ ├── auto_smb_mapjoin_14-21-e210ced77b32cd7ce87044bb3e3370d1 │ │ │ ├── auto_smb_mapjoin_14-22-2fe7b834b341bf18e36cd79dd00ec16a │ │ │ ├── auto_smb_mapjoin_14-23-63d105e0acd3521bb29ba8cec9ac4583 │ │ │ ├── auto_smb_mapjoin_14-24-43ba2c72db9db1ec18d835ec978f8da1 │ │ │ ├── auto_smb_mapjoin_14-25-7b2a1128afe35706f1540bfc251d0736 │ │ │ ├── auto_smb_mapjoin_14-26-b66c416fdd98d76981f19e9c14b6a562 │ │ │ ├── auto_smb_mapjoin_14-27-5438118dc1d9fab501a8e60eddd625a2 │ │ │ ├── auto_smb_mapjoin_14-28-b889b147255231f7fe44bd57e1f8ba66 │ │ │ ├── auto_smb_mapjoin_14-29-ff6eca271c60cb15a3ea2395ac737b0d │ │ │ ├── auto_smb_mapjoin_14-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_smb_mapjoin_14-30-b9d66e78b8898a97a42d1118300fa0ce │ │ │ ├── auto_smb_mapjoin_14-31-d25f41c6f7c20044ed4d9a9905fdfcce │ │ │ ├── auto_smb_mapjoin_14-32-b0ca9e20cd48457e6cf1c313d5505213 │ │ │ ├── auto_smb_mapjoin_14-33-5f340dbc8126f7e336d3c85e9ab346b5 │ │ │ ├── auto_smb_mapjoin_14-34-76ded9e08c765bf2e1b670b4ffb938b │ │ │ ├── auto_smb_mapjoin_14-35-4e6a34e1f68538ad9e25b7c3a8d18e76 │ │ │ ├── auto_smb_mapjoin_14-36-1ba279881865c861a793797ae84a3934 │ │ │ ├── auto_smb_mapjoin_14-37-a45927057c01fd54818b5dd50e77f60e │ │ │ ├── auto_smb_mapjoin_14-38-a988727daa49fb5e190f81c027bb7005 │ │ │ ├── auto_smb_mapjoin_14-39-20c26228d10872eec10dbb9322dd74da │ │ │ ├── auto_smb_mapjoin_14-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_smb_mapjoin_14-40-4c57b1c6c081294cbd72626ff0fd940e │ │ │ ├── auto_smb_mapjoin_14-41-81b3db8d18d4b3843ed0be6eca5d793c │ │ │ ├── auto_smb_mapjoin_14-42-80db3a67d59c8710edf9f695e7eeb37c │ │ │ ├── auto_smb_mapjoin_14-43-a45927057c01fd54818b5dd50e77f60e │ │ │ ├── auto_smb_mapjoin_14-44-48b32dd521ddf1af1c8075ecbeccaa75 │ │ │ ├── auto_smb_mapjoin_14-5-9140b367b5680860f4c7c0238377583f │ │ │ ├── auto_smb_mapjoin_14-6-70c1d66123d434d3a1e1801e0b19bc3f │ │ │ ├── auto_smb_mapjoin_14-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_smb_mapjoin_14-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_smb_mapjoin_14-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── auto_sortmerge_join_1-0-b24f5a262c6693f31ed376a5da0787f3 │ │ │ ├── auto_sortmerge_join_1-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_1-10-5cba470fbd02e730781a3b63fd9aa3e2 │ │ │ ├── auto_sortmerge_join_1-11-337e909605c780d00ad8895686defa06 │ │ │ ├── auto_sortmerge_join_1-12-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_1-13-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_1-14-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_1-15-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_1-16-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_1-17-30259eb1873d8f5d00dccd8af0b0ccbc │ │ │ ├── auto_sortmerge_join_1-18-a6ef74ae9c70c382abb4d361e6f1e070 │ │ │ ├── auto_sortmerge_join_1-19-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_1-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_1-20-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_1-21-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_1-22-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_1-23-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_1-24-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_1-3-18bd222285d3a3bd71d3cfa217d9b1db │ │ │ ├── auto_sortmerge_join_1-4-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_1-5-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_1-6-e44aff8a860cf3965752d3e1ce725cde │ │ │ ├── auto_sortmerge_join_1-7-ae582a255a02d91674aab500aee79e20 │ │ │ ├── auto_sortmerge_join_1-8-962264967269db1d5f28a9a6c60dbf1 │ │ │ ├── auto_sortmerge_join_1-9-10b03ce2526bf180faaec9310cfab290 │ │ │ ├── auto_sortmerge_join_10-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_sortmerge_join_10-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_sortmerge_join_10-10-b89ea2173180c8ae423d856f943e061f │ │ │ ├── auto_sortmerge_join_10-11-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_10-12-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_10-13-469a09efa93fa9aec154a5967eec09c5 │ │ │ ├── auto_sortmerge_join_10-14-95e18bd00f2de246efca1756681c1e87 │ │ │ ├── auto_sortmerge_join_10-15-6a7fdb423721e7aefa2efda26785e1a │ │ │ ├── auto_sortmerge_join_10-16-caa641c820fcc5f601758c5f0385b4e │ │ │ ├── auto_sortmerge_join_10-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_sortmerge_join_10-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_sortmerge_join_10-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_sortmerge_join_10-5-9140b367b5680860f4c7c0238377583f │ │ │ ├── auto_sortmerge_join_10-6-70c1d66123d434d3a1e1801e0b19bc3f │ │ │ ├── auto_sortmerge_join_10-7-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_10-8-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_10-9-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_11-0-4705fafa08c6d927aa01337e19605c8a │ │ │ ├── auto_sortmerge_join_11-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_11-10-5cba470fbd02e730781a3b63fd9aa3e2 │ │ │ ├── auto_sortmerge_join_11-11-337e909605c780d00ad8895686defa06 │ │ │ ├── auto_sortmerge_join_11-12-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_11-13-398b81a1928284f29e832838ec3764fd │ │ │ ├── auto_sortmerge_join_11-14-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_11-15-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_11-16-c23ea191ee4d60c0a6252ce763b1beed │ │ │ ├── auto_sortmerge_join_11-17-442e69416faaea9309bb8c2a3eb73ef │ │ │ ├── auto_sortmerge_join_11-18-d8260daa82c8439e0c80a63998bd5d2e │ │ │ ├── auto_sortmerge_join_11-19-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_11-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_11-20-62fab16c00f510c001f146c929360c71 │ │ │ ├── auto_sortmerge_join_11-21-c4d55c247c9326f474d89b29b81d60aa │ │ │ ├── auto_sortmerge_join_11-3-b4a6a67ac771394140ed695810930ac6 │ │ │ ├── auto_sortmerge_join_11-4-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_11-5-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_11-6-e44aff8a860cf3965752d3e1ce725cde │ │ │ ├── auto_sortmerge_join_11-7-ae582a255a02d91674aab500aee79e20 │ │ │ ├── auto_sortmerge_join_11-8-962264967269db1d5f28a9a6c60dbf1 │ │ │ ├── auto_sortmerge_join_11-9-10b03ce2526bf180faaec9310cfab290 │ │ │ ├── auto_sortmerge_join_12-0-d7af66a0aa504ad44bf01d5a2e7cdcec │ │ │ ├── auto_sortmerge_join_12-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_12-10-5cba470fbd02e730781a3b63fd9aa3e2 │ │ │ ├── auto_sortmerge_join_12-11-337e909605c780d00ad8895686defa06 │ │ │ ├── auto_sortmerge_join_12-12-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_12-13-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_12-14-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_12-15-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_12-16-746f0c0dd71cd5cb6673fbd53ef05a1e │ │ │ ├── auto_sortmerge_join_12-17-97ba394ab6aad2547f399ebbf757a4b6 │ │ │ ├── auto_sortmerge_join_12-18-73ee2d7b62e2aede20ca5de577cd7b7f │ │ │ ├── auto_sortmerge_join_12-19-5fb8b113a91fbdb15eb35fe1a1d1b4f │ │ │ ├── auto_sortmerge_join_12-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_12-20-3404f0b912c898d6c81aa88bf0cd8c11 │ │ │ ├── auto_sortmerge_join_12-21-4ecd65f0e26e981b66770b3e91e128fc │ │ │ ├── auto_sortmerge_join_12-3-18bd222285d3a3bd71d3cfa217d9b1db │ │ │ ├── auto_sortmerge_join_12-4-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_12-5-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_12-6-e44aff8a860cf3965752d3e1ce725cde │ │ │ ├── auto_sortmerge_join_12-7-ae582a255a02d91674aab500aee79e20 │ │ │ ├── auto_sortmerge_join_12-8-962264967269db1d5f28a9a6c60dbf1 │ │ │ ├── auto_sortmerge_join_12-9-10b03ce2526bf180faaec9310cfab290 │ │ │ ├── auto_sortmerge_join_13-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_sortmerge_join_13-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_sortmerge_join_13-10-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── auto_sortmerge_join_13-11-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_13-12-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_13-13-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_13-14-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_13-15-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_13-16-14ad1ec6ac3dbedb29d43cf178fa8552 │ │ │ ├── auto_sortmerge_join_13-17-b366dcf84021a7dc4a17a52fe381b5f0 │ │ │ ├── auto_sortmerge_join_13-18-cc27d771c9a20d3d83f87802e1a9dbe2 │ │ │ ├── auto_sortmerge_join_13-19-4b2ac2865384fbca7f374191d8021d51 │ │ │ ├── auto_sortmerge_join_13-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_sortmerge_join_13-20-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── auto_sortmerge_join_13-21-ea23403b9eb55e8b06d1c198e439569f │ │ │ ├── auto_sortmerge_join_13-22-14ad1ec6ac3dbedb29d43cf178fa8552 │ │ │ ├── auto_sortmerge_join_13-23-b366dcf84021a7dc4a17a52fe381b5f0 │ │ │ ├── auto_sortmerge_join_13-24-cc27d771c9a20d3d83f87802e1a9dbe2 │ │ │ ├── auto_sortmerge_join_13-25-4b2ac2865384fbca7f374191d8021d51 │ │ │ ├── auto_sortmerge_join_13-26-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_13-27-14ad1ec6ac3dbedb29d43cf178fa8552 │ │ │ ├── auto_sortmerge_join_13-28-b366dcf84021a7dc4a17a52fe381b5f0 │ │ │ ├── auto_sortmerge_join_13-29-cc27d771c9a20d3d83f87802e1a9dbe2 │ │ │ ├── auto_sortmerge_join_13-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_sortmerge_join_13-30-4b2ac2865384fbca7f374191d8021d51 │ │ │ ├── auto_sortmerge_join_13-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_sortmerge_join_13-5-d73046d4785e9c89acb10eea77d32ca8 │ │ │ ├── auto_sortmerge_join_13-6-3d02238197b076b6f77daacb81aa2cb4 │ │ │ ├── auto_sortmerge_join_13-7-6f949602369ac3af6ded9884bc525310 │ │ │ ├── auto_sortmerge_join_13-8-b334c03af5acdcb136072bb427683bb │ │ │ ├── auto_sortmerge_join_13-9-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── auto_sortmerge_join_14-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_sortmerge_join_14-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_sortmerge_join_14-10-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_14-11-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_14-12-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_14-13-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_14-14-51e4c81f56c64f6aa25322055694f641 │ │ │ ├── auto_sortmerge_join_14-15-43ad2152b18d711adbdd1aeb940b662a │ │ │ ├── auto_sortmerge_join_14-16-51ee88184cbc22b5bef4e96856e41e7c │ │ │ ├── auto_sortmerge_join_14-17-334529f1a720bfb408efee90bc8be61 │ │ │ ├── auto_sortmerge_join_14-18-a16ff76d72ad428fb9d43ab910f259fd │ │ │ ├── auto_sortmerge_join_14-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_sortmerge_join_14-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_sortmerge_join_14-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_sortmerge_join_14-5-945b37381c2719e18e2945bf8b4e56ac │ │ │ ├── auto_sortmerge_join_14-6-3d02238197b076b6f77daacb81aa2cb4 │ │ │ ├── auto_sortmerge_join_14-7-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── auto_sortmerge_join_14-8-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── auto_sortmerge_join_14-9-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_15-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_sortmerge_join_15-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_sortmerge_join_15-10-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_15-11-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_15-12-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_15-13-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_15-14-62b7e43463386c11e031cf7e4f584a53 │ │ │ ├── auto_sortmerge_join_15-15-3c37a21813ee34d4d1f9e01f5f3ef5d3 │ │ │ ├── auto_sortmerge_join_15-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_sortmerge_join_15-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_sortmerge_join_15-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_sortmerge_join_15-5-945b37381c2719e18e2945bf8b4e56ac │ │ │ ├── auto_sortmerge_join_15-6-3d02238197b076b6f77daacb81aa2cb4 │ │ │ ├── auto_sortmerge_join_15-7-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── auto_sortmerge_join_15-8-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── auto_sortmerge_join_15-9-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_16-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_16-1-16367c381d4b189b3640c92511244bfe │ │ │ ├── auto_sortmerge_join_16-10-4706d21b17f993cc1cc94be6b7e04c28 │ │ │ ├── auto_sortmerge_join_16-11-5e81d0b41cc58d8cc151046c7a111411 │ │ │ ├── auto_sortmerge_join_16-12-e8a77ff790bfd6740489fc4374ec6c3d │ │ │ ├── auto_sortmerge_join_16-13-920818d557d2525dabb5c539a80a1bbb │ │ │ ├── auto_sortmerge_join_16-14-455dfeeba27ecf53923db0cbf0aab908 │ │ │ ├── auto_sortmerge_join_16-15-11f98f575685beedc14a88fc47a61041 │ │ │ ├── auto_sortmerge_join_16-16-dff02d7b4c5242434d5e7449bdb67f8b │ │ │ ├── auto_sortmerge_join_16-2-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── auto_sortmerge_join_16-3-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── auto_sortmerge_join_16-4-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_16-5-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_16-6-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_16-7-7e87a31677022b6a1c360922ef74754e │ │ │ ├── auto_sortmerge_join_16-8-17d5c9dd1a25e8a54dc9c7444cbe98c │ │ │ ├── auto_sortmerge_join_16-9-ae5880516ea2f924cfbaeb919adc86e │ │ │ ├── auto_sortmerge_join_2-0-ac562e10c3d4dd7c7cce920d29cde65d │ │ │ ├── auto_sortmerge_join_2-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_2-10-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_2-11-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_2-12-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_2-13-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_2-14-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_2-15-ec410b2c54c1ce7001abe7130a3b1c21 │ │ │ ├── auto_sortmerge_join_2-16-af6016f3db000e6e180e2f3b10f120ce │ │ │ ├── auto_sortmerge_join_2-17-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_2-18-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_2-19-a0fc12fc2b968d7e85e6c1e2fd70cd94 │ │ │ ├── auto_sortmerge_join_2-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_2-20-8180638a57b64557e02815c863031755 │ │ │ ├── auto_sortmerge_join_2-21-e6283ea14d493b0d7bf390249665f289 │ │ │ ├── auto_sortmerge_join_2-22-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_2-3-aa6ec7f17b48cf49f02ab7367453ab39 │ │ │ ├── auto_sortmerge_join_2-4-66b07c93d79ed9958b8427dad16c3ef3 │ │ │ ├── auto_sortmerge_join_2-5-bfc04dda7e11f06d01689f2b57959ed7 │ │ │ ├── auto_sortmerge_join_2-6-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_2-7-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_2-8-962264967269db1d5f28a9a6c60dbf1 │ │ │ ├── auto_sortmerge_join_2-9-10b03ce2526bf180faaec9310cfab290 │ │ │ ├── auto_sortmerge_join_3-0-71378da1900d130fd68aaebc45f87313 │ │ │ ├── auto_sortmerge_join_3-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_3-10-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_3-11-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_3-12-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_3-13-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_3-14-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_3-15-30259eb1873d8f5d00dccd8af0b0ccbc │ │ │ ├── auto_sortmerge_join_3-16-a6ef74ae9c70c382abb4d361e6f1e070 │ │ │ ├── auto_sortmerge_join_3-17-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_3-18-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_3-19-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_3-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_3-20-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_3-21-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_3-22-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_3-3-47a16cf1686c81c5ba76fd92fa5e05a1 │ │ │ ├── auto_sortmerge_join_3-4-45b63361c1e5178b69a1531b238c8460 │ │ │ ├── auto_sortmerge_join_3-5-18bd222285d3a3bd71d3cfa217d9b1db │ │ │ ├── auto_sortmerge_join_3-6-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_3-7-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_3-8-e44aff8a860cf3965752d3e1ce725cde │ │ │ ├── auto_sortmerge_join_3-9-ae582a255a02d91674aab500aee79e20 │ │ │ ├── auto_sortmerge_join_4-0-1528e7173b91cd90f101ca27f51d963c │ │ │ ├── auto_sortmerge_join_4-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_4-10-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_4-11-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_4-12-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_4-13-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_4-14-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_4-15-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_4-16-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_4-17-b1607a2f1e7da8ac0a9a035b99f81d28 │ │ │ ├── auto_sortmerge_join_4-18-a6ef74ae9c70c382abb4d361e6f1e070 │ │ │ ├── auto_sortmerge_join_4-19-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_4-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_4-20-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_4-21-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_4-22-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_4-23-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_4-24-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_4-3-aa6ec7f17b48cf49f02ab7367453ab39 │ │ │ ├── auto_sortmerge_join_4-4-66b07c93d79ed9958b8427dad16c3ef3 │ │ │ ├── auto_sortmerge_join_4-5-47a16cf1686c81c5ba76fd92fa5e05a1 │ │ │ ├── auto_sortmerge_join_4-6-45b63361c1e5178b69a1531b238c8460 │ │ │ ├── auto_sortmerge_join_4-7-ecca12a2f377c18c53563a534e9dd5a5 │ │ │ ├── auto_sortmerge_join_4-8-65930e1b01da720cf296ca3df668b58d │ │ │ ├── auto_sortmerge_join_4-9-bfc04dda7e11f06d01689f2b57959ed7 │ │ │ ├── auto_sortmerge_join_5-0-9f8764dddb7b106f879d1a7c4318310d │ │ │ ├── auto_sortmerge_join_5-1-fdbb11a2de2777dfdd916b59764d5c8e │ │ │ ├── auto_sortmerge_join_5-10-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_5-11-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_5-12-b1607a2f1e7da8ac0a9a035b99f81d28 │ │ │ ├── auto_sortmerge_join_5-13-a6ef74ae9c70c382abb4d361e6f1e070 │ │ │ ├── auto_sortmerge_join_5-14-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_5-15-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_5-16-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_5-17-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_5-18-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_5-19-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_5-2-4f56cb50ec6c5cc57974f85d54bcc8ed │ │ │ ├── auto_sortmerge_join_5-20-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_5-3-9878d6ab0fe143611c88ffc0602197e3 │ │ │ ├── auto_sortmerge_join_5-4-a576657b9fd1c23aed85a7409887b2fb │ │ │ ├── auto_sortmerge_join_5-5-ce5ee903a36a074293fa509149d94447 │ │ │ ├── auto_sortmerge_join_5-6-350b202868590b5edaed18007fd5cbbe │ │ │ ├── auto_sortmerge_join_5-7-1155788c7c133a73c3609e8052accfa5 │ │ │ ├── auto_sortmerge_join_5-8-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_5-9-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_6-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_sortmerge_join_6-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_sortmerge_join_6-10-34779e6a90b2e9968a9a98b048cdaab6 │ │ │ ├── auto_sortmerge_join_6-11-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_6-12-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_6-13-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_6-14-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_6-15-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── auto_sortmerge_join_6-16-ea23403b9eb55e8b06d1c198e439569f │ │ │ ├── auto_sortmerge_join_6-17-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_6-18-32efb3656e05e40f9f928bbcb11d010 │ │ │ ├── auto_sortmerge_join_6-19-cf41f7ce9478536e823107d1810ff1d7 │ │ │ ├── auto_sortmerge_join_6-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_sortmerge_join_6-20-b23f9ec74e58e5c53417bfff6794e8fd │ │ │ ├── auto_sortmerge_join_6-21-b55506a213ec710004e6d7f3462834d0 │ │ │ ├── auto_sortmerge_join_6-22-4b066e39be51ea19a1790c1287ad0d2c │ │ │ ├── auto_sortmerge_join_6-23-4281442c87dcf6007f8bd42504eba186 │ │ │ ├── auto_sortmerge_join_6-24-12ec3636a4c62fd56b40da2979f53f5f │ │ │ ├── auto_sortmerge_join_6-25-52f0e65724d29e2b4054b59a50d2837b │ │ │ ├── auto_sortmerge_join_6-26-bf7478a041a164ef219964cb865aa63b │ │ │ ├── auto_sortmerge_join_6-27-961f141836f2cc9521f681cadbc3d140 │ │ │ ├── auto_sortmerge_join_6-28-171974ff7145ffc85c8ba2724ef1f31 │ │ │ ├── auto_sortmerge_join_6-29-fd0cc412e0987569a4ed879454b53fb0 │ │ │ ├── auto_sortmerge_join_6-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_sortmerge_join_6-30-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_6-31-940f423a57afd2734f62d93bcd4d7caf │ │ │ ├── auto_sortmerge_join_6-32-cf41f7ce9478536e823107d1810ff1d7 │ │ │ ├── auto_sortmerge_join_6-33-12ec3636a4c62fd56b40da2979f53f5f │ │ │ ├── auto_sortmerge_join_6-34-52f0e65724d29e2b4054b59a50d2837b │ │ │ ├── auto_sortmerge_join_6-35-bf7478a041a164ef219964cb865aa63b │ │ │ ├── auto_sortmerge_join_6-36-961f141836f2cc9521f681cadbc3d140 │ │ │ ├── auto_sortmerge_join_6-37-171974ff7145ffc85c8ba2724ef1f31 │ │ │ ├── auto_sortmerge_join_6-38-fd0cc412e0987569a4ed879454b53fb0 │ │ │ ├── auto_sortmerge_join_6-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_sortmerge_join_6-5-612f97716b8efe4b659206938e5ea5f2 │ │ │ ├── auto_sortmerge_join_6-6-64856231335fc5fec61c3fd3aceefcc4 │ │ │ ├── auto_sortmerge_join_6-7-b34c9b18481df043912e910ed3a5f149 │ │ │ ├── auto_sortmerge_join_6-8-57e68163453d4632ef740ce1223f44d1 │ │ │ ├── auto_sortmerge_join_6-9-36d2a698f88e53ab2a66e8baa980299b │ │ │ ├── auto_sortmerge_join_7-0-fa10661c7e8791fb319ade49f3cca50 │ │ │ ├── auto_sortmerge_join_7-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_7-10-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_7-11-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_7-12-962264967269db1d5f28a9a6c60dbf1 │ │ │ ├── auto_sortmerge_join_7-13-10b03ce2526bf180faaec9310cfab290 │ │ │ ├── auto_sortmerge_join_7-14-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_7-15-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_7-16-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_7-17-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_7-18-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_7-19-b1607a2f1e7da8ac0a9a035b99f81d28 │ │ │ ├── auto_sortmerge_join_7-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_7-20-a6ef74ae9c70c382abb4d361e6f1e070 │ │ │ ├── auto_sortmerge_join_7-21-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_7-22-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_7-23-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_7-24-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_7-25-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_7-26-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_7-3-aa6ec7f17b48cf49f02ab7367453ab39 │ │ │ ├── auto_sortmerge_join_7-4-66b07c93d79ed9958b8427dad16c3ef3 │ │ │ ├── auto_sortmerge_join_7-5-47a16cf1686c81c5ba76fd92fa5e05a1 │ │ │ ├── auto_sortmerge_join_7-6-45b63361c1e5178b69a1531b238c8460 │ │ │ ├── auto_sortmerge_join_7-7-ecca12a2f377c18c53563a534e9dd5a5 │ │ │ ├── auto_sortmerge_join_7-8-65930e1b01da720cf296ca3df668b58d │ │ │ ├── auto_sortmerge_join_7-9-bfc04dda7e11f06d01689f2b57959ed7 │ │ │ ├── auto_sortmerge_join_8-0-42977c556a54aaaee9d1e59a6dcc06aa │ │ │ ├── auto_sortmerge_join_8-1-4e24a5c0c67a137478e4a8be2a081872 │ │ │ ├── auto_sortmerge_join_8-10-962264967269db1d5f28a9a6c60dbf1 │ │ │ ├── auto_sortmerge_join_8-11-10b03ce2526bf180faaec9310cfab290 │ │ │ ├── auto_sortmerge_join_8-12-5cba470fbd02e730781a3b63fd9aa3e2 │ │ │ ├── auto_sortmerge_join_8-13-337e909605c780d00ad8895686defa06 │ │ │ ├── auto_sortmerge_join_8-14-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_8-15-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_8-16-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_8-17-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── auto_sortmerge_join_8-18-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_8-19-30259eb1873d8f5d00dccd8af0b0ccbc │ │ │ ├── auto_sortmerge_join_8-2-f42438f3f5c266b997686ba846420ebe │ │ │ ├── auto_sortmerge_join_8-20-a6ef74ae9c70c382abb4d361e6f1e070 │ │ │ ├── auto_sortmerge_join_8-21-325432a220aa3ebe8b816069916924d8 │ │ │ ├── auto_sortmerge_join_8-22-6f2f1144ab2b8b12684f3fbc55e27bf7 │ │ │ ├── auto_sortmerge_join_8-23-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_8-24-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_8-25-a0fc12fc2b968d7e85e6c1e2fd70cd94 │ │ │ ├── auto_sortmerge_join_8-26-8180638a57b64557e02815c863031755 │ │ │ ├── auto_sortmerge_join_8-27-e6283ea14d493b0d7bf390249665f289 │ │ │ ├── auto_sortmerge_join_8-28-7d0c37fc09323ce11aae0b58dc687660 │ │ │ ├── auto_sortmerge_join_8-3-47a16cf1686c81c5ba76fd92fa5e05a1 │ │ │ ├── auto_sortmerge_join_8-4-45b63361c1e5178b69a1531b238c8460 │ │ │ ├── auto_sortmerge_join_8-5-18bd222285d3a3bd71d3cfa217d9b1db │ │ │ ├── auto_sortmerge_join_8-6-9e58f8a961723c40a5d1f742251a8fa5 │ │ │ ├── auto_sortmerge_join_8-7-d964114ed76536c8e3cacd231340851c │ │ │ ├── auto_sortmerge_join_8-8-e44aff8a860cf3965752d3e1ce725cde │ │ │ ├── auto_sortmerge_join_8-9-ae582a255a02d91674aab500aee79e20 │ │ │ ├── auto_sortmerge_join_9-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── auto_sortmerge_join_9-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── auto_sortmerge_join_9-10-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── auto_sortmerge_join_9-11-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── auto_sortmerge_join_9-12-906a582602602372e1d4776243abeab5 │ │ │ ├── auto_sortmerge_join_9-13-94538bc7322522a5534cafc0551d2189 │ │ │ ├── auto_sortmerge_join_9-14-133023474337f2cdc53ee82ffeb1c13e │ │ │ ├── auto_sortmerge_join_9-15-63261d35ddda973eeeb97b994ab7a476 │ │ │ ├── auto_sortmerge_join_9-16-1d603e61c2cb888499504ddab98ccc65 │ │ │ ├── auto_sortmerge_join_9-17-d5183dfa8d9fb9175478fb1c2f2edb97 │ │ │ ├── auto_sortmerge_join_9-18-758d5532083d6279e169b54fd69bb580 │ │ │ ├── auto_sortmerge_join_9-19-2798f20aaf0fe5505c34b118e4b10bc5 │ │ │ ├── auto_sortmerge_join_9-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── auto_sortmerge_join_9-20-ca77b5fb54de526972c16ad6118e86d6 │ │ │ ├── auto_sortmerge_join_9-21-21269869cd3aaf4ade2170d9017de018 │ │ │ ├── auto_sortmerge_join_9-22-853c4fa5a2385b92fdb39d0ac2926973 │ │ │ ├── auto_sortmerge_join_9-23-4e0e8cd0626a84b21ca7d2f633623578 │ │ │ ├── auto_sortmerge_join_9-24-e210ced77b32cd7ce87044bb3e3370d1 │ │ │ ├── auto_sortmerge_join_9-25-2fe7b834b341bf18e36cd79dd00ec16a │ │ │ ├── auto_sortmerge_join_9-26-63d105e0acd3521bb29ba8cec9ac4583 │ │ │ ├── auto_sortmerge_join_9-27-43ba2c72db9db1ec18d835ec978f8da1 │ │ │ ├── auto_sortmerge_join_9-28-5965c5c6ef08240eb27eb9620cc2338 │ │ │ ├── auto_sortmerge_join_9-29-b66c416fdd98d76981f19e9c14b6a562 │ │ │ ├── auto_sortmerge_join_9-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── auto_sortmerge_join_9-30-4376bdd8412f94fe184d46481fee345d │ │ │ ├── auto_sortmerge_join_9-31-b889b147255231f7fe44bd57e1f8ba66 │ │ │ ├── auto_sortmerge_join_9-32-c5c3668b2434a5b90f308ca4bbdcd647 │ │ │ ├── auto_sortmerge_join_9-33-aa8d713ad4e19b72b5bd7628d60c295e │ │ │ ├── auto_sortmerge_join_9-34-ff6eca271c60cb15a3ea2395ac737b0d │ │ │ ├── auto_sortmerge_join_9-35-b9d66e78b8898a97a42d1118300fa0ce │ │ │ ├── auto_sortmerge_join_9-36-d25f41c6f7c20044ed4d9a9905fdfcce │ │ │ ├── auto_sortmerge_join_9-37-b0ca9e20cd48457e6cf1c313d5505213 │ │ │ ├── auto_sortmerge_join_9-38-f135547e33c01d1f543c8b1349d60348 │ │ │ ├── auto_sortmerge_join_9-39-906a582602602372e1d4776243abeab5 │ │ │ ├── auto_sortmerge_join_9-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── auto_sortmerge_join_9-40-94538bc7322522a5534cafc0551d2189 │ │ │ ├── auto_sortmerge_join_9-41-133023474337f2cdc53ee82ffeb1c13e │ │ │ ├── auto_sortmerge_join_9-42-63261d35ddda973eeeb97b994ab7a476 │ │ │ ├── auto_sortmerge_join_9-43-1d603e61c2cb888499504ddab98ccc65 │ │ │ ├── auto_sortmerge_join_9-44-d5183dfa8d9fb9175478fb1c2f2edb97 │ │ │ ├── auto_sortmerge_join_9-45-758d5532083d6279e169b54fd69bb580 │ │ │ ├── auto_sortmerge_join_9-46-2798f20aaf0fe5505c34b118e4b10bc5 │ │ │ ├── auto_sortmerge_join_9-47-ca77b5fb54de526972c16ad6118e86d6 │ │ │ ├── auto_sortmerge_join_9-48-21269869cd3aaf4ade2170d9017de018 │ │ │ ├── auto_sortmerge_join_9-49-853c4fa5a2385b92fdb39d0ac2926973 │ │ │ ├── auto_sortmerge_join_9-5-9140b367b5680860f4c7c0238377583f │ │ │ ├── auto_sortmerge_join_9-50-4e0e8cd0626a84b21ca7d2f633623578 │ │ │ ├── auto_sortmerge_join_9-51-e210ced77b32cd7ce87044bb3e3370d1 │ │ │ ├── auto_sortmerge_join_9-52-2fe7b834b341bf18e36cd79dd00ec16a │ │ │ ├── auto_sortmerge_join_9-53-63d105e0acd3521bb29ba8cec9ac4583 │ │ │ ├── auto_sortmerge_join_9-54-43ba2c72db9db1ec18d835ec978f8da1 │ │ │ ├── auto_sortmerge_join_9-55-4376bdd8412f94fe184d46481fee345d │ │ │ ├── auto_sortmerge_join_9-56-b889b147255231f7fe44bd57e1f8ba66 │ │ │ ├── auto_sortmerge_join_9-57-c5c3668b2434a5b90f308ca4bbdcd647 │ │ │ ├── auto_sortmerge_join_9-58-aa8d713ad4e19b72b5bd7628d60c295e │ │ │ ├── auto_sortmerge_join_9-59-ff6eca271c60cb15a3ea2395ac737b0d │ │ │ ├── auto_sortmerge_join_9-6-70c1d66123d434d3a1e1801e0b19bc3f │ │ │ ├── auto_sortmerge_join_9-60-b9d66e78b8898a97a42d1118300fa0ce │ │ │ ├── auto_sortmerge_join_9-61-d25f41c6f7c20044ed4d9a9905fdfcce │ │ │ ├── auto_sortmerge_join_9-62-b0ca9e20cd48457e6cf1c313d5505213 │ │ │ ├── auto_sortmerge_join_9-7-24ca942f094b14b92086305cc125e833 │ │ │ ├── auto_sortmerge_join_9-8-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── auto_sortmerge_join_9-9-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── ba_table_udfs-0-7a9e67189d3d4151f23b12c22bde06b5 │ │ │ ├── ba_table_udfs-1-3baac4c47f9cb2895f01bcfccd5f904b │ │ │ ├── between-0-570e4c4bf2968368ac2f325c6c940a06 │ │ │ ├── binary_constant-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── binary_constant-1-604fde0397444c5c9f1d70e6287de664 │ │ │ ├── binarysortable_1-0-3562c2ed956a59cc98362d2f64e19ce1 │ │ │ ├── binarysortable_1-1-aca7ae366662c9698b5d2c01a6cb3948 │ │ │ ├── binarysortable_1-2-faa8d95365e4116734a056c911350c05 │ │ │ ├── binarysortable_1-3-d6518380547e7eef338886f3bdc7bdd2 │ │ │ ├── boolean = number-0-6b6975fa1892cc48edd87dc0df48a7c0 │ │ │ ├── case else null-0-8ef2f741400830ef889a9dd0c817fe3d │ │ │ ├── case sensitivity when query Hive table-0-5d14d21a239daa42b086cc895215009a │ │ │ ├── case statements WITHOUT key #1-0-36750f0f6727c287c471309689ff7563 │ │ │ ├── case statements WITHOUT key #2-0-e3a2b981ebff7e273537dd6c43ece0c0 │ │ │ ├── case statements WITHOUT key #3-0-be5efc0574a97ec465e2686f4a724bd5 │ │ │ ├── case statements WITHOUT key #4-0-631f824a91b7230657bea7a05e393a1e │ │ │ ├── case statements with key #1-0-616830b2011da0990e87a188fb609299 │ │ │ ├── case statements with key #2-0-6c5b5a997949f9e5ab9676b60e95657b │ │ │ ├── case statements with key #3-0-a241862582c47d9e98be95339d35c7c4 │ │ │ ├── case statements with key #4-0-ea87ca38ead8858d2337792dcd430226 │ │ │ ├── case when then 1 else null end -0-f7c7fdd35c084bc797890aa08d33693c │ │ │ ├── case when then 1.0 else null end -0-cf71a4c4cce08635cc80a64a1ae6bc83 │ │ │ ├── case when then 1L else null end -0-763ae85e7a52b4cf4162d6a8931716bb │ │ │ ├── case when then 1S else null end -0-6f5f3b3dbe9f1d1eb98443aef315b982 │ │ │ ├── case when then 1Y else null end -0-589982a400d86157791c7216b10b6b5d │ │ │ ├── case when then null else 1 end -0-48bd83660cf3ba93cdbdc24559092171 │ │ │ ├── case when then null else 1.0 end -0-dfc876530eeaa7c42978d1bc0b1fd58 │ │ │ ├── case when then null else 1L end -0-a7f1305ea4f86e596c368e35e45cc4e5 │ │ │ ├── case when then null else 1S end -0-dfb61969e6cb6e6dbe89225b538c8d98 │ │ │ ├── case when then null else 1Y end -0-7f4c32299c3738739b678ece62752a7b │ │ │ ├── cast1-0-b0e8966b7c06be9e044ed30b487d0661 │ │ │ ├── cast1-1-1ee16b8209701131017533cfa6eb4680 │ │ │ ├── cast1-2-3fe73e7435e30b37266ef6a33537dc4c │ │ │ ├── cast1-3-18dc2ce8a8b2486d268bceef63aa0c2a │ │ │ ├── char_varchar_udf-0-4de1b2fa0908a3d856474aae2bc38c08 │ │ │ ├── char_varchar_udf-1-5b1e7c580ed5e756d30a4c557af8902 │ │ │ ├── char_varchar_udf-2-880ce74a83bb2bfb9c9bd584b8874ac │ │ │ ├── cluster-0-16681f9c2bdd44278817d72c138b6ee1 │ │ │ ├── cluster-1-707a2295731e0d631a6c5f71c745c8d5 │ │ │ ├── cluster-10-bba339a22907c06d1d01ba9cd7ea8f5 │ │ │ ├── cluster-11-dcf78a6537ba2b4d4b828a9a27cf545e │ │ │ ├── cluster-12-6ad920e2ae83c78fccb06ff65308a438 │ │ │ ├── cluster-13-12635b4b7f34eba5554d5b892b5b64e7 │ │ │ ├── cluster-14-cd2e125bceb1611137f0750f5d69c475 │ │ │ ├── cluster-15-b4c15c85c18f310f1b5bc56a78ad94b0 │ │ │ ├── cluster-16-a2d5e5ec2504041ea1a62856c7086451 │ │ │ ├── cluster-17-62979aa9e6b4e6ffb44ec452aabbef65 │ │ │ ├── cluster-18-e01f450969ae7e1cd018e6ef0cc67141 │ │ │ ├── cluster-19-e5284c7a7c36ee55740bd127ef4bf8c7 │ │ │ ├── cluster-2-50197277eb03ad20696a135bd7d18de7 │ │ │ ├── cluster-20-294891c1d956245540a80aa800ba393d │ │ │ ├── cluster-21-4787b258a786cf195bcb59cd90f6013f │ │ │ ├── cluster-22-8801aa93cf6dba7e13e99a0260fde68 │ │ │ ├── cluster-23-b66ed6ead4deecd49f0f67de1f2bab2e │ │ │ ├── cluster-24-f492a7f78faf180621e83e5a69aa1eae │ │ │ ├── cluster-25-f57ce48b6a6e671b58c96535ab482b6a │ │ │ ├── cluster-3-530671e2a5b8983c60cfedaf486f0f0f │ │ │ ├── cluster-4-cb4af90f52f2626213f918fda3b81dfc │ │ │ ├── cluster-5-e99040f6a24c53a4c89801ff3663ff72 │ │ │ ├── cluster-6-56f8e3e7abe504522a2bfd77b5be3270 │ │ │ ├── cluster-7-a22600d60c81a25061b1e20b6726c691 │ │ │ ├── cluster-8-251b178e4fe39ea03a30d2b9bd40710d │ │ │ ├── cluster-9-cc36ac7ee5e8c6ea21b956abbc2506e2 │ │ │ ├── combine1-0-84b74227c9f1563f530cd3ac3b333e54 │ │ │ ├── combine1-1-86a409d8b868dc5f1a3bd1e04c2bc28c │ │ │ ├── combine1-2-6142f47d3fcdd4323162014d5eb35e07 │ │ │ ├── combine1-3-10266e3d5dd4c841c0d65030b1edba7c │ │ │ ├── combine1-4-9cbd6d400fb6c3cd09010e3dbd76601 │ │ │ ├── combine1-5-1ba2d6f3bb3348da3fee7fab4f283f34 │ │ │ ├── combine1-6-1d1f97cce07323812de3027920b04b75 │ │ │ ├── combine1-7-f7d8d6d0e9504b4dd2f1a557c0c69c30 │ │ │ ├── combine1-8-da1fda96db80592bf2bbda8f22b5687c │ │ │ ├── combine1-9-e5ce23369b0ad260512a0f61c6969b73 │ │ │ ├── combine2-0-7a9e67189d3d4151f23b12c22bde06b5 │ │ │ ├── combine2-1-86a409d8b868dc5f1a3bd1e04c2bc28c │ │ │ ├── combine2-10-54649f87d403c6fcb163c4d51e382d3a │ │ │ ├── combine2-11-2d2d73a929c7d995ea57b40529b74b56 │ │ │ ├── combine2-12-cd15ffd140539cf86090814729ec4748 │ │ │ ├── combine2-13-5ac3e540fd24f94fee378e49597817b3 │ │ │ ├── combine2-14-4695309eb4e91ef29c9857aa8fd6130c │ │ │ ├── combine2-15-dd652175dac4463fed3c56aded11e6c1 │ │ │ ├── combine2-16-557997716a68312e8cae75428e3ce31 │ │ │ ├── combine2-17-8e4598e3f0701478ed12042438699ce5 │ │ │ ├── combine2-18-2af7419c1d84fe155e23f3972e049b97 │ │ │ ├── combine2-2-6142f47d3fcdd4323162014d5eb35e07 │ │ │ ├── combine2-3-10266e3d5dd4c841c0d65030b1edba7c │ │ │ ├── combine2-4-9cbd6d400fb6c3cd09010e3dbd76601 │ │ │ ├── combine2-5-1ba2d6f3bb3348da3fee7fab4f283f34 │ │ │ ├── combine2-6-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── combine2-7-16367c381d4b189b3640c92511244bfe │ │ │ ├── combine2-8-99d1f07b2ce904afd6a809fd1814efe9 │ │ │ ├── combine2-9-30cb07965e4b5025545361b948fc83c2 │ │ │ ├── compute_stats_binary-0-16dcd4810ff82419cf1ae914d1860f21 │ │ │ ├── compute_stats_binary-1-44b15c6c9600109e064a5ea5f9c81051 │ │ │ ├── compute_stats_binary-2-c5a68f035051eef3e1c8d44d8b90017c │ │ │ ├── compute_stats_binary-3-bcac92c4a17678873b01779e3d0e84e3 │ │ │ ├── compute_stats_boolean-0-e39ee7d1e03efae1334a4cafc94af1d8 │ │ │ ├── compute_stats_boolean-1-72ee4bdd5cea69136940dc40e6890e1d │ │ │ ├── compute_stats_boolean-2-fbea367698de65e22d4d660a518ea95e │ │ │ ├── compute_stats_boolean-3-a14d8a5835c94829271f9f463d96d83d │ │ │ ├── compute_stats_double-0-76e8d4ba13c67a0834987b6dcd1d05ce │ │ │ ├── compute_stats_double-1-8f634b9e334fd58e71844e6283d9794d │ │ │ ├── compute_stats_double-2-8f988b757fd62f318f35447a3fd65452 │ │ │ ├── compute_stats_double-3-756f6b2d1c63fd5cb0bb25f76d5bfce2 │ │ │ ├── compute_stats_empty_table-0-12161b12442ad9b664b51e443fabaf5d │ │ │ ├── compute_stats_empty_table-1-1f720211105d9a6d611c5d378ee45ec0 │ │ │ ├── compute_stats_empty_table-2-372df408a15de1e6f05e807a3aff223f │ │ │ ├── compute_stats_empty_table-3-73f6626835884f34a47e8e78396bc25b │ │ │ ├── compute_stats_empty_table-4-7f356d57c8c6125e4083f51ed4bae5cf │ │ │ ├── compute_stats_empty_table-5-294a33b7c457eb7846335a4b1775ddc4 │ │ │ ├── compute_stats_empty_table-6-137180ebd2a072f08b5d849bdd9a464 │ │ │ ├── compute_stats_long-0-2ee7f9e4c307417d4da2660e303c07c3 │ │ │ ├── compute_stats_long-1-9313f166464633b3929707d7ef11d758 │ │ │ ├── compute_stats_long-2-71ffbc32647b3b562ccdc7e3db71e7a8 │ │ │ ├── compute_stats_long-3-cf4bb755ade3079409e2251c7cd0118d │ │ │ ├── compute_stats_string-0-3b932d28809fb8f40d81b4f8dfe2693b │ │ │ ├── compute_stats_string-1-3491ef2747a8f34899108d4ae8ebc7eb │ │ │ ├── compute_stats_string-2-b87a68ae5ffa689bada75425169d131a │ │ │ ├── compute_stats_string-3-cea908dd41c78490990ee6b681d19fc │ │ │ ├── constant array-0-761ef205b10ac4a10122c8b4ce10ada │ │ │ ├── constant null testing-0-6a01a94ef1b0d29152c88cd3083fd70b │ │ │ ├── constant object inspector for generic udf-0-638f81ad9077c7d0c5c735c6e73742ad │ │ │ ├── convert_enum_to_string-0-f22bc1aaadc6f36ba36420073ea04543 │ │ │ ├── convert_enum_to_string-1-db089ff46f9826c7883198adacdfad59 │ │ │ ├── correlationoptimizer1-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer1-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-10-5d712a42dcc1c4f7c797dabda5eb7b3a │ │ │ ├── correlationoptimizer1-11-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer1-12-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-13-f9f839aedb3a350719c0cbc53a06ace5 │ │ │ ├── correlationoptimizer1-14-dae4256e08d595317f8e09a56354a3d9 │ │ │ ├── correlationoptimizer1-15-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-16-43f356b36962f2bade5706d8cf5ae6b4 │ │ │ ├── correlationoptimizer1-17-dae4256e08d595317f8e09a56354a3d9 │ │ │ ├── correlationoptimizer1-18-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer1-19-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-2-42a0eedc3751f792ad5438b2c64d3897 │ │ │ ├── correlationoptimizer1-20-b4c1e27a7c1f61a3e9ae07c80e6e2973 │ │ │ ├── correlationoptimizer1-21-16c57348be42ca3cc2f80f7f92265696 │ │ │ ├── correlationoptimizer1-22-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-23-2cdc77fd60449f3547cf95d8eb09a2 │ │ │ ├── correlationoptimizer1-24-16c57348be42ca3cc2f80f7f92265696 │ │ │ ├── correlationoptimizer1-25-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-26-5522db58d123d1bec48b6e71c1b258f3 │ │ │ ├── correlationoptimizer1-27-d31433f229e853e8b8440b4ddc63c80e │ │ │ ├── correlationoptimizer1-28-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-29-941ecfef9448ecff56cc16bcfb233ee4 │ │ │ ├── correlationoptimizer1-3-5d712a42dcc1c4f7c797dabda5eb7b3a │ │ │ ├── correlationoptimizer1-30-d31433f229e853e8b8440b4ddc63c80e │ │ │ ├── correlationoptimizer1-31-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-32-76aad6bc7d7e4a28c33aca1f0ba30e65 │ │ │ ├── correlationoptimizer1-33-7722bcc896718b584f78cecdab1fdc9f │ │ │ ├── correlationoptimizer1-34-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-35-e1d4857548e626bb31d70c096b8d0a95 │ │ │ ├── correlationoptimizer1-36-7722bcc896718b584f78cecdab1fdc9f │ │ │ ├── correlationoptimizer1-37-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-38-ef6502d6b282c8a6d228bba395b24724 │ │ │ ├── correlationoptimizer1-39-ea87e76dba02a46cb958148333e397b7 │ │ │ ├── correlationoptimizer1-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-40-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-41-b79b220859c09354e23b533c105ccbab │ │ │ ├── correlationoptimizer1-42-ea87e76dba02a46cb958148333e397b7 │ │ │ ├── correlationoptimizer1-43-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-44-638e5300f4c892c2bf27bd91a8f81b64 │ │ │ ├── correlationoptimizer1-45-66010469a9cdb66851da9a727ef9fdad │ │ │ ├── correlationoptimizer1-46-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-47-3514c74c7f68f2d70cc6d51ac46c20 │ │ │ ├── correlationoptimizer1-48-66010469a9cdb66851da9a727ef9fdad │ │ │ ├── correlationoptimizer1-49-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-5-a1c80c68b9a7597096c2580c3766f7f7 │ │ │ ├── correlationoptimizer1-50-7490df6719cd7e47aa08dbcbc3266a92 │ │ │ ├── correlationoptimizer1-51-e71195e7d9f557e2abc7f03462d22dba │ │ │ ├── correlationoptimizer1-52-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-53-73da9fe2b0c2ee26c021ec3f2fa27272 │ │ │ ├── correlationoptimizer1-54-e71195e7d9f557e2abc7f03462d22dba │ │ │ ├── correlationoptimizer1-55-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer1-56-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-57-fcf9bcb522f542637ccdea863b408448 │ │ │ ├── correlationoptimizer1-58-3070366869308907e54797927805603 │ │ │ ├── correlationoptimizer1-59-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-6-5d712a42dcc1c4f7c797dabda5eb7b3a │ │ │ ├── correlationoptimizer1-60-dad56e1f06c808b29e5dc8fb0c49efb2 │ │ │ ├── correlationoptimizer1-61-3070366869308907e54797927805603 │ │ │ ├── correlationoptimizer1-62-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer1-63-3cd3fbbbd8ee5c274fe3d6a45126cef4 │ │ │ ├── correlationoptimizer1-64-a6bba6d9b422adb386b35c62cecb548 │ │ │ ├── correlationoptimizer1-65-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-66-d6bbaf0d40010159095e4cac025c50c5 │ │ │ ├── correlationoptimizer1-67-a6bba6d9b422adb386b35c62cecb548 │ │ │ ├── correlationoptimizer1-7-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer1-8-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer1-9-d5bea91b4edb8be0428a336ff9c21dde │ │ │ ├── correlationoptimizer10-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer10-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer10-10-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer10-11-a1b7af95dfd01783c07aa23208d6160 │ │ │ ├── correlationoptimizer10-12-1322cff0bdf29aab32e638ad48c71ff9 │ │ │ ├── correlationoptimizer10-13-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer10-14-934b668c11600dc9c013c2ddc4c0d68c │ │ │ ├── correlationoptimizer10-15-430ff20a144fb3dbf526232d9cb2baa │ │ │ ├── correlationoptimizer10-16-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer10-17-9d5521ecef1353d23fd2d4f7d78e7006 │ │ │ ├── correlationoptimizer10-18-430ff20a144fb3dbf526232d9cb2baa │ │ │ ├── correlationoptimizer10-2-f9de06a4184ab1f42793327c1497437 │ │ │ ├── correlationoptimizer10-3-6a01aa7ca94cda4268af894b4fd852ea │ │ │ ├── correlationoptimizer10-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer10-5-6f191930802d659058465b2e6de08dd3 │ │ │ ├── correlationoptimizer10-6-6a01aa7ca94cda4268af894b4fd852ea │ │ │ ├── correlationoptimizer10-7-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer10-8-b2c8d0056b9f1b41cdaeaab4a1a5c9ec │ │ │ ├── correlationoptimizer10-9-1322cff0bdf29aab32e638ad48c71ff9 │ │ │ ├── correlationoptimizer11-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer11-1-3a7f180f26dd2aec3ceab769f0cd965 │ │ │ ├── correlationoptimizer11-10-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer11-11-f7918ee4d4941d3272e0262a750de700 │ │ │ ├── correlationoptimizer11-12-5cefedc27b914d45b1512c92ad36c6e4 │ │ │ ├── correlationoptimizer11-13-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer11-14-c16dc98e6fc3e9ea52f7f3ca04ad953d │ │ │ ├── correlationoptimizer11-15-5cefedc27b914d45b1512c92ad36c6e4 │ │ │ ├── correlationoptimizer11-2-e148026f8994e22ca756c68753a0cc26 │ │ │ ├── correlationoptimizer11-3-b04195464e014cb47fd20a76b5f9ac0 │ │ │ ├── correlationoptimizer11-4-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer11-5-88d8dfbff4269af34724bf30ff4fec34 │ │ │ ├── correlationoptimizer11-6-fce66bdc5987a642f8f93471e62c1748 │ │ │ ├── correlationoptimizer11-7-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer11-8-45d4d690886288ef04addbb659397ad1 │ │ │ ├── correlationoptimizer11-9-fce66bdc5987a642f8f93471e62c1748 │ │ │ ├── correlationoptimizer13-0-efd135a811fa94760736a761d220b82 │ │ │ ├── correlationoptimizer13-1-32a82500cc28465fac6f64dde0c431c6 │ │ │ ├── correlationoptimizer13-2-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer13-3-bb61d9292434f37bd386e5bff683764d │ │ │ ├── correlationoptimizer14-0-aa047b3a8b40b68b93c4ad11e173c767 │ │ │ ├── correlationoptimizer14-1-d0a93f40892e3894460553b443c77428 │ │ │ ├── correlationoptimizer14-10-a837e66f8c37cc3b2f6d3596b03a6eda │ │ │ ├── correlationoptimizer14-11-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer14-12-99f81dd0f33197c724eb58398542ff22 │ │ │ ├── correlationoptimizer14-13-5e19a84c0c3ede17b8d9685a22f0a1e6 │ │ │ ├── correlationoptimizer14-14-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer14-15-78fed7defb6154e01abbd97a0741adf │ │ │ ├── correlationoptimizer14-16-7ebe26e8a3620830e824b4099519395 │ │ │ ├── correlationoptimizer14-17-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer14-18-aa18035e1d8fdcedb91b76f9a32b11 │ │ │ ├── correlationoptimizer14-19-7ebe26e8a3620830e824b4099519395 │ │ │ ├── correlationoptimizer14-2-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer14-20-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer14-21-e85444100b2e0c71b3d792e4bf1486d1 │ │ │ ├── correlationoptimizer14-22-aeed9fe2c3ffdf99eba2821ecfa18242 │ │ │ ├── correlationoptimizer14-23-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer14-24-8e88fd43a2c216b3409bee768425772c │ │ │ ├── correlationoptimizer14-25-aeed9fe2c3ffdf99eba2821ecfa18242 │ │ │ ├── correlationoptimizer14-3-88b3974a7639097ed915402827e8941f │ │ │ ├── correlationoptimizer14-4-f58c909a1cbcbca3ea64bada41b0a18f │ │ │ ├── correlationoptimizer14-5-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer14-6-dcc6819f5848ff3d68b1d28c8787d41c │ │ │ ├── correlationoptimizer14-7-a837e66f8c37cc3b2f6d3596b03a6eda │ │ │ ├── correlationoptimizer14-8-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer14-9-e5f8709d75fbe813609cbdc8ed707489 │ │ │ ├── correlationoptimizer15-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer15-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer15-2-f3001b5ee3fe7b9b01c82b0c79c2df02 │ │ │ ├── correlationoptimizer15-3-e149747103059314a9984235702b24b6 │ │ │ ├── correlationoptimizer15-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer15-5-9914f44ecb6ae7587b62e5349ff60d04 │ │ │ ├── correlationoptimizer15-6-3bc6f1aef3516fd7ba8c7527f2865dcd │ │ │ ├── correlationoptimizer15-7-e149747103059314a9984235702b24b6 │ │ │ ├── correlationoptimizer2-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer2-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer2-10-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer2-11-165752d0d250e5c9cddca50cf0c9cab │ │ │ ├── correlationoptimizer2-12-e6b368bfaea4d2838f8038b3bd29db06 │ │ │ ├── correlationoptimizer2-13-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer2-14-b8a58e660d7416485c3d9a97d610bdfd │ │ │ ├── correlationoptimizer2-15-18f10d12e8bfa473a916c2f528500538 │ │ │ ├── correlationoptimizer2-16-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer2-17-2a3e19b28e5262eb8c467e237df34421 │ │ │ ├── correlationoptimizer2-18-18f10d12e8bfa473a916c2f528500538 │ │ │ ├── correlationoptimizer2-19-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer2-2-354213872b92046d7aec97c9ba7b4e97 │ │ │ ├── correlationoptimizer2-20-6907d13fadd74e0df33c7a99c1de0baf │ │ │ ├── correlationoptimizer2-21-c0c5744805b82aa8a6e3a62dfdb8097e │ │ │ ├── correlationoptimizer2-22-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer2-23-38b273c68d644e801695d5414c0e119b │ │ │ ├── correlationoptimizer2-24-c0c5744805b82aa8a6e3a62dfdb8097e │ │ │ ├── correlationoptimizer2-25-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer2-26-12408fe0bc5e6a22e838ee5ccef144d9 │ │ │ ├── correlationoptimizer2-27-9b22dad2843cdc379d90687745561104 │ │ │ ├── correlationoptimizer2-28-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer2-29-3781a20b72437434ef8fa7174edf36ab │ │ │ ├── correlationoptimizer2-3-d915fbdd493869aec42f548bdb66598d │ │ │ ├── correlationoptimizer2-30-9b22dad2843cdc379d90687745561104 │ │ │ ├── correlationoptimizer2-31-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer2-32-5ac93f83acfd31ce036381993eda303f │ │ │ ├── correlationoptimizer2-33-2b9eddc3452d8fc24ae9273e5d522e4b │ │ │ ├── correlationoptimizer2-34-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer2-35-996af7ef09a07d38d1a238b00c80da03 │ │ │ ├── correlationoptimizer2-36-2b9eddc3452d8fc24ae9273e5d522e4b │ │ │ ├── correlationoptimizer2-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer2-5-6eeb3aa27037ecf59c79c4252cb31f28 │ │ │ ├── correlationoptimizer2-6-d915fbdd493869aec42f548bdb66598d │ │ │ ├── correlationoptimizer2-7-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer2-8-74078f19dfe424f3211e6ce26de52152 │ │ │ ├── correlationoptimizer2-9-e6b368bfaea4d2838f8038b3bd29db06 │ │ │ ├── correlationoptimizer3-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer3-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer3-10-e3d5ff08760b877d49c0f10f63776325 │ │ │ ├── correlationoptimizer3-11-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer3-12-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer3-13-11a7c4a1256b5f56dbf8f2722e24831 │ │ │ ├── correlationoptimizer3-14-1f13e03988991067d13a9f3f1b36fcf5 │ │ │ ├── correlationoptimizer3-15-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer3-16-11a7c4a1256b5f56dbf8f2722e24831 │ │ │ ├── correlationoptimizer3-17-1f13e03988991067d13a9f3f1b36fcf5 │ │ │ ├── correlationoptimizer3-18-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer3-19-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer3-2-9a7769de1ce7fc0b0fc46f17da287ace │ │ │ ├── correlationoptimizer3-20-4025759f01fa2169a061070319ee8bfe │ │ │ ├── correlationoptimizer3-21-1f13e03988991067d13a9f3f1b36fcf5 │ │ │ ├── correlationoptimizer3-3-e3d5ff08760b877d49c0f10f63776325 │ │ │ ├── correlationoptimizer3-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer3-5-3c5cec9256d6f9d24a64b36fe6256f91 │ │ │ ├── correlationoptimizer3-6-e3d5ff08760b877d49c0f10f63776325 │ │ │ ├── correlationoptimizer3-7-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer3-8-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer3-9-c575bf5ba408caadb836d307b9971bea │ │ │ ├── correlationoptimizer4-0-d157f058f9e8659c4367e01c4da13579 │ │ │ ├── correlationoptimizer4-1-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── correlationoptimizer4-10-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-11-fb7cadb1f06690537178b2a04b1ee91e │ │ │ ├── correlationoptimizer4-12-340cf26bcac4ee29bdf8fd588ddc3c2e │ │ │ ├── correlationoptimizer4-13-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-14-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer4-15-8db0d44941d0ce086e95088ef579c136 │ │ │ ├── correlationoptimizer4-16-340cf26bcac4ee29bdf8fd588ddc3c2e │ │ │ ├── correlationoptimizer4-17-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer4-18-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer4-19-5e241577196c76217ed9615fcbc76dcb │ │ │ ├── correlationoptimizer4-2-46c5eef67c57677810028451dd2b4d9 │ │ │ ├── correlationoptimizer4-20-6ad79a473a876923a247f0cb57bb4208 │ │ │ ├── correlationoptimizer4-21-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-22-392b7eecdc93567cd0621e0efafbbaa8 │ │ │ ├── correlationoptimizer4-23-6ad79a473a876923a247f0cb57bb4208 │ │ │ ├── correlationoptimizer4-24-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-25-18ec265534266497e1da68480cfe51cf │ │ │ ├── correlationoptimizer4-26-62a0fd05be48759c39f3c284458dde9b │ │ │ ├── correlationoptimizer4-27-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer4-28-f14be583b8c69df924ac3bc4cf1761fb │ │ │ ├── correlationoptimizer4-29-6fa624d24bcc899e11dbe8b19b0d5cbf │ │ │ ├── correlationoptimizer4-3-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── correlationoptimizer4-30-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-31-7fea74857587a30456b095e20bc2bde1 │ │ │ ├── correlationoptimizer4-32-6fa624d24bcc899e11dbe8b19b0d5cbf │ │ │ ├── correlationoptimizer4-33-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-34-fa4c05d7d8707d20d89338d744f51dd0 │ │ │ ├── correlationoptimizer4-35-64d8e7807af6fc5a0214675a7c6a3be8 │ │ │ ├── correlationoptimizer4-36-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer4-37-3cd84bc4d9e25a49dee3d1ab09f002c1 │ │ │ ├── correlationoptimizer4-38-85fff71b240d0e26bab91d670c1349f2 │ │ │ ├── correlationoptimizer4-39-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer4-4-ee940bcfd73a883d16245ef746798e15 │ │ │ ├── correlationoptimizer4-40-ef5268865a18f57e15dc650a11527b11 │ │ │ ├── correlationoptimizer4-41-85fff71b240d0e26bab91d670c1349f2 │ │ │ ├── correlationoptimizer4-5-b5777cff7c522c4b527f77988e7f6bf1 │ │ │ ├── correlationoptimizer4-6-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer4-7-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer4-8-d926d0a2ecc3b2b7094cc7a094cb3d89 │ │ │ ├── correlationoptimizer4-9-340cf26bcac4ee29bdf8fd588ddc3c2e │ │ │ ├── correlationoptimizer6-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer6-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-10-25b1fe48ef86952fc7766fb74b63bf21 │ │ │ ├── correlationoptimizer6-11-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer6-12-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-13-f16444a052505377b7747949ffc2c028 │ │ │ ├── correlationoptimizer6-14-84463190baec77d61b287a071c8886db │ │ │ ├── correlationoptimizer6-15-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-16-1cce9d13fab4b27d36c0fe705d239f68 │ │ │ ├── correlationoptimizer6-17-84463190baec77d61b287a071c8886db │ │ │ ├── correlationoptimizer6-18-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-19-e7b8cde1cfc381901066753ecfa87ed4 │ │ │ ├── correlationoptimizer6-2-f196f01fc1d04f0e88881eb51e3b43c2 │ │ │ ├── correlationoptimizer6-20-4b0a2d0d62b76bbd8a44ebed4a9cc4de │ │ │ ├── correlationoptimizer6-21-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-22-a5e1c26011ddfbe79a886044dc17ea67 │ │ │ ├── correlationoptimizer6-23-4b0a2d0d62b76bbd8a44ebed4a9cc4de │ │ │ ├── correlationoptimizer6-24-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer6-25-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-26-f3001b5ee3fe7b9b01c82b0c79c2df02 │ │ │ ├── correlationoptimizer6-27-e149747103059314a9984235702b24b6 │ │ │ ├── correlationoptimizer6-28-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-29-3bc6f1aef3516fd7ba8c7527f2865dcd │ │ │ ├── correlationoptimizer6-3-25b1fe48ef86952fc7766fb74b63bf21 │ │ │ ├── correlationoptimizer6-30-e149747103059314a9984235702b24b6 │ │ │ ├── correlationoptimizer6-31-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-32-17c94297caaed15ea3ea2ea72d3508b7 │ │ │ ├── correlationoptimizer6-33-15d991127dc684513e2fff1aea3f1560 │ │ │ ├── correlationoptimizer6-34-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-35-833150221aa5d9fbb0cb626bd8ce0762 │ │ │ ├── correlationoptimizer6-36-15d991127dc684513e2fff1aea3f1560 │ │ │ ├── correlationoptimizer6-37-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-38-d1a903645384c97759e835649ce898fb │ │ │ ├── correlationoptimizer6-39-813d72763b5e9e3bed0f06232f55c8b8 │ │ │ ├── correlationoptimizer6-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-40-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-41-cea4eb2e1299a57e4732adc1439e7bb6 │ │ │ ├── correlationoptimizer6-42-813d72763b5e9e3bed0f06232f55c8b8 │ │ │ ├── correlationoptimizer6-43-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-44-ed339f429b82397bffb7298a534d59fb │ │ │ ├── correlationoptimizer6-45-ff6c54b483726ef15c90a4c68dc659a0 │ │ │ ├── correlationoptimizer6-46-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-47-53940f5dd35ccbe9086533076c362bd4 │ │ │ ├── correlationoptimizer6-48-ff6c54b483726ef15c90a4c68dc659a0 │ │ │ ├── correlationoptimizer6-49-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer6-5-c58f05e3e6f63bf3af7cad564063e9d3 │ │ │ ├── correlationoptimizer6-50-ade42af96a1436c5c4a3c86e3bc1a9f8 │ │ │ ├── correlationoptimizer6-51-4746d944f4193018017984ca2df3c60d │ │ │ ├── correlationoptimizer6-52-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-53-b9552c6399ce578cde69e663dd43d870 │ │ │ ├── correlationoptimizer6-54-4746d944f4193018017984ca2df3c60d │ │ │ ├── correlationoptimizer6-55-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-56-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer6-57-b9552c6399ce578cde69e663dd43d870 │ │ │ ├── correlationoptimizer6-58-4746d944f4193018017984ca2df3c60d │ │ │ ├── correlationoptimizer6-6-25b1fe48ef86952fc7766fb74b63bf21 │ │ │ ├── correlationoptimizer6-7-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer6-8-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer6-9-fd372b979ca4b12d64c65cb24e7d82ae │ │ │ ├── correlationoptimizer7-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer7-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer7-10-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer7-11-fc438bb849eff3496559a916c7dee058 │ │ │ ├── correlationoptimizer7-12-22d71fb589c53776dabb4696b38c4a42 │ │ │ ├── correlationoptimizer7-13-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer7-14-5b2d5594522db2b4bbc6aeb8e33b68d8 │ │ │ ├── correlationoptimizer7-15-22d71fb589c53776dabb4696b38c4a42 │ │ │ ├── correlationoptimizer7-2-5b2d5594522db2b4bbc6aeb8e33b68d8 │ │ │ ├── correlationoptimizer7-3-22d71fb589c53776dabb4696b38c4a42 │ │ │ ├── correlationoptimizer7-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer7-5-5b2d5594522db2b4bbc6aeb8e33b68d8 │ │ │ ├── correlationoptimizer7-6-22d71fb589c53776dabb4696b38c4a42 │ │ │ ├── correlationoptimizer7-7-24ca942f094b14b92086305cc125e833 │ │ │ ├── correlationoptimizer7-8-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── correlationoptimizer7-9-4d3e60a0e9bd8c12fdba4e010493537d │ │ │ ├── correlationoptimizer8-0-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer8-1-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer8-10-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer8-11-45693930a19f7e1b86202a5f5f2d139d │ │ │ ├── correlationoptimizer8-12-c1dfbe5cf77a97d195a3d0a65d1f1f │ │ │ ├── correlationoptimizer8-13-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer8-14-2b8991eb2f59bae3250c8d379b6d6aea │ │ │ ├── correlationoptimizer8-15-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer8-16-8c9264ae28e72f3724a78412f26ddbcc │ │ │ ├── correlationoptimizer8-2-34cad62f8ca6f6b53cf593960055c56a │ │ │ ├── correlationoptimizer8-3-932db4b9935e4bc3d21dd33a8d12c275 │ │ │ ├── correlationoptimizer8-4-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer8-5-f5fa5cecdf6f7359e7d727716a7e5b78 │ │ │ ├── correlationoptimizer8-6-932db4b9935e4bc3d21dd33a8d12c275 │ │ │ ├── correlationoptimizer8-7-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer8-8-39a62b29e0ac91861c58c56fc654ba67 │ │ │ ├── correlationoptimizer8-9-c1dfbe5cf77a97d195a3d0a65d1f1f │ │ │ ├── correlationoptimizer9-0-efd135a811fa94760736a761d220b82 │ │ │ ├── correlationoptimizer9-1-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── correlationoptimizer9-10-1190d82f88f7fb1f91968f6e2e03772a │ │ │ ├── correlationoptimizer9-11-bc2ae88b17ac2bdbd288e07194a40168 │ │ │ ├── correlationoptimizer9-12-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer9-13-1190d82f88f7fb1f91968f6e2e03772a │ │ │ ├── correlationoptimizer9-14-bc2ae88b17ac2bdbd288e07194a40168 │ │ │ ├── correlationoptimizer9-2-32a82500cc28465fac6f64dde0c431c6 │ │ │ ├── correlationoptimizer9-3-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── correlationoptimizer9-4-ec131bcf578dba99f20b16a7dc6b9b │ │ │ ├── correlationoptimizer9-5-b4e378104bb5ab8d8ba5f905aa1ff450 │ │ │ ├── correlationoptimizer9-6-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── correlationoptimizer9-7-f952899d70bd718cbdbc44a5290938c9 │ │ │ ├── correlationoptimizer9-8-b4e378104bb5ab8d8ba5f905aa1ff450 │ │ │ ├── correlationoptimizer9-9-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── count distinct 0 values-0-1843b7947729b771fee3a4abd050bfdc │ │ │ ├── count distinct 1 value + null long-0-89b850197b326239d60a5e1d5db7c9c9 │ │ │ ├── count distinct 1 value + null-0-a014038c00fb81e88041ed4a8368e6f7 │ │ │ ├── count distinct 1 value long-0-77b9ed1d7ae65fa53830a3bc586856ff │ │ │ ├── count distinct 1 value strings-0-c68e75ec4c884b93765a466e992e391d │ │ │ ├── count distinct 1 value-0-a4047b06a324fb5ea400c94350c9e038 │ │ │ ├── count distinct 2 values including null-0-75672236a30e10dab13b9b246c5a3a1e │ │ │ ├── count distinct 2 values long-0-f4ec7d767ba8c49d41edf5d6f58cf6d1 │ │ │ ├── count distinct 2 values-0-c61df65af167acaf7edb174e77898f3e │ │ │ ├── count-0-dd24f2cc60a0cd0eba0a3f8ca8127a0b │ │ │ ├── count-1-c47c4abedf055b4e734232fd2e274d55 │ │ │ ├── count-10-d0f804c7d06375db74a0fcf5f17603c6 │ │ │ ├── count-11-29aa086fe75b55482a91316c38498565 │ │ │ ├── count-12-944f53db544c07a7b38a0544a21d8e13 │ │ │ ├── count-2-461bad3feb7dbc25fb35d45c6876d698 │ │ │ ├── count-3-dbcec232623048c7748b708123e18bf0 │ │ │ ├── count-4-590bf60b8d4dfa135f73dbb52180136f │ │ │ ├── count-5-d0f804c7d06375db74a0fcf5f17603c6 │ │ │ ├── count-6-29aa086fe75b55482a91316c38498565 │ │ │ ├── count-7-944f53db544c07a7b38a0544a21d8e13 │ │ │ ├── count-8-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── count-9-590bf60b8d4dfa135f73dbb52180136f │ │ │ ├── cp_mj_rc-0-645f784b04a91b8c8e5bb770f95c3766 │ │ │ ├── cp_mj_rc-1-128c219e87f95f0425c8545a8c4bb32 │ │ │ ├── cp_mj_rc-2-17bbe2a542acac5960b755979dcb6d5e │ │ │ ├── cp_mj_rc-3-b1746cc42d6bbd2b1d314a9e5b18eb60 │ │ │ ├── cp_mj_rc-4-15beca26e35c885dff3bfe2336c26673 │ │ │ ├── cp_mj_rc-5-27550c25058249ebfc6cda30dcf513f9 │ │ │ ├── create table as with db name within backticks-0-a253b1ed35dbf503d1b8902dacbe23ac │ │ │ ├── create table as with db name within backticks-1-61dc640dfeaff471f3d2b730f9cbf959 │ │ │ ├── create table as with db name within backticks-2-ce780d068b8d24786e639e361101a0c7 │ │ │ ├── create table as with db name within backticks-3-afd6e46b6a289c3c24a8eec75a94043c │ │ │ ├── create table as with db name-0-a253b1ed35dbf503d1b8902dacbe23ac │ │ │ ├── create table as with db name-1-febc8588a2a54ed5b00e47cb83dd85c7 │ │ │ ├── create table as with db name-2-ce780d068b8d24786e639e361101a0c7 │ │ │ ├── create table as with db name-3-afd6e46b6a289c3c24a8eec75a94043c │ │ │ ├── create table as-0-fd42e3ffae73415391acb1012a3531bd │ │ │ ├── create table as-1-b9002c1d71895be765575b62656d1928 │ │ │ ├── create_genericudf-0-dd23fb149bb6d6937b838334559ad8d1 │ │ │ ├── create_insert_outputformat-0-16167c581df48112004009fef228e29a │ │ │ ├── create_insert_outputformat-1-1246ba69e870178971f5ae062641cf47 │ │ │ ├── create_insert_outputformat-2-8c2e4081b9d69297c35faab0a2ff86dc │ │ │ ├── create_insert_outputformat-3-cc4e4ae8e5be09017c6206b8ae5088c3 │ │ │ ├── create_insert_outputformat-4-2453e9c2ed5c7c517dce66a20e402a57 │ │ │ ├── create_insert_outputformat-5-8552731917a8260c25e6df79b83bf5c │ │ │ ├── create_insert_outputformat-6-2f52c0c383ad83fae1620a0db9f6c863 │ │ │ ├── create_insert_outputformat-7-a755c7e39694261510421e262b5005e │ │ │ ├── create_insert_outputformat-8-33a4312fd617c5c9f2a560dc6ce868a5 │ │ │ ├── create_like_tbl_props-0-432a3ade72afd99cfb4b886692c15e55 │ │ │ ├── create_like_tbl_props-1-f8481dcbc8f2731bab8ac3894511ff9f │ │ │ ├── create_like_tbl_props-10-2a2d6f2c92e32285dd4c4dd3d0faa9 │ │ │ ├── create_like_tbl_props-11-b4f47dcb46073bda6fb1d9f96e8b36e6 │ │ │ ├── create_like_tbl_props-12-184ab0f730b53d1b8b4f4e1feade9824 │ │ │ ├── create_like_tbl_props-2-62c728aff7df8cd2bd2c114c9076a1ff │ │ │ ├── create_like_tbl_props-3-3320f357baaadfe13820349b8d941865 │ │ │ ├── create_like_tbl_props-4-f59c262efb0482b555ae867abef4040f │ │ │ ├── create_like_tbl_props-5-11e1ff4a0cf4ee27f5ccb5f267643cfd │ │ │ ├── create_like_tbl_props-6-c49698cf69779ee8a519e2566c6b2acb │ │ │ ├── create_like_tbl_props-7-25f0c8b81d949d73737ee3a5398fc9f7 │ │ │ ├── create_like_tbl_props-8-69b6bc0b259beb299874e7cdfc5edb1b │ │ │ ├── create_like_tbl_props-9-9461431e44ae60a529cc309d8f325dbc │ │ │ ├── create_like_view-0-3b48eae3848493703396156bedb1e98b │ │ │ ├── create_like_view-1-3c805fc10db9af83327e04d518f3753a │ │ │ ├── create_like_view-10-eea111a209cf8895f31f64699669c705 │ │ │ ├── create_like_view-11-62e0dd08ff9214aa999d9a2f30704fe2 │ │ │ ├── create_like_view-12-cb343b6b463c2e9b5735fbdf82d24811 │ │ │ ├── create_like_view-13-fd80fbff7a622abe6b25c9fff7c5d608 │ │ │ ├── create_like_view-14-f19e6b501d5d2fb284777c71f8f6c0c3 │ │ │ ├── create_like_view-15-231c8b6709a8dc0b6a3b3a9751191cd7 │ │ │ ├── create_like_view-16-639a13da6855b974fc2e170fd49b33cb │ │ │ ├── create_like_view-17-a0ce573e299b66b8ce31da2890b318cb │ │ │ ├── create_like_view-18-d77d78569d86802f7c097d3d02150c │ │ │ ├── create_like_view-19-deabf2d92205da2cbce9bdff854a81f │ │ │ ├── create_like_view-2-78e7a2bb4c10776cbdfb37c73d92ad6b │ │ │ ├── create_like_view-20-152e6a694276b2fc1bb4fe6b4543fef0 │ │ │ ├── create_like_view-21-f982cac17966dcb9d76c1b6b9d4a7914 │ │ │ ├── create_like_view-22-26e7fe8b9b9769a8d6a8a95b9cfbdf91 │ │ │ ├── create_like_view-23-44c601e364e42a83babab4a342dfbd2b │ │ │ ├── create_like_view-24-df2d18dbae578430bfc7b9d27d201505 │ │ │ ├── create_like_view-25-87a663f8fd80110a9cee249535037c0d │ │ │ ├── create_like_view-26-152e6a694276b2fc1bb4fe6b4543fef0 │ │ │ ├── create_like_view-27-26e7fe8b9b9769a8d6a8a95b9cfbdf91 │ │ │ ├── create_like_view-3-559f17e8f827532749948b3b9e6c0f3f │ │ │ ├── create_like_view-4-c2351f011b8ea41ff7dfa8f195148da3 │ │ │ ├── create_like_view-5-ecd02bc3563cd6b60b8394956cb69084 │ │ │ ├── create_like_view-6-30485a2507b60b96cad3d293527e6af │ │ │ ├── create_like_view-7-fcc954b645304d258611f21d3aed7b76 │ │ │ ├── create_like_view-8-304a79a8a321b84aee91f907f756a7e3 │ │ │ ├── create_like_view-9-52dc9f900d7f7a559698aff9565f061a │ │ │ ├── create_nested_type-0-17320fbe4af5d2c6bf2d52425f70f968 │ │ │ ├── create_nested_type-1-ecd02bc3563cd6b60b8394956cb69084 │ │ │ ├── create_nested_type-2-c27702ff131e0ecfd71f1e1779fbe365 │ │ │ ├── create_nested_type-3-280fd0d9876e475d7dcf5383876ebc79 │ │ │ ├── create_nested_type-4-c26dff65f60f7c0c70183ce22f4529ff │ │ │ ├── create_skewed_table1-0-cafed8ca348b243372b9114910be1557 │ │ │ ├── create_skewed_table1-1-cc66bd64f1cdc97b953e20860305370 │ │ │ ├── create_skewed_table1-2-32a6d8b77b06bbd1f236d6c9d9a0c75e │ │ │ ├── create_skewed_table1-3-4f1d4f68bacf5fc6af33ef9e5e89e159 │ │ │ ├── create_skewed_table1-4-f3f1642674545762a4bff5cb75634e20 │ │ │ ├── create_skewed_table1-5-f5e6d62497ae174fdfeeb3fd6f899b2e │ │ │ ├── create_skewed_table1-6-d7a147c6b0a3609663628b43457b2cef │ │ │ ├── create_skewed_table1-7-81fc0a09afbcd674874961c09aa947d6 │ │ │ ├── create_skewed_table1-8-2ae6d96ecee0081ccc474388d50675fd │ │ │ ├── create_skewed_table1-9-758987cfb7302bdb76898290de49a80e │ │ │ ├── create_struct_table-0-d519c3ac0717b41167f8a40b472ad6b1 │ │ │ ├── create_struct_table-1-719851d0e8b89b51bdc6be4177455a92 │ │ │ ├── create_struct_table-2-d51e74fd10cc16607137b7f715557ecd │ │ │ ├── create_view_translate-0-dc7fc9ce5109ef459ee84ccfbb12d2c0 │ │ │ ├── create_view_translate-1-3896ae0e680a5fdc01833533b11c07bb │ │ │ ├── create_view_translate-10-7016e1e3a4248564f3d08cddad7ae116 │ │ │ ├── create_view_translate-11-e27c6a59a833dcbc2e5cdb7ff7972828 │ │ │ ├── create_view_translate-2-6b4caec6d7e3a91e61720bbd6b7697f0 │ │ │ ├── create_view_translate-3-30dc3e80e3873af5115e4f5e39078a13 │ │ │ ├── create_view_translate-4-cefb7530126f9e60cb4a29441d578f23 │ │ │ ├── create_view_translate-5-856ea995681b18a543dc0e53b8b43a8e │ │ │ ├── create_view_translate-6-a14cfe3eff322066e61023ec06c7735d │ │ │ ├── create_view_translate-7-e947bf2dacc907825df154a4131a3fcc │ │ │ ├── create_view_translate-8-b1a99b0beffb0b298aec9233ecc0707f │ │ │ ├── create_view_translate-9-fc0dc39c4796d917685e0797bc4a9786 │ │ │ ├── cross_join-0-7e4af1870bc73decae43b3383c7d2046 │ │ │ ├── cross_join-1-1a96761bf3e47ace9a422ed58273ff35 │ │ │ ├── cross_join-2-85c93a81eae05bf56a04a904bb80a229 │ │ │ ├── cross_product_check_1-0-d782db598869f9b19e0fcf5ea2a83594 │ │ │ ├── cross_product_check_1-1-bd8395c55fa2fc80b68eb043b7020b76 │ │ │ ├── cross_product_check_1-2-4e1b3108b7e1b9d8e94e73f9dfa44617 │ │ │ ├── cross_product_check_1-3-32a3e6eb858d37f58e225d07fb323254 │ │ │ ├── cross_product_check_1-4-36a6b6fb71ea08ff817dd40d1ffdb970 │ │ │ ├── cross_product_check_1-5-103739f072b849d212dbc40919f92b74 │ │ │ ├── cross_product_check_1-6-9a202e3bf15be2a310504a50920e7d25 │ │ │ ├── cross_product_check_1-7-e4e93f6e0dc63e1e324fb913a26fa8ac │ │ │ ├── cross_product_check_2-0-d782db598869f9b19e0fcf5ea2a83594 │ │ │ ├── cross_product_check_2-1-bd8395c55fa2fc80b68eb043b7020b76 │ │ │ ├── cross_product_check_2-2-24ca942f094b14b92086305cc125e833 │ │ │ ├── cross_product_check_2-3-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── cross_product_check_2-4-c14792ccac2ca64e3e9e21af4fd12d2c │ │ │ ├── cross_product_check_2-5-32a3e6eb858d37f58e225d07fb323254 │ │ │ ├── cross_product_check_2-6-36a6b6fb71ea08ff817dd40d1ffdb970 │ │ │ ├── cross_product_check_2-7-103739f072b849d212dbc40919f92b74 │ │ │ ├── cross_product_check_2-8-9a202e3bf15be2a310504a50920e7d25 │ │ │ ├── cross_product_check_2-9-e4e93f6e0dc63e1e324fb913a26fa8ac │ │ │ ├── ct_case_insensitive-0-a22bfdbaf9720a07e0b2c0923036ce93 │ │ │ ├── ct_case_insensitive-1-893c61ec6ea62362324c213f588d8030 │ │ │ ├── ct_case_insensitive-2-9db45f87a7b1e69d7bf38ac6d5009122 │ │ │ ├── database.table table.attr case insensitive-0-98b2e34c9134208e9fe7c62d33010005 │ │ │ ├── database.table table.attr-0-6cbb13c3a48f53fa6550dbba4d2c28fd │ │ │ ├── database.table-0-c657beb729b6a7882309a203fc6f298e │ │ │ ├── database_drop-0-49f18014566b3e020dc19b1e61d25a4f │ │ │ ├── database_drop-1-549981e00a3d95f03dd5a9ef6044aa20 │ │ │ ├── database_drop-10-8db536f925bf0f5058f97897e145a661 │ │ │ ├── database_drop-11-1b0a6cff3151cfa0ef0a6f78587973a5 │ │ │ ├── database_drop-12-2ea883422b74b701711e14e61472ba06 │ │ │ ├── database_drop-13-e02a53f7e798d2741152526516f14941 │ │ │ ├── database_drop-14-8f0fe60664d020b2a42c7f5c0c7bed35 │ │ │ ├── database_drop-15-7928ac876f76c990fa21d74b6c9e14f6 │ │ │ ├── database_drop-16-f9036ff3f0a3101373bdbc9a52faf00e │ │ │ ├── database_drop-17-95b906fd73935da8746b5277170e91e8 │ │ │ ├── database_drop-18-f65bf675b83871af7906741a60fa1318 │ │ │ ├── database_drop-19-d7fefbf585dbb67491e871ef58dca752 │ │ │ ├── database_drop-2-b28ed063cd2c2d1d370d6d422782a8f1 │ │ │ ├── database_drop-20-cbb84f0db4d55930a85cff28f7400bd0 │ │ │ ├── database_drop-21-eea49f066631be60519ae9d6b614d7d0 │ │ │ ├── database_drop-22-85833c3a68c29098827e438ff580bb94 │ │ │ ├── database_drop-23-84a5672989118a1b5792474c1469de90 │ │ │ ├── database_drop-24-441116797e8d95554c74472fa7644440 │ │ │ ├── database_drop-25-847ca97dd211889d83e5d487bfc44e23 │ │ │ ├── database_drop-26-bea20178515df24fcca04c0384f1c1b7 │ │ │ ├── database_drop-27-cb4b90a7f63c1646319ee7bb014a7750 │ │ │ ├── database_drop-28-53d67cbed634cff012dac41340bf6630 │ │ │ ├── database_drop-29-29d3232325eda40cbb0bd1786b7d070e │ │ │ ├── database_drop-3-db64b724719d27c7f0db4f51f5c4edaa │ │ │ ├── database_drop-30-bbad0860316d8b9b1eed50d231f3ab5d │ │ │ ├── database_drop-31-981f8e58caeae9cbbad3a113e3043de5 │ │ │ ├── database_drop-32-6c8e7590238b5aca1772721f0b914ece │ │ │ ├── database_drop-33-2bc7864932f597bdf98bdc410b1a2d9c │ │ │ ├── database_drop-34-491138bed44a70cb783bb2b531e1d82 │ │ │ ├── database_drop-35-9e0285d0596607cdadf75a763a543866 │ │ │ ├── database_drop-36-e66471f3f1bbe2d4b3b214e47793656d │ │ │ ├── database_drop-37-f6410721e3125a89836817136306eac4 │ │ │ ├── database_drop-38-7d45d97adebe50917a94cbe232c112a8 │ │ │ ├── database_drop-39-91b4a660ae5d5d2966d6bf3b6ae751d1 │ │ │ ├── database_drop-4-f21dd011aeb417043ed58c03fd5c3bf0 │ │ │ ├── database_drop-40-10073fb74a5c792322fc52389997695b │ │ │ ├── database_drop-41-7164c585e1ef4d9036ed4db275811084 │ │ │ ├── database_drop-42-c55cffbfc4d950363be97ccdb028faf3 │ │ │ ├── database_drop-43-cc6860c125b8b62450cb858c72716dc2 │ │ │ ├── database_drop-44-de81fd80132350aedcd9f0d9a212fd94 │ │ │ ├── database_drop-45-64e22634663e57153119340583e93651 │ │ │ ├── database_drop-46-eb28b907b605e51026f9902287e1d90d │ │ │ ├── database_drop-47-44e4d2bdab2dfa4583da47281ed00ba3 │ │ │ ├── database_drop-48-d419f4ff197d4291208c2028cd158909 │ │ │ ├── database_drop-5-d419f4ff197d4291208c2028cd158909 │ │ │ ├── database_drop-6-b7cf74929eabe781b0db79ed1043dc24 │ │ │ ├── database_drop-7-a47b1b070ec7c3b9ccabc34f41aebad9 │ │ │ ├── database_drop-8-b3980119a4b2d8f531951a940cba3697 │ │ │ ├── database_drop-9-97101266791d2b2c662bcde549422318 │ │ │ ├── database_location-0-5528e36b3b0f5b14313898cc45f9c23a │ │ │ ├── database_location-1-2b66b4554cf8ecf2ab6c325d4d89491 │ │ │ ├── database_location-10-c5cd9c57a13da7f345563fbd75da4e45 │ │ │ ├── database_location-11-9c36cac1372650b703400c60dd29042c │ │ │ ├── database_location-2-7650b86c86dd6b1a99c86ddc5a31bd63 │ │ │ ├── database_location-3-81383a2b9568f942cc8e758f9a6ee2f1 │ │ │ ├── database_location-4-be65cf649363681d54e593c42a5ecffb │ │ │ ├── database_location-5-9c36cac1372650b703400c60dd29042c │ │ │ ├── database_location-6-6fa58170a7c2e78b06a250403f02091a │ │ │ ├── database_location-7-5698ac10441da07dbe3a947143c999c2 │ │ │ ├── database_location-8-6f2797b6f81943d3b53b8d247ae8512b │ │ │ ├── database_location-9-92f087a5934481942995fc2aaf0d87e8 │ │ │ ├── database_properties-0-e7bfbd9422685e9a3a6c9bd4965f828f │ │ │ ├── database_properties-1-10de6a198e2b3f61974519ddd8623e68 │ │ │ ├── database_properties-10-26c10ff2ec4a69b16589069ced427d23 │ │ │ ├── database_properties-2-a1074315e598ad16bce55860e6e43363 │ │ │ ├── database_properties-3-751417d45b8e80ee5cba2034458b5bc9 │ │ │ ├── database_properties-4-ddf44597db4fa15e89bee313f2dad371 │ │ │ ├── database_properties-5-51c0974df1125b233936f25ce709ba4a │ │ │ ├── database_properties-6-26c10ff2ec4a69b16589069ced427d23 │ │ │ ├── database_properties-7-e7bfbd9422685e9a3a6c9bd4965f828f │ │ │ ├── database_properties-8-10de6a198e2b3f61974519ddd8623e68 │ │ │ ├── database_properties-9-5a2bc556d3c66c5b33ab86e6cd37b54a │ │ │ ├── date_1-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── date_1-1-23edf29bf7376c70d5ecf12720f4b1eb │ │ │ ├── date_1-10-df16364a220ff96a6ea1cd478cbc1d0b │ │ │ ├── date_1-11-d964bec7e5632091ab5cb6f6786dbbf9 │ │ │ ├── date_1-12-480c5f024a28232b7857be327c992509 │ │ │ ├── date_1-13-4c0ed7fcb75770d8790575b586bf14f4 │ │ │ ├── date_1-14-44fc74c1993062c0a9522199ff27fea │ │ │ ├── date_1-15-4855a66124b16d1d0d003235995ac06b │ │ │ ├── date_1-16-8bc190dba0f641840b5e1e198a14c55b │ │ │ ├── date_1-17-23edf29bf7376c70d5ecf12720f4b1eb │ │ │ ├── date_1-2-4ebe3571c13a8b0c03096fbd972b7f1b │ │ │ ├── date_1-3-26b5c291400dfde455b3c1b878b71d0 │ │ │ ├── date_1-4-df16364a220ff96a6ea1cd478cbc1d0b │ │ │ ├── date_1-5-d964bec7e5632091ab5cb6f6786dbbf9 │ │ │ ├── date_1-6-559d01fb0b42c42f0c4927fa0f9deac4 │ │ │ ├── date_1-7-df16364a220ff96a6ea1cd478cbc1d0b │ │ │ ├── date_1-8-d964bec7e5632091ab5cb6f6786dbbf9 │ │ │ ├── date_1-9-8306558e0eabe936ac33dabaaa17fea4 │ │ │ ├── date_2-0-8acfa0b538112534f57a3e051f0216bd │ │ │ ├── date_2-1-116032b973a2060b533e1cdc9dfda301 │ │ │ ├── date_2-2-efdf7f5d9f15edcb59a30f8ea166fbf1 │ │ │ ├── date_2-3-eedb73e0a622c2ab760b524f395dd4ba │ │ │ ├── date_2-4-3618dfde8da7c26f03bca72970db9ef7 │ │ │ ├── date_2-5-fe9bebfc8994ddd8d7cd0208c1f0af3c │ │ │ ├── date_2-6-f4edce7cb20f325e8b69e787b2ae8882 │ │ │ ├── date_4-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── date_4-0-b84f7e931d710dcbe3c5126d998285a8 │ │ │ ├── date_4-1-6272f5e518f6a20bc96a5870ff315c4f │ │ │ ├── date_4-1-b84f7e931d710dcbe3c5126d998285a8 │ │ │ ├── date_4-2-4a0e7bde447ef616b98e0f55d2886de0 │ │ │ ├── date_4-2-6272f5e518f6a20bc96a5870ff315c4f │ │ │ ├── date_4-3-4a0e7bde447ef616b98e0f55d2886de0 │ │ │ ├── date_4-3-a23faa56b5d3ca9063a21f72b4278b00 │ │ │ ├── date_4-4-6c4c2941bae77147a4d3d8fcaa1c88c8 │ │ │ ├── date_4-4-bee09a7384666043621f68297cee2e68 │ │ │ ├── date_4-5-b84f7e931d710dcbe3c5126d998285a8 │ │ │ ├── date_4-5-bee09a7384666043621f68297cee2e68 │ │ │ ├── date_4-6-b84f7e931d710dcbe3c5126d998285a8 │ │ │ ├── date_comparison-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── date_comparison-0-69eec445bd045c9dc899fafa348d8495 │ │ │ ├── date_comparison-1-69eec445bd045c9dc899fafa348d8495 │ │ │ ├── date_comparison-1-fcc400871a502009c8680509e3869ec1 │ │ │ ├── date_comparison-10-a9f2560c273163e11306d4f1dd1d9d54 │ │ │ ├── date_comparison-10-bcd987341fc1c38047a27d29dac6ae7c │ │ │ ├── date_comparison-11-4a7bac9ddcf40db6329faaec8e426543 │ │ │ ├── date_comparison-11-a9f2560c273163e11306d4f1dd1d9d54 │ │ │ ├── date_comparison-12-4a7bac9ddcf40db6329faaec8e426543 │ │ │ ├── date_comparison-2-b8598a4d0c948c2ddcf3eeef0abf2264 │ │ │ ├── date_comparison-2-fcc400871a502009c8680509e3869ec1 │ │ │ ├── date_comparison-3-14d35f266be9cceb11a2ae09ec8b3835 │ │ │ ├── date_comparison-3-b8598a4d0c948c2ddcf3eeef0abf2264 │ │ │ ├── date_comparison-4-14d35f266be9cceb11a2ae09ec8b3835 │ │ │ ├── date_comparison-4-c8865b14d53f2c2496fb69ee8191bf37 │ │ │ ├── date_comparison-5-c8865b14d53f2c2496fb69ee8191bf37 │ │ │ ├── date_comparison-5-f2c907e64da8166a731ddc0ed19bad6c │ │ │ ├── date_comparison-6-5606505a92bad10023ad9a3ef77eacc9 │ │ │ ├── date_comparison-6-f2c907e64da8166a731ddc0ed19bad6c │ │ │ ├── date_comparison-7-47913d4aaf0d468ab3764cc3bfd68eb │ │ │ ├── date_comparison-7-5606505a92bad10023ad9a3ef77eacc9 │ │ │ ├── date_comparison-8-1e5ce4f833b6fba45618437c8fb7643c │ │ │ ├── date_comparison-8-47913d4aaf0d468ab3764cc3bfd68eb │ │ │ ├── date_comparison-9-1e5ce4f833b6fba45618437c8fb7643c │ │ │ ├── date_comparison-9-bcd987341fc1c38047a27d29dac6ae7c │ │ │ ├── date_join1-0-70b9b49c55699fe94cfde069f5d197c │ │ │ ├── date_join1-1-3a68de2112a212a07a3068916c608fb │ │ │ ├── date_join1-2-e967e1ef6b209dfa5bdc60021dcb1964 │ │ │ ├── date_join1-3-f71c7be760fb4de4eff8225f2c6614b2 │ │ │ ├── date_join1-4-70b9b49c55699fe94cfde069f5d197c │ │ │ ├── date_serde-0-ca88593bb7ec47fa782145d732100c07 │ │ │ ├── date_serde-1-36e6041f53433482631018410bb62a99 │ │ │ ├── date_serde-10-d80e681519dcd8f5078c5602bb5befa9 │ │ │ ├── date_serde-11-29540200936bba47f17553547b409af7 │ │ │ ├── date_serde-12-c3c3275658b89d31fc504db31ae9f99c │ │ │ ├── date_serde-13-6c546456c81e635b6753e1552fac9129 │ │ │ ├── date_serde-14-f8ba18cc7b0225b4022299c44d435101 │ │ │ ├── date_serde-15-66fadc9bcea7d107a610758aa6f50ff3 │ │ │ ├── date_serde-16-1bd3345b46f77e17810978e56f9f7c6b │ │ │ ├── date_serde-17-a0df43062f8ab676ef728c9968443f12 │ │ │ ├── date_serde-18-b50ecc72ce9018ab12fb17568fef038a │ │ │ ├── date_serde-19-28f1cf92bdd6b2e5d328cd9d10f828b6 │ │ │ ├── date_serde-2-3ddfd8ecb28991aeed588f1ea852c427 │ │ │ ├── date_serde-20-588516368d8c1533cb7bfb2157fd58c1 │ │ │ ├── date_serde-21-dfe166fe053468e738dca23ebe043091 │ │ │ ├── date_serde-22-45240a488fb708e432d2f45b74ef7e63 │ │ │ ├── date_serde-23-1742a51e4967a8d263572d890cd8d4a8 │ │ │ ├── date_serde-24-14fd49bd6fee907c1699f7b4e26685b │ │ │ ├── date_serde-25-a199cf185184a25190d65c123d0694ee │ │ │ ├── date_serde-26-c5fa68d9aff36f22e5edc1b54332d0ab │ │ │ ├── date_serde-27-4d86c79f858866acec3c37f6598c2638 │ │ │ ├── date_serde-28-16a41fc9e0f51eb417c763bae8e9cadb │ │ │ ├── date_serde-29-bd1cb09aacd906527b0bbf43bbded812 │ │ │ ├── date_serde-3-e6167e27465514356c557a77d956ea46 │ │ │ ├── date_serde-30-7c80741f9f485729afc68609c55423a0 │ │ │ ├── date_serde-31-da36cd1654aee055cb3650133c9d11f │ │ │ ├── date_serde-32-bb2f76bd307ed616a3c797f8dd45a8d1 │ │ │ ├── date_serde-33-a742813b024e6dcfb4a358aa4e9fcdb6 │ │ │ ├── date_serde-34-6485841336c097895ad5b34f42c0745f │ │ │ ├── date_serde-35-8651a7c351cbc07fb1af6193f6885de8 │ │ │ ├── date_serde-36-36e6041f53433482631018410bb62a99 │ │ │ ├── date_serde-37-3ddfd8ecb28991aeed588f1ea852c427 │ │ │ ├── date_serde-38-e6167e27465514356c557a77d956ea46 │ │ │ ├── date_serde-39-c1e17c93582656c12970c37bac153bf2 │ │ │ ├── date_serde-4-c1e17c93582656c12970c37bac153bf2 │ │ │ ├── date_serde-40-4a17944b9ec8999bb20c5ba5d4cb877c │ │ │ ├── date_serde-5-4a17944b9ec8999bb20c5ba5d4cb877c │ │ │ ├── date_serde-6-e00facec2986bc55074868eff87ba22a │ │ │ ├── date_serde-7-580096b3b48db26bea91b80e1e1b081a │ │ │ ├── date_serde-8-cace4f60a08342f58fbe816a9c3a73cf │ │ │ ├── date_serde-9-436c3c61cc4278b54ac79c53c88ff422 │ │ │ ├── date_udf-0-84604a42a5d7f2842f1eec10c689d447 │ │ │ ├── date_udf-1-5e8136f6a6503ae9bef9beca80fada13 │ │ │ ├── date_udf-10-988ad9744096a29a3672a2d4c121299b │ │ │ ├── date_udf-11-a5100dd42201b5bc035a9d684cc21bdc │ │ │ ├── date_udf-12-eb7280a1f191344a99eaa0f805e8faff │ │ │ ├── date_udf-13-cc99e4f14fd092994b006ee7ebe4fc92 │ │ │ ├── date_udf-14-a6a5ce5134cc1125355a4bdf0a73d97 │ │ │ ├── date_udf-15-d031ee50c119d7c6acafd53543dbd0c4 │ │ │ ├── date_udf-16-dc59f69e1685e8d923b187ec50d80f06 │ │ │ ├── date_udf-17-7d046d4efc568049cf3792470b6feab9 │ │ │ ├── date_udf-18-84604a42a5d7f2842f1eec10c689d447 │ │ │ ├── date_udf-19-5e8136f6a6503ae9bef9beca80fada13 │ │ │ ├── date_udf-2-10e337c34d1e82a360b8599988f4b266 │ │ │ ├── date_udf-20-10e337c34d1e82a360b8599988f4b266 │ │ │ ├── date_udf-3-29e406e613c0284b3e16a8943a4d31bd │ │ │ ├── date_udf-4-23653315213f578856ab5c3bd80c0264 │ │ │ ├── date_udf-5-891fd92a4787b9789f6d1f51c1eddc8a │ │ │ ├── date_udf-6-3473c118d20783eafb456043a2ee5d5b │ │ │ ├── date_udf-7-9fb5165824e161074565e7500959c1b2 │ │ │ ├── date_udf-7-ef82dff775f4aba5d7a638b4e5fd9c5d │ │ │ ├── date_udf-8-badfe833681362092fc6345f888b1c21 │ │ │ ├── date_udf-9-a8cbb039661d796beaa0d1564c58c563 │ │ │ ├── decimal_1-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── decimal_1-1-6742a91ba2b9fa9c906d30d4d0ad0972 │ │ │ ├── decimal_1-10-c20dea9d716bef1bdbdef71323b1cc5b │ │ │ ├── decimal_1-11-f2f975b73220512d4bf2b9bd93354aba │ │ │ ├── decimal_1-12-2c2325880ea79c8e308398d46c8565f8 │ │ │ ├── decimal_1-13-c4c33bdb9f3c6cad77552f0f353092d3 │ │ │ ├── decimal_1-14-e45935cfffb9045394e804d0d1fc52f0 │ │ │ ├── decimal_1-15-31ecaab3afa056fcc656d6e54f845cf4 │ │ │ ├── decimal_1-2-ee665100ca5de3a006df43e97cfa707 │ │ │ ├── decimal_1-3-80fc87cab17ceffea334afbb230a6653 │ │ │ ├── decimal_1-4-5dd925bba25f735bfd6442a841afe119 │ │ │ ├── decimal_1-5-bfab296ca5693e647e33899dfeeb256 │ │ │ ├── decimal_1-6-a402201ed5159941384d40e09dc367a5 │ │ │ ├── decimal_1-7-2cfd7d00bc37a8e433ad005896173c1 │ │ │ ├── decimal_1-8-84cd75e494d113a48c4145298177d6d8 │ │ │ ├── decimal_1-9-e4e90927ac59f5920de3dc61c3288dde │ │ │ ├── decimal_1_1-0-3a2dd6fbf1d1bd84d4ca3db49522c79b │ │ │ ├── decimal_1_1-1-b53cdd539a5e5982b6b931a3730c54d3 │ │ │ ├── decimal_1_1-2-61bc0cebc625919a8fa3bec657b32a8a │ │ │ ├── decimal_1_1-3-ac24b36077314acab595ada14e598e │ │ │ ├── decimal_1_1-4-128804f8dfe7dbb23be0498b91647ba3 │ │ │ ├── decimal_1_1-5-8568f0a7b466fba7247cf5c195884579 │ │ │ ├── decimal_4-0-98a58225355eb73036bb7b1144fa5a5f │ │ │ ├── decimal_4-1-fa7e76c5dff605e58aa9d99182f865b1 │ │ │ ├── decimal_4-2-85c3185beb011f5c1e6856fc773a7484 │ │ │ ├── decimal_4-3-1451d7491441c1632fd5f751876cce6e │ │ │ ├── decimal_4-4-1bf9ff1d72a06c33885ba695adf2511d │ │ │ ├── decimal_4-5-7f2b3465d6a46b6f05cbb9bfe963f88c │ │ │ ├── decimal_4-6-693c2e345731f9b2b547c3b75218458e │ │ │ ├── decimal_4-7-f1eb45492510cb76cf6b452121af8531 │ │ │ ├── decimal_4-8-79734272b75fb9076bdb64644bed6276 │ │ │ ├── decimal_4-9-fe020b24cca92de056bddee2a1a3c5a6 │ │ │ ├── decimal_join-0-4668e9dee2cd7a32f2b7311d7cd35508 │ │ │ ├── decimal_join-1-5098974222b22a21ed847c7906df9313 │ │ │ ├── decimal_join-2-e966f01e702d4cc8f970dcdbc6007285 │ │ │ ├── default_partition_name-0-312a37c422883aa0d660018248157cf8 │ │ │ ├── default_partition_name-1-9de8e5f66c536d4ace89c61759db829c │ │ │ ├── default_partition_name-2-8732fdce7fb224dd783da2b83a93c795 │ │ │ ├── default_partition_name-3-a7047012b4bce0158edaafe5cf0a57be │ │ │ ├── delimiter-0-ef9bd1f5e2dad851509d6d2907c0e6ba │ │ │ ├── delimiter-1-121ff21e6931a82235de8301118cbed8 │ │ │ ├── delimiter-2-d7137294d2e53ea6edc259943e4c6069 │ │ │ ├── delimiter-3-176724f76343433a8f2e6131b12206d7 │ │ │ ├── delimiter-4-f17c3a91cdc84fbc6d14011b04f12a64 │ │ │ ├── describe_formatted_view_partitioned-0-889714213a760ae9ab3ebe199eb30b62 │ │ │ ├── describe_formatted_view_partitioned-1-cbd03c487eba9e34d57a8decaa3a0dfa │ │ │ ├── describe_formatted_view_partitioned-2-db8910ace81a5102495905a508ef5c28 │ │ │ ├── describe_formatted_view_partitioned-3-b80c7ae3530bfdbc8e865d49742da826 │ │ │ ├── describe_formatted_view_partitioned-4-889714213a760ae9ab3ebe199eb30b62 │ │ │ ├── disable_file_format_check-0-bd9d00e3ffcaea450a3cc8d0ba6f865c │ │ │ ├── disable_file_format_check-1-ec4d7e2ce5bd580b24119860e96f376e │ │ │ ├── disable_file_format_check-2-2d27f92dfced693fa3a68ecce5e2e838 │ │ │ ├── disable_file_format_check-3-93063fb3476a400ecfec0bfd02cbc23f │ │ │ ├── disable_file_format_check-4-a2150709a6ff73326bdf4865dd124a23 │ │ │ ├── distinct_stats-0-418ec894d08c33fd712eb358f579b7a0 │ │ │ ├── distinct_stats-1-10987e425ba8ba8d9c01538f16eab970 │ │ │ ├── distinct_stats-2-a2d8f812612283b20ec3f1e92a263440 │ │ │ ├── distinct_stats-3-a4397664f1f109ef0aa5ff36961b25b │ │ │ ├── distinct_stats-4-e540680af4a857404a0cb7cabc1bcf31 │ │ │ ├── distinct_stats-5-32e9736bf27c1d2e4399a8125e14befc │ │ │ ├── distinct_stats-6-297a53801744e6c4786e315e32c6189a │ │ │ ├── distinct_stats-7-92b9ef922e6b63a9de3ebcc23ee2d02d │ │ │ ├── distinct_stats-8-ca16024e6f5399b1d035f5b9fd665163 │ │ │ ├── distinct_stats-9-4b2407991ccf180e0eb38bf3d2ef2ec8 │ │ │ ├── div-0-3760f9b354ddacd7c7b01b28791d4585 │ │ │ ├── double case-0-f513687d17dcb18546fefa75000a52f2 │ │ │ ├── drop_function-0-9a0a48e6e2e5edffb4bcca349c49fa48 │ │ │ ├── drop_function-1-ea5871f0a80a41e19fd6a42bd29b693a │ │ │ ├── drop_index-0-9a0a48e6e2e5edffb4bcca349c49fa48 │ │ │ ├── drop_index-1-5875a80dd89498c8b61db5f6bf26898 │ │ │ ├── drop_index_removes_partition_dirs-0-a99af48bbcbaba062e9bc387ae2b4975 │ │ │ ├── drop_index_removes_partition_dirs-1-e67a0f7ff61a97b2c49386890ea88c54 │ │ │ ├── drop_index_removes_partition_dirs-2-19915227905aab376d918b3cada85c25 │ │ │ ├── drop_index_removes_partition_dirs-3-e32b952789a115ff02201dfa618d92b2 │ │ │ ├── drop_index_removes_partition_dirs-4-58aff7fa05fba3a7549629a17e285036 │ │ │ ├── drop_index_removes_partition_dirs-5-e32b952789a115ff02201dfa618d92b2 │ │ │ ├── drop_index_removes_partition_dirs-6-4642f8a18bf7409849f2e91d7a05f352 │ │ │ ├── drop_multi_partitions-0-c4449feb8f8e2c40c294ccf50680b47b │ │ │ ├── drop_multi_partitions-1-d738aa3c169c10f5b1e5959453dffbd4 │ │ │ ├── drop_multi_partitions-10-9120e865aa132bac6e0a29c907f0b760 │ │ │ ├── drop_multi_partitions-2-7554be9025c7683c67dce09177396357 │ │ │ ├── drop_multi_partitions-3-bc92a4d9670709904a8d49ebe9ba8e5 │ │ │ ├── drop_multi_partitions-4-9120e865aa132bac6e0a29c907f0b760 │ │ │ ├── drop_multi_partitions-5-53b0c9e5b0c8c37e75c1750280cf2aa0 │ │ │ ├── drop_multi_partitions-6-70ad97221d2be48259ea556f9d8e5353 │ │ │ ├── drop_multi_partitions-7-9120e865aa132bac6e0a29c907f0b760 │ │ │ ├── drop_multi_partitions-8-46a4f646bbc04f70e7ae5ed992f102f1 │ │ │ ├── drop_multi_partitions-9-3d4108847515b6386cd28b8862dcab53 │ │ │ ├── drop_partitions_filter-0-6863a128b9a05e5c251ec0092e6124d3 │ │ │ ├── drop_partitions_filter-1-e3eda6672f6602a1b9bc93ef789662f6 │ │ │ ├── drop_partitions_filter-10-119b0fe0597fa478e1533a412e2d444b │ │ │ ├── drop_partitions_filter-11-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-12-e0e995c7bcc6b6d801b68878b6166835 │ │ │ ├── drop_partitions_filter-13-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-14-f47427726dd7546c3c59a2ec53891bb3 │ │ │ ├── drop_partitions_filter-15-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-16-fae7d99452ab708daa96c30f0b25c03b │ │ │ ├── drop_partitions_filter-17-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-18-4553ba96e8c121b2e98966a67220a0fd │ │ │ ├── drop_partitions_filter-19-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-2-16027a4bed34a7610bbea1e11e83c3f2 │ │ │ ├── drop_partitions_filter-20-a08a2d37122fd5770f4197ec1f0ebd1c │ │ │ ├── drop_partitions_filter-21-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-22-46a4f646bbc04f70e7ae5ed992f102f1 │ │ │ ├── drop_partitions_filter-23-45bb3dea1b8d4bd353885cd68729698e │ │ │ ├── drop_partitions_filter-24-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter-25-67d75c72ea2d3982c55f3a850d93f83c │ │ │ ├── drop_partitions_filter-3-a499bb560b6e228b924387759214bc3c │ │ │ ├── drop_partitions_filter-4-8fde1e5c12230f4b8081950dfd68b18d │ │ │ ├── drop_partitions_filter-5-d3dc443408a20518c42b839fba218216 │ │ │ ├── drop_partitions_filter-6-8cf34fc1e9004b8fdf43770f7893506e │ │ │ ├── drop_partitions_filter-7-7f8f890e3104e36ff8f5747d9a287b39 │ │ │ ├── drop_partitions_filter-8-12ca7d0f34ab5127416bdb66d9e4a698 │ │ │ ├── drop_partitions_filter-9-972bcd28a9e24b4cac70ef74524f1696 │ │ │ ├── drop_partitions_filter2-0-322b270dab4032668de9002e9e8bc7c5 │ │ │ ├── drop_partitions_filter2-1-e3eda6672f6602a1b9bc93ef789662f6 │ │ │ ├── drop_partitions_filter2-10-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter2-11-8b9e0542bfbf07e9ceabb1ce599d856a │ │ │ ├── drop_partitions_filter2-12-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter2-13-8117981303487dc4c4873356931ef26a │ │ │ ├── drop_partitions_filter2-14-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter2-15-67d75c72ea2d3982c55f3a850d93f83c │ │ │ ├── drop_partitions_filter2-2-e83e7a8f276f890c4eb29e192d684730 │ │ │ ├── drop_partitions_filter2-3-31bf5686028f845040ae39acf642701 │ │ │ ├── drop_partitions_filter2-4-a2c778112718207a10070596cb4595d8 │ │ │ ├── drop_partitions_filter2-5-bc5cbd3b953ca86467c4a5fccd262f0a │ │ │ ├── drop_partitions_filter2-6-bbe938b3b20589283cc4541f3e417268 │ │ │ ├── drop_partitions_filter2-7-f34625fd49a5e655cba3abb5cb8c5417 │ │ │ ├── drop_partitions_filter2-8-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter2-9-185122a935af4fbe8466d7e39fc7648a │ │ │ ├── drop_partitions_filter3-0-e182f5fbf99c4d9be3fa8c496e0a5994 │ │ │ ├── drop_partitions_filter3-1-e3eda6672f6602a1b9bc93ef789662f6 │ │ │ ├── drop_partitions_filter3-10-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter3-11-57ca78d49ce16d1ebbbc759bad7adfa0 │ │ │ ├── drop_partitions_filter3-12-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter3-13-67d75c72ea2d3982c55f3a850d93f83c │ │ │ ├── drop_partitions_filter3-2-3e8e821dd63112223649b5d06febf7d9 │ │ │ ├── drop_partitions_filter3-3-431228f63002f8b7d1364aa2a07f92ec │ │ │ ├── drop_partitions_filter3-4-ce613fad87e72c2519c0d01b64f4a99a │ │ │ ├── drop_partitions_filter3-5-9a22b61cd027d740791ba847abc7e072 │ │ │ ├── drop_partitions_filter3-6-6127604e4c55b13778cc56c0068ce6ae │ │ │ ├── drop_partitions_filter3-7-688620ee5d61cce432e6c2d590b31404 │ │ │ ├── drop_partitions_filter3-8-83e3e422cdf9403523fa60d75376d7d7 │ │ │ ├── drop_partitions_filter3-9-d1a5c03e520fbfa2249e0a32b824a275 │ │ │ ├── drop_partitions_ignore_protection-0-11d8788cb803a84dd4ca3b4103a8bcb │ │ │ ├── drop_partitions_ignore_protection-1-864c8c804db30687f4265ba081ca6368 │ │ │ ├── drop_partitions_ignore_protection-2-446c2380269a60eb4710d7dbeb7c2ec6 │ │ │ ├── drop_partitions_ignore_protection-3-312aa26fdea6da7907e3a91f75e36f1 │ │ │ ├── drop_partitions_ignore_protection-4-11f9ef9dd235f44b29c77abf7ca27881 │ │ │ ├── drop_partitions_ignore_protection-5-1283e970d6dc39e7a86e86af904bf116 │ │ │ ├── drop_table-0-9a0a48e6e2e5edffb4bcca349c49fa48 │ │ │ ├── drop_table-1-afec243db5bd3a1b65d961e2325c6a57 │ │ │ ├── drop_table2-0-ac5bb9a5583f2d8968f2aaef3385b3f2 │ │ │ ├── drop_table2-1-35229351a48427cf25b42ac8a61200fa │ │ │ ├── drop_table2-2-cb72d751d94b6d8518c8d69017b6a293 │ │ │ ├── drop_table2-3-5f94efc9e658389a6d63553abd7a517f │ │ │ ├── drop_table2-4-1c852531c1e75093c27911b45315ed62 │ │ │ ├── drop_table2-5-1fdd850f6c301619f91eb58c890f2ad4 │ │ │ ├── drop_table2-6-120f319d6031395a86c726e43d4ef678 │ │ │ ├── drop_table2-7-35229351a48427cf25b42ac8a61200fa │ │ │ ├── drop_table2-8-1fdd850f6c301619f91eb58c890f2ad4 │ │ │ ├── drop_table2-9-120f319d6031395a86c726e43d4ef678 │ │ │ ├── drop_view-0-9a0a48e6e2e5edffb4bcca349c49fa48 │ │ │ ├── drop_view-1-70a24b7e47d8527298241bcbec922cf5 │ │ │ ├── dynamic_partition-0-be33aaa7253c8f248ff3921cd7dae340 │ │ │ ├── dynamic_partition-1-640552dd462707563fd255a713f83b41 │ │ │ ├── dynamic_partition-2-36456c9d0d2e3ef72ab5ba9ba48e5493 │ │ │ ├── dynamic_partition-3-b7f7fa7ebf666f4fee27e149d8c6961f │ │ │ ├── dynamic_partition-4-8bdb71ad8cb3cc3026043def2525de3a │ │ │ ├── dynamic_partition-5-c630dce438f3792e7fb0f523fbbb3e1e │ │ │ ├── dynamic_partition-6-7abc9ec8a36cdc5e89e955265a7fd7cf │ │ │ ├── dynamic_partition-7-be33aaa7253c8f248ff3921cd7dae340 │ │ │ ├── dynamic_partition_skip_default-0-3cd14bc5b126ff8b337c4abc09134260 │ │ │ ├── dynamic_partition_skip_default-1-16367c381d4b189b3640c92511244bfe │ │ │ ├── dynamic_partition_skip_default-2-ce929ee6a92b81d8080ca322c1c38a4b │ │ │ ├── dynamic_partition_skip_default-3-f3a5a998099b756a21cf9122a15b09d5 │ │ │ ├── dynamic_partition_skip_default-4-c8aa1ebce4b0b2b7f46bb3c2502f8b49 │ │ │ ├── dynamic_partition_skip_default-5-fed732d2e7d94a4fc02e7694f9f9a39c │ │ │ ├── dynamic_partition_skip_default-6-adab6a0187003ab7ee6f217c9e409d91 │ │ │ ├── dynamic_partition_skip_default-7-e707e693aa61edf87768fb71f6e936e1 │ │ │ ├── dynamic_partition_skip_default-8-adab6a0187003ab7ee6f217c9e409d91 │ │ │ ├── dynamic_partition_skip_default-9-4b099f87e221b8fd5c0d0d4a97c0d146 │ │ │ ├── empty aggregate input-0-bbd21aa0c1faf4c1fe6d8a822b416349 │ │ │ ├── escape_clusterby1-0-e34202f0d36c00a68722c802139d17cf │ │ │ ├── escape_clusterby1-1-914091aa635a64c707c69e296eb097a5 │ │ │ ├── escape_distributeby1-0-1f178ec5a7ea27b365012c751f3a9cdb │ │ │ ├── escape_distributeby1-1-f17d649f307c8c827bf2d136c5d02e5 │ │ │ ├── escape_orderby1-0-4057beace528a415308f7ca332f29941 │ │ │ ├── escape_orderby1-1-9c36a3f0e645466b4ebaf2b0f83bc568 │ │ │ ├── escape_sortby1-0-e9ca3a2551a33c710e1759517af3d5b0 │ │ │ ├── escape_sortby1-1-bb5ad94d261df75e195d3051a4634d99 │ │ │ ├── explain_rearrange-0-6f7c8515c354fb050829ebd66413425 │ │ │ ├── explain_rearrange-1-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── explain_rearrange-10-3f2680208772a0e51aefc4ef5604dddf │ │ │ ├── explain_rearrange-11-f2ca12a948fd9b5b842168e7c7d7b768 │ │ │ ├── explain_rearrange-12-3d63f0bb8fbacbcff9e5989ddf1bcc8e │ │ │ ├── explain_rearrange-13-5baad22ed7efa18d73eb8349e57cf331 │ │ │ ├── explain_rearrange-14-490d6253b73064ce403e4d04a8bc18f3 │ │ │ ├── explain_rearrange-2-24ca942f094b14b92086305cc125e833 │ │ │ ├── explain_rearrange-3-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── explain_rearrange-4-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── explain_rearrange-5-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── explain_rearrange-6-cda81d86d127fca0e2fbc2161e91400d │ │ │ ├── explain_rearrange-7-5b13cfa4b730e38ef2794c1532968e04 │ │ │ ├── explain_rearrange-8-1fd9c02fc67c3a403cb73eb10ed9fc12 │ │ │ ├── explain_rearrange-9-73b9ac83dbc9874dc9379ad4364d40ac │ │ │ ├── fetch_aggregation-0-739356d010a919138911f295fac81607 │ │ │ ├── fetch_aggregation-1-8dc96d77daa18d053fab3c134028788 │ │ │ ├── fetch_aggregation-2-f015c961b6c34ac56cb8fc52fb36d7c7 │ │ │ ├── file_split_for_small_table-0-7a45831bf96814d9a7fc3d78fb7bd8dc │ │ │ ├── fileformat_sequencefile-0-7df8fcbfff1c967de72295b90c530776 │ │ │ ├── fileformat_sequencefile-1-3114fdebb1e9b0830de9e9c3fff8a67e │ │ │ ├── fileformat_sequencefile-2-80ec34a069bc561aa6dc87314391b131 │ │ │ ├── fileformat_sequencefile-3-699522b1ff3f38cf6a75b06d83820b87 │ │ │ ├── fileformat_sequencefile-4-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── fileformat_text-0-c84258297070d93009fabc59c1f40a1e │ │ │ ├── fileformat_text-1-6375f4ba7af19f94c6afc366dc75429e │ │ │ ├── fileformat_text-2-80ec34a069bc561aa6dc87314391b131 │ │ │ ├── fileformat_text-3-699522b1ff3f38cf6a75b06d83820b87 │ │ │ ├── fileformat_text-4-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── filter_join_breaktask-0-5090cca7feb54de047bc535e234bd4a8 │ │ │ ├── filter_join_breaktask-1-3e3504c67d1ef47c71ea661f647ac4a6 │ │ │ ├── filter_join_breaktask-2-aa61f4a2dd974ae0df026de640ed5802 │ │ │ ├── filter_join_breaktask-3-550e9b759fb088a81feddeff2e4be64e │ │ │ ├── filter_join_breaktask2-0-db1a6e42b4f880b00b389ae21c7658e1 │ │ │ ├── filter_join_breaktask2-1-4a7480781402d0ac0a856a46ca3883fd │ │ │ ├── filter_join_breaktask2-10-8dbe2f8cda7ab38b38fc75d0d2413efd │ │ │ ├── filter_join_breaktask2-11-5cc7e24257a1cb4ad0f2fe41c7177370 │ │ │ ├── filter_join_breaktask2-12-c608f51882260caec7bb9c57a0ba3179 │ │ │ ├── filter_join_breaktask2-2-b8486987aee5bac5f5b7301952e67d0c │ │ │ ├── filter_join_breaktask2-3-1139b5e7f76614bc03bf0db677ed7d73 │ │ │ ├── filter_join_breaktask2-4-fe8b55e4e4098d7a2662338783a50306 │ │ │ ├── filter_join_breaktask2-5-cf724251613216ec54f8ac2e6b9b92fd │ │ │ ├── filter_join_breaktask2-6-8c782ae8f8245bdbe90d068a6b577d1e │ │ │ ├── filter_join_breaktask2-7-571467e86d08833eecf5d3e67b41bba6 │ │ │ ├── filter_join_breaktask2-8-604cf64d16b9d438ee187a10d9f6352e │ │ │ ├── filter_join_breaktask2-9-6d551990a8a745dde1cb5244947b81a1 │ │ │ ├── get_json_object #1-0-f01b340b5662c45bb5f1e3b7c6900e1f │ │ │ ├── get_json_object #10-0-f3f47d06d7c51d493d68112b0bd6c1fc │ │ │ ├── get_json_object #2-0-e84c2f8136919830fd665a278e4158a │ │ │ ├── get_json_object #3-0-bf140c65c31f8d892ec23e41e16e58bb │ │ │ ├── get_json_object #4-0-f0bd902edc1990c9a6c65a6bb672c4d5 │ │ │ ├── get_json_object #5-0-3c09f4316a1533049aee8af749cdcab │ │ │ ├── get_json_object #6-0-8334d1ddbe0f41fc7b80d4e6b45409da │ │ │ ├── get_json_object #7-0-40d7dff94b26a2e3f4ab71baee3d3ce0 │ │ │ ├── get_json_object #8-0-180b4b6fdb26011fec05a7ca99fd9844 │ │ │ ├── get_json_object #9-0-47c451a969d856f008f4d6b3d378d94b │ │ │ ├── groupby1-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby1-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby1-2-f90acd59ace31e16059bae52583188cc │ │ │ ├── groupby1-3-c8478dac3497697b4375ee35118a5c3e │ │ │ ├── groupby1-4-19094f229f8af852ef8dad406333ae08 │ │ │ ├── groupby1-5-c9cee6382b64bd3d71177527961b8be2 │ │ │ ├── groupby1-6-977359ea0d2f429a9a35bbd8599cddea │ │ │ ├── groupby1-7-c2c54378ffce53ade73a9dda783903e7 │ │ │ ├── groupby11-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby11-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby11-2-f06bf6a360c7f9425cffa237f00445d8 │ │ │ ├── groupby11-3-f11e9a986df49215fb8aa17aaccc7087 │ │ │ ├── groupby11-4-1ae3e153888f9ca44e92ef43aea19092 │ │ │ ├── groupby11-5-a6d0a37db950e5d309ef2b89e9cffe0f │ │ │ ├── groupby11-6-686ee4a5b2e24e51ba1d41b42215accd │ │ │ ├── groupby11-7-149d359546ab38226ffeb023d7414b3d │ │ │ ├── groupby12-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby12-1-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── groupby12-2-fd150794945892f3c926a1881cd819f4 │ │ │ ├── groupby12-3-8018bb917a0706925c14421ec2761663 │ │ │ ├── groupby12-4-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby1_limit-0-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby1_limit-1-647cd470ff311f1879243a6e7f1e7bf6 │ │ │ ├── groupby1_limit-2-e8f9567aa6dd201dd22db10fe7e8e082 │ │ │ ├── groupby1_limit-3-607512a8dd16cd9ddde561eeabfa51db │ │ │ ├── groupby1_limit-4-7a5ee36a377f0869bcb8c29c2391caa2 │ │ │ ├── groupby1_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby1_map-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby1_map-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby1_map-3-647cd470ff311f1879243a6e7f1e7bf6 │ │ │ ├── groupby1_map-4-330a40b8e19028bbb370adf219f469fe │ │ │ ├── groupby1_map-5-40f5168bfd9d124165bd207543b68a28 │ │ │ ├── groupby1_map-6-c83b156356c269b6aef263640a4f6b7b │ │ │ ├── groupby1_map_nomap-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby1_map_nomap-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby1_map_nomap-2-fb2713a701e7e9c3fa36b5459d772f4 │ │ │ ├── groupby1_map_nomap-3-647cd470ff311f1879243a6e7f1e7bf6 │ │ │ ├── groupby1_map_nomap-4-330a40b8e19028bbb370adf219f469fe │ │ │ ├── groupby1_map_nomap-5-40f5168bfd9d124165bd207543b68a28 │ │ │ ├── groupby1_map_nomap-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby1_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby1_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby1_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby1_map_skew-3-647cd470ff311f1879243a6e7f1e7bf6 │ │ │ ├── groupby1_map_skew-4-330a40b8e19028bbb370adf219f469fe │ │ │ ├── groupby1_map_skew-5-40f5168bfd9d124165bd207543b68a28 │ │ │ ├── groupby1_map_skew-6-c83b156356c269b6aef263640a4f6b7b │ │ │ ├── groupby1_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby1_noskew-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby1_noskew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby1_noskew-3-f90acd59ace31e16059bae52583188cc │ │ │ ├── groupby1_noskew-4-19094f229f8af852ef8dad406333ae08 │ │ │ ├── groupby1_noskew-5-977359ea0d2f429a9a35bbd8599cddea │ │ │ ├── groupby1_noskew-6-f7eda18efd187ec4bf4cb135833746cb │ │ │ ├── groupby2-0-43d53504df013e6b35f81811138a167a │ │ │ ├── groupby2-1-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby2-2-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby2-3-6b5d354a5a81c0171c3cc8d553bfdb9b │ │ │ ├── groupby2-4-67a2618eb44e68e6d8cf8792ded802f7 │ │ │ ├── groupby2-5-c0660310e5d882732d07cb76bc0a7939 │ │ │ ├── groupby2-6-41dfb7b036cae4972b275a0262ea2e4c │ │ │ ├── groupby2_limit-0-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby2_limit-1-a56d6499aef913e11ef599ac8b4f2a25 │ │ │ ├── groupby2_limit-2-e7a95dc27fbfcb10bf92a6db61522b6a │ │ │ ├── groupby2_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby2_map-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby2_map-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby2_map-3-1c0aa77190a5b3e1895e58cfbe7467a9 │ │ │ ├── groupby2_map-4-e193b8c0a9e1731dd46b145d166c78a7 │ │ │ ├── groupby2_map-5-ce0965adac15c4da6526d433d17ebc0 │ │ │ ├── groupby2_map-6-c83b156356c269b6aef263640a4f6b7b │ │ │ ├── groupby2_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby2_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby2_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby2_map_skew-3-1c0aa77190a5b3e1895e58cfbe7467a9 │ │ │ ├── groupby2_map_skew-4-e193b8c0a9e1731dd46b145d166c78a7 │ │ │ ├── groupby2_map_skew-5-ce0965adac15c4da6526d433d17ebc0 │ │ │ ├── groupby2_map_skew-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby2_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby2_noskew-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby2_noskew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby2_noskew-3-6b5d354a5a81c0171c3cc8d553bfdb9b │ │ │ ├── groupby2_noskew-4-67a2618eb44e68e6d8cf8792ded802f7 │ │ │ ├── groupby2_noskew-5-c0660310e5d882732d07cb76bc0a7939 │ │ │ ├── groupby2_noskew-6-232957c90d04497da7fe4e599e0dbb94 │ │ │ ├── groupby4-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby4-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby4-2-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── groupby4-3-132eabb30b8d011c848c531a6ab54529 │ │ │ ├── groupby4-4-ac19a9a7f4a16763bfe7998179257933 │ │ │ ├── groupby4-5-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby4_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby4_map-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby4_map-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby4_map-3-840759680be77463c13e4b19b2c1eb04 │ │ │ ├── groupby4_map-4-19182d5780c4632c5bf8effdd5c7f36b │ │ │ ├── groupby4_map-5-c0117072e2d392e3f860456d0226b7b9 │ │ │ ├── groupby4_map-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby4_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby4_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby4_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby4_map_skew-3-840759680be77463c13e4b19b2c1eb04 │ │ │ ├── groupby4_map_skew-4-19182d5780c4632c5bf8effdd5c7f36b │ │ │ ├── groupby4_map_skew-5-c0117072e2d392e3f860456d0226b7b9 │ │ │ ├── groupby4_map_skew-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby4_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby4_noskew-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby4_noskew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby4_noskew-3-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── groupby4_noskew-4-132eabb30b8d011c848c531a6ab54529 │ │ │ ├── groupby4_noskew-5-ac19a9a7f4a16763bfe7998179257933 │ │ │ ├── groupby4_noskew-6-2d1fb04c7060fafe470e14061b2a5b6f │ │ │ ├── groupby5-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby5-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby5-2-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── groupby5-3-a773aeb40af0516f2527f8e9d6907420 │ │ │ ├── groupby5-4-c4570c2676d599793e1e9ece32aa596e │ │ │ ├── groupby5-5-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby5_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby5_map-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby5_map-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby5_map-3-840759680be77463c13e4b19b2c1eb04 │ │ │ ├── groupby5_map-4-7b0346bd80d9833f2eccf8365b53d80f │ │ │ ├── groupby5_map-5-586dc4493f66ea612a1d5b3cda89d725 │ │ │ ├── groupby5_map-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby5_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby5_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby5_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby5_map_skew-3-840759680be77463c13e4b19b2c1eb04 │ │ │ ├── groupby5_map_skew-4-7b0346bd80d9833f2eccf8365b53d80f │ │ │ ├── groupby5_map_skew-5-586dc4493f66ea612a1d5b3cda89d725 │ │ │ ├── groupby5_map_skew-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby5_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby5_noskew-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby5_noskew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby5_noskew-3-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── groupby5_noskew-4-a773aeb40af0516f2527f8e9d6907420 │ │ │ ├── groupby5_noskew-5-c4570c2676d599793e1e9ece32aa596e │ │ │ ├── groupby5_noskew-6-c83b156356c269b6aef263640a4f6b7b │ │ │ ├── groupby6-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby6-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby6-2-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── groupby6-3-ae61517a9997b80d512a9089cdb71fac │ │ │ ├── groupby6-4-3f468a119e7975110b4063adb42c7dd9 │ │ │ ├── groupby6-5-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby6_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby6_map-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby6_map-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby6_map-3-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── groupby6_map-4-ae61517a9997b80d512a9089cdb71fac │ │ │ ├── groupby6_map-5-3f468a119e7975110b4063adb42c7dd9 │ │ │ ├── groupby6_map-6-2d1fb04c7060fafe470e14061b2a5b6f │ │ │ ├── groupby6_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby6_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby6_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby6_map_skew-3-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── groupby6_map_skew-4-ae61517a9997b80d512a9089cdb71fac │ │ │ ├── groupby6_map_skew-5-3f468a119e7975110b4063adb42c7dd9 │ │ │ ├── groupby6_map_skew-6-2d1fb04c7060fafe470e14061b2a5b6f │ │ │ ├── groupby6_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby6_noskew-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby6_noskew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby6_noskew-3-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── groupby6_noskew-4-ae61517a9997b80d512a9089cdb71fac │ │ │ ├── groupby6_noskew-5-3f468a119e7975110b4063adb42c7dd9 │ │ │ ├── groupby6_noskew-6-2d1fb04c7060fafe470e14061b2a5b6f │ │ │ ├── groupby7-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby7-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby7-2-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby7-3-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby7-4-9d01ff3d1fde3ed2ab55ea9d7079fd5c │ │ │ ├── groupby7-5-ed76c0068780120a6f23feefee303403 │ │ │ ├── groupby7-6-b2af91348c5fa9605702be50983c3bd2 │ │ │ ├── groupby7-7-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby7-8-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby7_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby7_map-1-7f98b724df05f51b3ec1f087a8da414e │ │ │ ├── groupby7_map-10-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby7_map-11-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby7_map-2-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby7_map-3-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby7_map-4-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby7_map-5-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby7_map-6-9d01ff3d1fde3ed2ab55ea9d7079fd5c │ │ │ ├── groupby7_map-7-ed76c0068780120a6f23feefee303403 │ │ │ ├── groupby7_map-8-409f355bf35dfaa8b9e643510c58fabd │ │ │ ├── groupby7_map-9-b2af91348c5fa9605702be50983c3bd2 │ │ │ ├── groupby7_map_multi_single_reducer-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby7_map_multi_single_reducer-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby7_map_multi_single_reducer-10-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby7_map_multi_single_reducer-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby7_map_multi_single_reducer-3-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby7_map_multi_single_reducer-4-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby7_map_multi_single_reducer-5-9d01ff3d1fde3ed2ab55ea9d7079fd5c │ │ │ ├── groupby7_map_multi_single_reducer-6-ed76c0068780120a6f23feefee303403 │ │ │ ├── groupby7_map_multi_single_reducer-7-409f355bf35dfaa8b9e643510c58fabd │ │ │ ├── groupby7_map_multi_single_reducer-8-b2af91348c5fa9605702be50983c3bd2 │ │ │ ├── groupby7_map_multi_single_reducer-9-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby7_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby7_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby7_map_skew-10-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby7_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby7_map_skew-3-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby7_map_skew-4-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby7_map_skew-5-9d01ff3d1fde3ed2ab55ea9d7079fd5c │ │ │ ├── groupby7_map_skew-6-ed76c0068780120a6f23feefee303403 │ │ │ ├── groupby7_map_skew-7-409f355bf35dfaa8b9e643510c58fabd │ │ │ ├── groupby7_map_skew-8-b2af91348c5fa9605702be50983c3bd2 │ │ │ ├── groupby7_map_skew-9-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby7_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby7_noskew-1-7f98b724df05f51b3ec1f087a8da414e │ │ │ ├── groupby7_noskew-10-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby7_noskew-11-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby7_noskew-2-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby7_noskew-3-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby7_noskew-4-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby7_noskew-5-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby7_noskew-6-9d01ff3d1fde3ed2ab55ea9d7079fd5c │ │ │ ├── groupby7_noskew-7-ed76c0068780120a6f23feefee303403 │ │ │ ├── groupby7_noskew-8-409f355bf35dfaa8b9e643510c58fabd │ │ │ ├── groupby7_noskew-9-b2af91348c5fa9605702be50983c3bd2 │ │ │ ├── groupby7_noskew_multi_single_reducer-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby7_noskew_multi_single_reducer-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby7_noskew_multi_single_reducer-10-96d0598a2a4c17041a31b908d1f065e5 │ │ │ ├── groupby7_noskew_multi_single_reducer-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby7_noskew_multi_single_reducer-3-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby7_noskew_multi_single_reducer-4-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby7_noskew_multi_single_reducer-5-9d01ff3d1fde3ed2ab55ea9d7079fd5c │ │ │ ├── groupby7_noskew_multi_single_reducer-6-ed76c0068780120a6f23feefee303403 │ │ │ ├── groupby7_noskew_multi_single_reducer-7-186e2b8dc9a393a8bd8c47a303f7f471 │ │ │ ├── groupby7_noskew_multi_single_reducer-8-ab2390a3b0ba76907a7bee390b2924a1 │ │ │ ├── groupby7_noskew_multi_single_reducer-9-652510b8dc20117c65511f06e6e73d73 │ │ │ ├── groupby8-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby8-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby8-10-83296fd5b5fc22af0c51514c4e67c95f │ │ │ ├── groupby8-11-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby8-12-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby8-2-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby8-3-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby8-4-a0a22ec83d6632cba3f17d79dbb9494d │ │ │ ├── groupby8-5-83296fd5b5fc22af0c51514c4e67c95f │ │ │ ├── groupby8-6-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby8-7-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby8-8-7f98b724df05f51b3ec1f087a8da414e │ │ │ ├── groupby8-9-a0a22ec83d6632cba3f17d79dbb9494d │ │ │ ├── groupby8_map-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby8_map-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby8_map-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby8_map-3-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby8_map-4-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby8_map-5-a0a22ec83d6632cba3f17d79dbb9494d │ │ │ ├── groupby8_map-6-83296fd5b5fc22af0c51514c4e67c95f │ │ │ ├── groupby8_map-7-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby8_map-8-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby8_map_skew-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby8_map_skew-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── groupby8_map_skew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby8_map_skew-3-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby8_map_skew-4-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby8_map_skew-5-a0a22ec83d6632cba3f17d79dbb9494d │ │ │ ├── groupby8_map_skew-6-83296fd5b5fc22af0c51514c4e67c95f │ │ │ ├── groupby8_map_skew-7-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby8_map_skew-8-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby8_noskew-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby8_noskew-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby8_noskew-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby8_noskew-3-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby8_noskew-4-95474af63c0f92717ed49c3a0f37b10a │ │ │ ├── groupby8_noskew-5-a0a22ec83d6632cba3f17d79dbb9494d │ │ │ ├── groupby8_noskew-6-83296fd5b5fc22af0c51514c4e67c95f │ │ │ ├── groupby8_noskew-7-c1a8cf4ef8060a4703b0affe40496169 │ │ │ ├── groupby8_noskew-8-6c26c5d39c4bdb61728defa9b44bfb52 │ │ │ ├── groupby9-0-3678fb67b5c739bd87d4907630da1208 │ │ │ ├── groupby9-1-6ffcd6fad9ca3e9934f521673f5039a5 │ │ │ ├── groupby9-10-7f98b724df05f51b3ec1f087a8da414e │ │ │ ├── groupby9-11-a4e1a4b250c160f9b90b12a2e7c5e82f │ │ │ ├── groupby9-12-9f4c2e7d95494bcdc7c4ed19e0434de6 │ │ │ ├── groupby9-13-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby9-14-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby9-15-c3d5e2da9bbf7d66aa106eb13183dbed │ │ │ ├── groupby9-16-c05b1bc66a607e43633dc457ecf48f3b │ │ │ ├── groupby9-17-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby9-18-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby9-19-55781df7ed3ff9e37001fbd7739b9c2e │ │ │ ├── groupby9-2-a4e1a4b250c160f9b90b12a2e7c5e82f │ │ │ ├── groupby9-20-ccc5914317422f569e8b7171a3b2b243 │ │ │ ├── groupby9-21-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby9-22-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby9-3-9f4c2e7d95494bcdc7c4ed19e0434de6 │ │ │ ├── groupby9-4-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby9-5-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby9-6-55781df7ed3ff9e37001fbd7739b9c2e │ │ │ ├── groupby9-7-ccc5914317422f569e8b7171a3b2b243 │ │ │ ├── groupby9-8-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── groupby9-9-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── groupby_distinct_samekey-0-63603572a0f759ea81f4649ae2210ef8 │ │ │ ├── groupby_distinct_samekey-1-a3f3e279ab0be5093f4a926e265c0211 │ │ │ ├── groupby_distinct_samekey-2-59ee4550803e419b3adb1e9dd4220113 │ │ │ ├── groupby_distinct_samekey-3-12b0749f4fb915f3b2e317ed4fbc9cb4 │ │ │ ├── groupby_distinct_samekey-4-d88c962262d3524bfc881b7309688e38 │ │ │ ├── groupby_distinct_samekey-5-78c0b7be08118a14e0337ff552fcb9ad │ │ │ ├── groupby_distinct_samekey-6-edcbea736edb6104a73f0dc670418ee5 │ │ │ ├── groupby_distinct_samekey-7-ca16024e6f5399b1d035f5b9fd665163 │ │ │ ├── groupby_grouping_id1-0-caf1c5fd299fdbdb655234d01d44caf2 │ │ │ ├── groupby_grouping_id1-1-b76bf9f6c92f83c9a5f351f8460d1e3b │ │ │ ├── groupby_grouping_id1-1-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_grouping_id1-2-3dfbff77a9b56d44312814d3fb0d07fa │ │ │ ├── groupby_grouping_id1-3-d113d984a30ad7b98c50a46158605a51 │ │ │ ├── groupby_grouping_id1-4-903a499840102e2cb722dd8b83820391 │ │ │ ├── groupby_grouping_id2-0-20539c642c514a590caca2f11395007e │ │ │ ├── groupby_grouping_id2-1-d1f3215e349f056c8de60b87a6a9855e │ │ │ ├── groupby_grouping_id2-1-d6fb6c164cda6a13a71290dbf95fcc6e │ │ │ ├── groupby_grouping_id2-2-a00d1791b7fa7ac5a0505d95c3d12257 │ │ │ ├── groupby_grouping_id2-3-b3cb95405b1200603f40aaab24be7586 │ │ │ ├── groupby_grouping_id2-4-9bdcf67baa5d7cf70cd2eb1a3ec6de74 │ │ │ ├── groupby_grouping_id2-5-7dd97bda7e2a900dfc509a6133620b82 │ │ │ ├── groupby_grouping_id2-6-a7dc16cb82c595b18d4258a38a304b1e │ │ │ ├── groupby_grouping_id2-7-b3cb95405b1200603f40aaab24be7586 │ │ │ ├── groupby_grouping_id2-8-9bdcf67baa5d7cf70cd2eb1a3ec6de74 │ │ │ ├── groupby_grouping_id2-9-7dd97bda7e2a900dfc509a6133620b82 │ │ │ ├── groupby_grouping_sets1-0-91128722f50ec00b51e0bf6fe5695cd1 │ │ │ ├── groupby_grouping_sets1-1-3673d61d0944adeba77438d882839de4 │ │ │ ├── groupby_grouping_sets1-1-d1c300ea08361fb8237689c6cf8cc1b5 │ │ │ ├── groupby_grouping_sets1-2-5c14fabebc5b4c526c459a6e867ec61a │ │ │ ├── groupby_grouping_sets1-3-9f501f293fe180bf6322e93d8dea025a │ │ │ ├── groupby_grouping_sets1-4-505ac6611b332d6cf4a364739075d49c │ │ │ ├── groupby_grouping_sets1-5-a33cc72bf5adee428eea079847034b62 │ │ │ ├── groupby_grouping_sets1-6-5f0c2e1d5489c867261e575625349542 │ │ │ ├── groupby_grouping_sets1-7-9b3bda02733476012e2cda434d936423 │ │ │ ├── groupby_grouping_sets1-8-1273ad6760f8c3ddad07819362dcc324 │ │ │ ├── groupby_grouping_sets2-0-bb96e87a0d6b0d1a6167e424b086acf6 │ │ │ ├── groupby_grouping_sets2-1-91128722f50ec00b51e0bf6fe5695cd1 │ │ │ ├── groupby_grouping_sets2-10-f39e49610430c91e5af3876d15fbdfe3 │ │ │ ├── groupby_grouping_sets2-2-3673d61d0944adeba77438d882839de4 │ │ │ ├── groupby_grouping_sets2-2-d1c300ea08361fb8237689c6cf8cc1b5 │ │ │ ├── groupby_grouping_sets2-3-59adefab34d80e8e185b2ad03877d381 │ │ │ ├── groupby_grouping_sets2-4-9f501f293fe180bf6322e93d8dea025a │ │ │ ├── groupby_grouping_sets2-5-1163c486fd7e2c4346805fb035e2f268 │ │ │ ├── groupby_grouping_sets2-6-9459dc3e8ab1f09d6d912b686e7f37fc │ │ │ ├── groupby_grouping_sets2-7-39db88427f92cb770b6daa38610c04e7 │ │ │ ├── groupby_grouping_sets2-8-e464ec3d5461bda47eac3d1ef8617786 │ │ │ ├── groupby_grouping_sets2-9-74126b100714164d13cbb3bff436c2ff │ │ │ ├── groupby_grouping_sets3-0-4fe85ca1e68a895ef403afdcfbbf61bc │ │ │ ├── groupby_grouping_sets3-1-38373b67d392924967a4695689d2164e │ │ │ ├── groupby_grouping_sets3-1-e8964b2aaeb388064c9fdac5ec687824 │ │ │ ├── groupby_grouping_sets3-2-c1942a377b1a440d4ed3dd05fed445d │ │ │ ├── groupby_grouping_sets3-2-d95cf9dfae402d369f338b8516845e02 │ │ │ ├── groupby_grouping_sets3-3-b89ea2173180c8ae423d856f943e061f │ │ │ ├── groupby_grouping_sets3-4-77c57e1b4ca37c2dc715b65668cd0c59 │ │ │ ├── groupby_grouping_sets3-5-6623f95d90d929a6d2c8171a0698d4fd │ │ │ ├── groupby_grouping_sets3-6-aec59088408cc57248851d3ce04e2eef │ │ │ ├── groupby_grouping_sets3-7-bb96e87a0d6b0d1a6167e424b086acf6 │ │ │ ├── groupby_grouping_sets3-8-f32c4a191759237733a10cd721b49966 │ │ │ ├── groupby_grouping_sets3-9-aec59088408cc57248851d3ce04e2eef │ │ │ ├── groupby_grouping_sets4-0-d8ae5a3e613dd2dda392995b90d47565 │ │ │ ├── groupby_grouping_sets4-1-6ad4e855adb49babfa3ae6abac190be3 │ │ │ ├── groupby_grouping_sets4-2-1789808269c8bd0f6259227f07da1a6a │ │ │ ├── groupby_grouping_sets4-3-3673d61d0944adeba77438d882839de4 │ │ │ ├── groupby_grouping_sets4-3-d1c300ea08361fb8237689c6cf8cc1b5 │ │ │ ├── groupby_grouping_sets4-4-b51d813d0c5a410d8cf9765d85005a01 │ │ │ ├── groupby_grouping_sets4-5-9be98faf8588a3c8e7436f14c638e438 │ │ │ ├── groupby_grouping_sets4-6-bb96e87a0d6b0d1a6167e424b086acf6 │ │ │ ├── groupby_grouping_sets4-7-98f7522ce136cdffb0c14163e613c250 │ │ │ ├── groupby_grouping_sets4-8-9be98faf8588a3c8e7436f14c638e438 │ │ │ ├── groupby_grouping_sets5-0-d8ae5a3e613dd2dda392995b90d47565 │ │ │ ├── groupby_grouping_sets5-1-6ad4e855adb49babfa3ae6abac190be3 │ │ │ ├── groupby_grouping_sets5-2-1789808269c8bd0f6259227f07da1a6a │ │ │ ├── groupby_grouping_sets5-3-3673d61d0944adeba77438d882839de4 │ │ │ ├── groupby_grouping_sets5-3-d1c300ea08361fb8237689c6cf8cc1b5 │ │ │ ├── groupby_grouping_sets5-4-6a89a34347f1c0eb9e0763ecedddb6f9 │ │ │ ├── groupby_grouping_sets5-5-af3569757b9f52fb9b1ead33130e1b4f │ │ │ ├── groupby_grouping_sets5-6-bb96e87a0d6b0d1a6167e424b086acf6 │ │ │ ├── groupby_grouping_sets5-7-6544a382d851f916616c4386fdcf0ed8 │ │ │ ├── groupby_grouping_sets5-8-af3569757b9f52fb9b1ead33130e1b4f │ │ │ ├── groupby_map_ppr-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby_map_ppr-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby_map_ppr-2-be2c0b32a02a1154bfdee1a52530f387 │ │ │ ├── groupby_map_ppr-3-1c0aa77190a5b3e1895e58cfbe7467a9 │ │ │ ├── groupby_map_ppr-4-e5121a2b8210b2e4f8b1bfbf0a044486 │ │ │ ├── groupby_map_ppr-5-d4faa22fc1ec8cfc8ab21474841d415a │ │ │ ├── groupby_map_ppr-6-c83b156356c269b6aef263640a4f6b7b │ │ │ ├── groupby_multi_insert_common_distinct-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── groupby_multi_insert_common_distinct-1-388618d4d475de38d5c280fd7038730b │ │ │ ├── groupby_multi_insert_common_distinct-10-6aa66df624cd32601218eee200977ce6 │ │ │ ├── groupby_multi_insert_common_distinct-11-59a77127c166fef57504c011ccb427a6 │ │ │ ├── groupby_multi_insert_common_distinct-2-2e1779fc58da364612a1c84d563ea7d5 │ │ │ ├── groupby_multi_insert_common_distinct-3-febd68f62dd71550dd3db8335d1f93f7 │ │ │ ├── groupby_multi_insert_common_distinct-4-c2781ed9ce9a29f484f7648ce6e06a9e │ │ │ ├── groupby_multi_insert_common_distinct-5-6aa66df624cd32601218eee200977ce6 │ │ │ ├── groupby_multi_insert_common_distinct-6-59a77127c166fef57504c011ccb427a6 │ │ │ ├── groupby_multi_insert_common_distinct-7-293182ac89effb268855f5ac53e1ec11 │ │ │ ├── groupby_multi_insert_common_distinct-8-51d6bc83dcb6610b5b4f350cbaf25d29 │ │ │ ├── groupby_multi_insert_common_distinct-9-c2781ed9ce9a29f484f7648ce6e06a9e │ │ │ ├── groupby_multi_single_reducer2-0-b31bf66c43bb9f7ddc09b138b7bf36e0 │ │ │ ├── groupby_multi_single_reducer2-1-660d3ff0ca588c2da097b5f3ca753ada │ │ │ ├── groupby_multi_single_reducer2-2-7372ea92a15e7beed3be5e2dd2cbac47 │ │ │ ├── groupby_multi_single_reducer2-3-eeaa92b3f8e6667d3395f8dc7ea6d89e │ │ │ ├── groupby_multi_single_reducer2-4-427627f4cf6d91e5314c85e0c5aa2f84 │ │ │ ├── groupby_multi_single_reducer2-5-376542befbcab97d864e874251720c40 │ │ │ ├── groupby_multi_single_reducer2-6-8566e4c94d34b0fc4a71d34e89529c74 │ │ │ ├── groupby_multi_single_reducer2-7-4938ddc6b516cf67779be0d7dc29e7ab │ │ │ ├── groupby_multi_single_reducer2-8-180b611e08d4080fa098ed69169c2478 │ │ │ ├── groupby_multi_single_reducer3-0-36cc74ebca5adb026757c5cd8df5a0dd │ │ │ ├── groupby_multi_single_reducer3-1-9e61989d717403353689cbbb2816210d │ │ │ ├── groupby_multi_single_reducer3-10-73819ea1a7c0653a61652b3766afb003 │ │ │ ├── groupby_multi_single_reducer3-11-8603afa3bf3deeda532fc69b7df49e09 │ │ │ ├── groupby_multi_single_reducer3-12-2ab5cc10c0b37e7cf3c0d33fdc39b628 │ │ │ ├── groupby_multi_single_reducer3-13-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── groupby_multi_single_reducer3-14-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── groupby_multi_single_reducer3-15-36e81eba0a6a42532d8ee147086d668a │ │ │ ├── groupby_multi_single_reducer3-16-59b2c947e136092e7ca5019c96a9994b │ │ │ ├── groupby_multi_single_reducer3-17-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── groupby_multi_single_reducer3-18-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── groupby_multi_single_reducer3-2-8603afa3bf3deeda532fc69b7df49e09 │ │ │ ├── groupby_multi_single_reducer3-3-2ab5cc10c0b37e7cf3c0d33fdc39b628 │ │ │ ├── groupby_multi_single_reducer3-4-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── groupby_multi_single_reducer3-5-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── groupby_multi_single_reducer3-6-36e81eba0a6a42532d8ee147086d668a │ │ │ ├── groupby_multi_single_reducer3-7-59b2c947e136092e7ca5019c96a9994b │ │ │ ├── groupby_multi_single_reducer3-8-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── groupby_multi_single_reducer3-9-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── groupby_neg_float-0-dd44874fbefeee1ed0a0dd8bfbab96eb │ │ │ ├── groupby_neg_float-1-4a435e268a327404f75725b82a32ee03 │ │ │ ├── groupby_ppd-0-4b116ec2d8fb55c52b7b0d248c616ae2 │ │ │ ├── groupby_ppd-1-db7b1db8f5e61f0fa78d2874e4d72d9d │ │ │ ├── groupby_ppd-2-d286410aa1d5f5c8d91b863a6d6e29c5 │ │ │ ├── groupby_ppr-0-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── groupby_ppr-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── groupby_ppr-2-1c0aa77190a5b3e1895e58cfbe7467a9 │ │ │ ├── groupby_ppr-3-e5121a2b8210b2e4f8b1bfbf0a044486 │ │ │ ├── groupby_ppr-4-d4faa22fc1ec8cfc8ab21474841d415a │ │ │ ├── groupby_ppr-5-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── groupby_sort_10-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_10-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_10-10-b4e225bc4787d7718bae6f00d8addfe2 │ │ │ ├── groupby_sort_10-11-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_10-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_10-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_10-4-475d50465b23adfb70e67122425ede9e │ │ │ ├── groupby_sort_10-5-91f5326fe696124d862dfcfb72de2bf4 │ │ │ ├── groupby_sort_10-6-7da6ce8e3115f054ce532c26fb19bb44 │ │ │ ├── groupby_sort_10-7-b4e225bc4787d7718bae6f00d8addfe2 │ │ │ ├── groupby_sort_10-8-2c37a0e69aca38f2ce9db4c0aaf94db7 │ │ │ ├── groupby_sort_10-9-aed4b33d1aeb64e88cf36e29f8d8b6c │ │ │ ├── groupby_sort_2-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_2-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_2-10-5032dd0941fab4871eefd79f7e4a5c86 │ │ │ ├── groupby_sort_2-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_2-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_2-4-7dc6959cca820ea825e6567e1b152088 │ │ │ ├── groupby_sort_2-5-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_2-6-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_2-7-2238ae1cfb52dfd4f9e7b1d0e2b2c0f8 │ │ │ ├── groupby_sort_2-8-4d64b6bb15f6b31e47d52df53a1d9414 │ │ │ ├── groupby_sort_2-9-30377eb1022ca1f4f5201f8897dff9ed │ │ │ ├── groupby_sort_3-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_3-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_3-10-4bf8dba6e66e733423a3408d61897926 │ │ │ ├── groupby_sort_3-11-2437764cdf86cd2d67430bd323346086 │ │ │ ├── groupby_sort_3-12-bc5b02bd034ead563d39d2685087005e │ │ │ ├── groupby_sort_3-13-1f1638d495fd67ab40bbd2a03ee4ddd │ │ │ ├── groupby_sort_3-14-1c8def3eb5fc590046d9cdd02d1cbf3f │ │ │ ├── groupby_sort_3-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_3-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_3-4-74ba824287893d3aaa1cdd957d472729 │ │ │ ├── groupby_sort_3-5-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_3-6-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_3-7-fa27a0ebfb1024248031f281b5e320d8 │ │ │ ├── groupby_sort_3-8-5ce0d81bbee5bbab19194535b4b05b6 │ │ │ ├── groupby_sort_3-9-37a53e292752d1a4caff70e64c5cdfbd │ │ │ ├── groupby_sort_4-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_4-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_4-10-f3f94c4814c3bff60a0b06edf0c884bd │ │ │ ├── groupby_sort_4-11-dfd54cb0f947152bcf66af1eaa221eb2 │ │ │ ├── groupby_sort_4-12-1f082ad7217ad620063b58887b9b922f │ │ │ ├── groupby_sort_4-13-46c4a3675c8de0510b648856a193f3e7 │ │ │ ├── groupby_sort_4-14-75d59344b6114c0bb20d5eac301c2170 │ │ │ ├── groupby_sort_4-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_4-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_4-4-40891a8b7f896b11de173835c51aca4f │ │ │ ├── groupby_sort_4-5-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_4-6-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_4-7-8f552bff84cdc75d7a7e1e12f67c240e │ │ │ ├── groupby_sort_4-8-91aa8f7c6e9b0d8fa11277061c00f6ef │ │ │ ├── groupby_sort_4-9-ebc7ac3b2dfdb958d161cd7c8f947a72 │ │ │ ├── groupby_sort_5-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_5-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_5-10-4bf8dba6e66e733423a3408d61897926 │ │ │ ├── groupby_sort_5-11-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_5-12-42f4d08dc197e04234d95e08f6ed1e2f │ │ │ ├── groupby_sort_5-13-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_5-14-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_5-15-e9baee9e98db00b9277dae33097aab82 │ │ │ ├── groupby_sort_5-16-37a53e292752d1a4caff70e64c5cdfbd │ │ │ ├── groupby_sort_5-17-4bf8dba6e66e733423a3408d61897926 │ │ │ ├── groupby_sort_5-18-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_5-19-2e441f92547a956942f4451e943bf5cf │ │ │ ├── groupby_sort_5-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_5-20-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_5-21-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_5-22-70a6c959960c299db2b961dffaa2628d │ │ │ ├── groupby_sort_5-23-8dce8ffad6523bbe076b968e243f094f │ │ │ ├── groupby_sort_5-24-1f1638d495fd67ab40bbd2a03ee4ddd │ │ │ ├── groupby_sort_5-25-1c8def3eb5fc590046d9cdd02d1cbf3f │ │ │ ├── groupby_sort_5-26-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_5-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_5-4-f3697ac93bcda24a9d7593b703b312e7 │ │ │ ├── groupby_sort_5-5-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_5-6-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_5-7-5219a87f995d294a0c68ae6499dba7d2 │ │ │ ├── groupby_sort_5-8-e9baee9e98db00b9277dae33097aab82 │ │ │ ├── groupby_sort_5-9-37a53e292752d1a4caff70e64c5cdfbd │ │ │ ├── groupby_sort_6-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_6-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_6-10-788b62269990c43aa3cb1847f99b3343 │ │ │ ├── groupby_sort_6-11-8c28fe3adff3cd106e88d7984ef5fe52 │ │ │ ├── groupby_sort_6-12-f3f94c4814c3bff60a0b06edf0c884bd │ │ │ ├── groupby_sort_6-13-73805f987b3b2384352c5dd5201f1b29 │ │ │ ├── groupby_sort_6-14-5574207f68aac30a893785c50c735864 │ │ │ ├── groupby_sort_6-15-f3f94c4814c3bff60a0b06edf0c884bd │ │ │ ├── groupby_sort_6-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_6-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_6-4-659bc2cd87fd74fef5ed50d795e8aa1e │ │ │ ├── groupby_sort_6-5-c0ea81b686236d661166912040a16ea7 │ │ │ ├── groupby_sort_6-6-788b62269990c43aa3cb1847f99b3343 │ │ │ ├── groupby_sort_6-7-8c28fe3adff3cd106e88d7984ef5fe52 │ │ │ ├── groupby_sort_6-8-f3f94c4814c3bff60a0b06edf0c884bd │ │ │ ├── groupby_sort_6-9-591e03d1cfc10821a601498df1ed6675 │ │ │ ├── groupby_sort_7-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_7-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_7-10-4bf8dba6e66e733423a3408d61897926 │ │ │ ├── groupby_sort_7-11-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_7-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_7-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_7-4-253f1f4f2e4153a4a9358d268f8352e7 │ │ │ ├── groupby_sort_7-5-43e94a517107a5bcf6fee78e6c88a1cc │ │ │ ├── groupby_sort_7-6-137e81fded2b36969bf71279d7ffee34 │ │ │ ├── groupby_sort_7-7-5219a87f995d294a0c68ae6499dba7d2 │ │ │ ├── groupby_sort_7-8-289632719165e6e8182ebd8f5f766b7b │ │ │ ├── groupby_sort_7-9-6e36549828003492627aa5e96a63d3a2 │ │ │ ├── groupby_sort_8-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_8-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_8-10-d3a2d251675f7bd7a196d2b8345b36d5 │ │ │ ├── groupby_sort_8-11-bd99462ed878bf4bec74b3cb9132908d │ │ │ ├── groupby_sort_8-12-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_8-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_8-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_8-4-14283ed438d96ad881025b969c8fb69f │ │ │ ├── groupby_sort_8-5-43e94a517107a5bcf6fee78e6c88a1cc │ │ │ ├── groupby_sort_8-6-137e81fded2b36969bf71279d7ffee34 │ │ │ ├── groupby_sort_8-7-8188c7bcb9ead25f8c27af7def87218d │ │ │ ├── groupby_sort_8-8-bd99462ed878bf4bec74b3cb9132908d │ │ │ ├── groupby_sort_8-9-8e06b51e940e956f14a8c7679c3d423a │ │ │ ├── groupby_sort_9-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_9-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_9-10-4d9341036906853bb9a1641f5e0179b3 │ │ │ ├── groupby_sort_9-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_9-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_9-4-14283ed438d96ad881025b969c8fb69f │ │ │ ├── groupby_sort_9-5-43e94a517107a5bcf6fee78e6c88a1cc │ │ │ ├── groupby_sort_9-6-137e81fded2b36969bf71279d7ffee34 │ │ │ ├── groupby_sort_9-7-c762061ecb1eea7ac218809b9e49900c │ │ │ ├── groupby_sort_9-8-fba2dc1329046ee81e2dbf16b92abc27 │ │ │ ├── groupby_sort_9-9-feec69facdc973a0ff78455f766845c │ │ │ ├── groupby_sort_test_1-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── groupby_sort_test_1-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── groupby_sort_test_1-2-fc30020d09151dc29be807795ad9475e │ │ │ ├── groupby_sort_test_1-3-fffea659b633b1f269b38556a7f54634 │ │ │ ├── groupby_sort_test_1-4-8e06b51e940e956f14a8c7679c3d423a │ │ │ ├── groupby_sort_test_1-5-e906be6d27c9dfcffd4af171541639ad │ │ │ ├── groupby_sort_test_1-6-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── groupby_sort_test_1-7-b6c452a800ff333aacb863bb3243c15b │ │ │ ├── groupby_sort_test_1-8-c0ea81b686236d661166912040a16ea7 │ │ │ ├── groupby_sort_test_1-9-4d3e8128fb29c232b984f41ed4e78794 │ │ │ ├── hash-0-a658b129316d666d4b01c1581eed1c1f │ │ │ ├── having no references-0-d2de3ba23759d25ef77cdfbab72cbb63 │ │ │ ├── having-0-57f3f26c0203c29c2a91a7cca557ce55 │ │ │ ├── having-1-ef81808faeab6d212c3cf32abfc0d873 │ │ │ ├── having-2-a2b4f52cb92f730ddb912b063636d6c1 │ │ │ ├── having-3-3fa6387b6a4ece110ac340c7b893964e │ │ │ ├── having-4-e9918bd385cb35db4ebcbd4e398547f4 │ │ │ ├── having-5-4a0c4e521b8a6f6146151c13a2715ff │ │ │ ├── having-6-9f50df5b5f31c7166b0396ab434dc095 │ │ │ ├── having-7-5ad96cb287df02080da1e2594f08d83e │ │ │ ├── having-8-4aa7197e20b5a64461ca670a79488103 │ │ │ ├── having-9-a79743372d86d77b0ff53a71adcb1cff │ │ │ ├── implicit_cast1-0-e3d2bd2cc5a4d5d794f9bf29927f2296 │ │ │ ├── implicit_cast1-1-66f185b6fdccddba498c463641e7dc7a │ │ │ ├── implicit_cast1-2-6871be041d36ea813e1b2f331e3747f4 │ │ │ ├── index_serde-0-db64b724719d27c7f0db4f51f5c4edaa │ │ │ ├── index_serde-1-6560d12b69d55e5297a145ebc4bb0cb3 │ │ │ ├── index_serde-10-c85e061ea9c5b90ca69b7450faad14b6 │ │ │ ├── index_serde-11-123301a057d4a46072d0431e00e20c4b │ │ │ ├── index_serde-12-309e916d683a1a12ab62565697cb0046 │ │ │ ├── index_serde-13-d590fd7cb9d433143de490d75686dd4 │ │ │ ├── index_serde-2-f92d6c66d21791c11d2a822df04c1b63 │ │ │ ├── index_serde-3-ebab588c84a7a29f03b41dcd98132229 │ │ │ ├── index_serde-4-afcf2a156ccd4f79a0489b4593908d79 │ │ │ ├── index_serde-5-d7547751c37375a9238043bbe250e716 │ │ │ ├── index_serde-6-e6ff4b23b7f102e359afb4d53a1dedc3 │ │ │ ├── index_serde-7-c9d7dcde469d3b9a66965a64dd15e4ae │ │ │ ├── index_serde-8-3b03210f94ec40db9ab02620645014d1 │ │ │ ├── index_serde-9-35f48c7d6fa164bb84643657bc9280a8 │ │ │ ├── innerjoin-0-43d53504df013e6b35f81811138a167a │ │ │ ├── innerjoin-1-f1293ebf768eb04f2f0bfe6297c4509e │ │ │ ├── innerjoin-2-6c0cafe1d94c0acfe2d09afd0289df75 │ │ │ ├── innerjoin-3-dec6031cdf20e07dd1cd70e3741dc330 │ │ │ ├── innerjoin-4-35c7611180562dcd9dab834f41654095 │ │ │ ├── innerjoin-5-5eb553ac988b409ad2d96cf6cd395d9a │ │ │ ├── innerjoin-6-17c49c593f6160e096b30dfee7b643ce │ │ │ ├── innerjoin-7-b42ecd0ee90bd28441c41fab4e36fe78 │ │ │ ├── innerjoin-8-b125c27acd6a6cacbde1f7587df2fce9 │ │ │ ├── innerjoin-9-326eeac56676d78fe489c464cddb526b │ │ │ ├── inoutdriver-0-47981488ab51ed3cc6c335f5cf703908 │ │ │ ├── inoutdriver-1-b2f337566a5075f3e3e81335008d95d3 │ │ │ ├── input-0-42022446607cfbe8a64d8fd7b9898ce7 │ │ │ ├── input-1-6558e385bb08991302a72076dd7b7ff5 │ │ │ ├── input0-0-fb47f8a8a8e3213f3fe47825a556c593 │ │ │ ├── input0-1-efefd4364cd2790447fb0f908e87501f │ │ │ ├── input1-0-28c9f2913833d6911f22e2e2e8c60f68 │ │ │ ├── input1-1-8aaad4ee49c9bdf7b34642cc75f6a1a0 │ │ │ ├── input1-2-d3aa54d5436b7b59ff5c7091b7ca6145 │ │ │ ├── input10-0-acdd72fda64c5463ce29f31020012d42 │ │ │ ├── input10-1-6970b6d2d451612b59fccbfd7ec68f74 │ │ │ ├── input10-2-73f00da5cfc254745d1d80f913eb6449 │ │ │ ├── input11-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── input11-1-3e66f12ae780a85721fa21c42fb3c8fb │ │ │ ├── input11-2-24fe55bae88ad4a8e240376d012bc491 │ │ │ ├── input11-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input11_limit-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── input11_limit-1-f2c43fcadcfca0c8c5cdd0b29c47a921 │ │ │ ├── input11_limit-2-47fdba9764a8851379e2ed7e16c54583 │ │ │ ├── input11_limit-3-8a0c68a4f7386ff214db5d9eed0876d5 │ │ │ ├── input12-0-9b141c1e5917ca82c6bc36a9a2950a1e │ │ │ ├── input12-1-2b9ccaa793eae0e73bf76335d3d6880 │ │ │ ├── input12-10-4d9eb316259a8e7ed6627bc27a639f7c │ │ │ ├── input12-2-bab89dfffa77258e34a595e0e79986e3 │ │ │ ├── input12-3-5186c4f54bcc1d9a2afb953c8dd5d8d7 │ │ │ ├── input12-4-f69ce1f5b3e0e77d1c487877580e6a23 │ │ │ ├── input12-5-d83ffe497d7f7a8f72a6844dc6dad3cf │ │ │ ├── input12-6-f6ae011490e0c8c037927767ad966ce4 │ │ │ ├── input12-7-16da1c1293626b943343443368679e9c │ │ │ ├── input12-8-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input12-9-3d08dc27c1a133c2497fc554c0d169bd │ │ │ ├── input12_hadoop20-0-2b9ccaa793eae0e73bf76335d3d6880 │ │ │ ├── input12_hadoop20-1-bab89dfffa77258e34a595e0e79986e3 │ │ │ ├── input12_hadoop20-2-743c24cd29161d31a16ec446bd709d92 │ │ │ ├── input12_hadoop20-3-f69ce1f5b3e0e77d1c487877580e6a23 │ │ │ ├── input12_hadoop20-4-d83ffe497d7f7a8f72a6844dc6dad3cf │ │ │ ├── input12_hadoop20-5-f6ae011490e0c8c037927767ad966ce4 │ │ │ ├── input12_hadoop20-6-16da1c1293626b943343443368679e9c │ │ │ ├── input12_hadoop20-7-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input12_hadoop20-8-3d08dc27c1a133c2497fc554c0d169bd │ │ │ ├── input12_hadoop20-9-4d9eb316259a8e7ed6627bc27a639f7c │ │ │ ├── input14-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── input14-1-d0a1caeeeb79580713b7ecc28543f74a │ │ │ ├── input14-2-1d791beabaa5288ea2fcf6b3675eda26 │ │ │ ├── input14-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input15-0-1570712216ce86428ee39974242ae961 │ │ │ ├── input15-1-86edc12357bf278d5e601a654358c32f │ │ │ ├── input15-2-ae5e0fbdf88ecca2c7d67df1ad141919 │ │ │ ├── input19-0-a8eaa79d3a2762cdb263bc822d62df3a │ │ │ ├── input19-1-f32df514de8156b5f5b435eea2c9be40 │ │ │ ├── input19-2-5a804e02e4419e785d15e7f39d6c5730 │ │ │ ├── input1_limit-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── input1_limit-1-f69ce1f5b3e0e77d1c487877580e6a23 │ │ │ ├── input1_limit-2-c1d996fc96189d323f6af180708abc12 │ │ │ ├── input1_limit-3-a4a7e1c4b4482e1063c00c32d11cf1e │ │ │ ├── input1_limit-4-8a0c68a4f7386ff214db5d9eed0876d5 │ │ │ ├── input1_limit-5-eaaf713833e28a803c798562c7d6cd23 │ │ │ ├── input2-0-eaf4ec8905774e4be6ea3fa4f32a456c │ │ │ ├── input2-1-e0efeda558cd0194f4764a5735147b16 │ │ │ ├── input2-2-aa9ab0598e0cb7a12c719f9b3d98dbfd │ │ │ ├── input2-3-45b9f786f64afa5e039d1856fe926649 │ │ │ ├── input2-4-235f92683416fab031e6e7490487b15b │ │ │ ├── input2-5-9c36cac1372650b703400c60dd29042c │ │ │ ├── input2-6-4a6b9674c126337f71834f11613f996d │ │ │ ├── input2-7-9c36cac1372650b703400c60dd29042c │ │ │ ├── input2-8-28c3fc507cd2e02a3a39331fc9c95334 │ │ │ ├── input2-9-48bf8c06ed0a264d0863613fe79795e1 │ │ │ ├── input21-0-7f40c525398953892ffd6283f54ba427 │ │ │ ├── input21-1-c45ad493e95150b580be778da6065f36 │ │ │ ├── input21-2-a4b3aeb45ae0cf38777e126faed0eff7 │ │ │ ├── input21-3-9809b74435cbaedef0dc6e6b88b180fe │ │ │ ├── input22-0-b9cd4041ca510639838a97376747b498 │ │ │ ├── input22-1-b663ec84da3f9d9b9594ea2da81b1442 │ │ │ ├── input22-2-10e46b53620b6b05019da4e58f53e6c3 │ │ │ ├── input22-3-8285c1934441b12f6c016e13cb410e79 │ │ │ ├── input23-0-c983ab8049996ad5e1e0296b51ae81cf │ │ │ ├── input23-1-c8e32187d09172eb32b0480fcd28cccb │ │ │ ├── input24-0-f8116598acadb7589ae02b13b65e1ad8 │ │ │ ├── input24-1-f57485de80ad64f9931bf92514fa1 │ │ │ ├── input24-2-3fc20939000a5324a928feeb673a1ee2 │ │ │ ├── input24-3-3189f3b2990de94619b9cb583d9dd3c5 │ │ │ ├── input25-0-f8116598acadb7589ae02b13b65e1ad8 │ │ │ ├── input25-1-f57485de80ad64f9931bf92514fa1 │ │ │ ├── input25-2-74a4b9d59ee26b650f567c07e9103b66 │ │ │ ├── input25-3-d4940dd537ae72d234ffea23f8f0b103 │ │ │ ├── input25-4-72c74c55dd7d85d194448e9c58488938 │ │ │ ├── input26-0-1b6e9e73dd7ee60644c0997b21f48430 │ │ │ ├── input26-1-8272225744e83ba4cbe158a5c113fce3 │ │ │ ├── input28-0-b85d5edb4640c4b154e91e9a1beeef8a │ │ │ ├── input28-1-f57485de80ad64f9931bf92514fa1 │ │ │ ├── input28-2-e88e8d960eeb128fbc6642274780ce4c │ │ │ ├── input28-3-a3da4a5ba73e312a8adafc1bc8a0f930 │ │ │ ├── input2_limit-0-44591b07e007def036cea6c61a3f0a7f │ │ │ ├── input2_limit-1-fed7e0bb996623da7dd17793e835f785 │ │ │ ├── input4-0-b9cd4041ca510639838a97376747b498 │ │ │ ├── input4-1-7ce0bc5e5feeb09bf3fc139e102fb00e │ │ │ ├── input4-2-b663ec84da3f9d9b9594ea2da81b1442 │ │ │ ├── input4-3-d9280be6c9dd1e2263f8d50f0f43a486 │ │ │ ├── input4-4-271b04e0fbee2ee81bae21dcb46d55e4 │ │ │ ├── input40-0-37e74908fd43254141ae3664f13a48d │ │ │ ├── input40-1-a8adb8ae1d13607851431a1baf7578ba │ │ │ ├── input40-2-e7ab3c9244fcfda76061b4153d796e93 │ │ │ ├── input40-3-12f634800ffae17942ddd789a01af227 │ │ │ ├── input40-4-fdeea6b676c670b17c8d91e24a97a127 │ │ │ ├── input40-5-ccdc9c87a8fdbeee0fa48927f9700361 │ │ │ ├── input40-6-6651f53efc5d03ed2d43b9d7aecc0002 │ │ │ ├── input40-7-ccdc9c87a8fdbeee0fa48927f9700361 │ │ │ ├── input41-0-763ab5853bff619e6525c01e46b2a923 │ │ │ ├── input41-1-8112b3a278e8337dbd6f017ae178658b │ │ │ ├── input41-2-61812b3093413d09f0fd2372c61f7d53 │ │ │ ├── input41-3-526399455dc5ecd4ea9f676b09fafeee │ │ │ ├── input49-0-2bd546beeb607da5b925ffbea20a741c │ │ │ ├── input49-1-e2b5acbef6ef09cb3eecdb0ce2729e8d │ │ │ ├── input49-2-d56860e68d333bb6132ef5ed0327eb1 │ │ │ ├── input49-3-4b0fff4bd5c63666ccc22b07a521b7b0 │ │ │ ├── input4_cb_delim-0-f8e975c0fc126982e8e70cc30d2b6367 │ │ │ ├── input4_cb_delim-1-353d2238b781a117888a67bb7b2b2537 │ │ │ ├── input4_cb_delim-2-e52787bf798a941c854eb09d75efe617 │ │ │ ├── input6-0-659e06570690cceeb3f37e10e855d2ea │ │ │ ├── input6-1-21149162906e31964a328b6cb2d5286e │ │ │ ├── input6-2-9601ace6dce45dc8d6281cc248c9e28c │ │ │ ├── input6-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input7-0-8daa7823607b82336736a9d4f9a2ce45 │ │ │ ├── input7-1-bb25de1b9a7791ec5609303bab350da0 │ │ │ ├── input7-2-c740098a289f9a4267d26fc10347a0dc │ │ │ ├── input7-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input8-0-584fc8ceef39e1e1333ebaeec3e9e7fa │ │ │ ├── input8-1-c9f9239e73b04fc5c0e0219f438ceefa │ │ │ ├── input8-2-4a4cb89ba45d26bb3dd73e44620578ba │ │ │ ├── input8-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input9-0-8cc1539c21d92af8ea8c1431b0e3d85 │ │ │ ├── input9-1-b30105391cb53915997a84ca3137bd0a │ │ │ ├── input9-2-171ea277f05a642699a0f91bacffccd8 │ │ │ ├── input9-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input_limit-0-b2b4b45519484c8bac49d07debf678b9 │ │ │ ├── input_limit-1-77d7012bc901b0a9bcf9dae500ae2034 │ │ │ ├── input_part0-0-5f2f3118b9f61ac610b2d76f470e3e27 │ │ │ ├── input_part0-1-1aa1486a207bedc275035acc3b37cbdb │ │ │ ├── input_part1-0-55f89c73a00f0f23ee04239ad9fc909 │ │ │ ├── input_part1-1-593e11f2ca748f3ae6b8fdf5da435229 │ │ │ ├── input_part1-2-4153379704a43162abf9dbdbd79a92bc │ │ │ ├── input_part1-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── input_part10-0-77d7f7c938d7827a2135d9391376a518 │ │ │ ├── input_part10-1-35f67c0112026170d015b5f80a254bde │ │ │ ├── input_part10-2-40069c199502c2724ac2a2733f964248 │ │ │ ├── input_part10-3-48b242bc305c9bf879e083fa11edc967 │ │ │ ├── input_part10-4-d0ba28297a8b73569d93605aa890aa09 │ │ │ ├── input_part10_win-0-93c438f3bbfa5c46514f0ab6b83a59bf │ │ │ ├── input_part10_win-1-35f67c0112026170d015b5f80a254bde │ │ │ ├── input_part10_win-2-40069c199502c2724ac2a2733f964248 │ │ │ ├── input_part10_win-3-48b242bc305c9bf879e083fa11edc967 │ │ │ ├── input_part10_win-4-d0ba28297a8b73569d93605aa890aa09 │ │ │ ├── input_part2-0-55f89c73a00f0f23ee04239ad9fc909 │ │ │ ├── input_part2-1-5fde770f3a672878b62d7c2e9e9a8f8e │ │ │ ├── input_part2-2-a8684c5574f90c3db2fc8a269a7556cd │ │ │ ├── input_part2-3-fcb06513e757d4bf929ff681cb9f02b1 │ │ │ ├── input_part2-4-93c97e1760e0d41b3791d6f08010a665 │ │ │ ├── input_part2-5-9d0992a91951e6e4242b5b4c38d4e861 │ │ │ ├── input_part3-0-aed975ebb2a3dfee3f8747c00ea2c4ff │ │ │ ├── input_part3-1-ba5256285fb22a43b491253a2d519730 │ │ │ ├── input_part4-0-6c73b8b3f885b8fe0e61a7111f5cc4ef │ │ │ ├── input_part4-1-88be7d93e9a03ea76085111c18d437a5 │ │ │ ├── input_part5-0-679bf51b7de8df94fd2928744e887e3b │ │ │ ├── input_part5-1-705301f0bf4fe9758e9f919d129dbc7c │ │ │ ├── input_part5-2-d678533566fba4b922f01284538ca484 │ │ │ ├── input_part5-3-e4419c33287ca1f48a43f61cca5b5928 │ │ │ ├── input_part6-0-6ec3d5a634d8c011f32a0277e654ae6d │ │ │ ├── input_part6-1-9ffee7a86f484eab399266efa6e086f6 │ │ │ ├── input_part7-0-14448a12627b8bccf6828032f938f39e │ │ │ ├── input_part7-1-affad4cedcd29bb136bc477fc07e6ea0 │ │ │ ├── input_part8-0-f60652796af548135f9e104b456840e3 │ │ │ ├── input_part8-1-60b409a520999ba50e8b7c6e30de3474 │ │ │ ├── input_part9-0-726907a7cf62f5a79466caa0fa6eca01 │ │ │ ├── input_part9-1-e60c60afc073367464898b8396e8f643 │ │ │ ├── input_testsequencefile-0-dd959af1968381d0ed90178d349b01a7 │ │ │ ├── input_testsequencefile-1-ddbb8d5e5dc0988bda96ac2b4aec8f94 │ │ │ ├── input_testsequencefile-2-186e4009966778e765b18d6476cf5abf │ │ │ ├── input_testsequencefile-3-d0fade04b658b0dc0caf3fe4b2d5d432 │ │ │ ├── input_testsequencefile-4-8ebe479eca517e80bf0348a1b3a89f42 │ │ │ ├── input_testsequencefile-5-25715870c569b0f8c3d483e3a38b3199 │ │ │ ├── input_testsequencefile-6-6716fa5aec125f0f8e9520e4318f71b9 │ │ │ ├── inputddl1-0-52f161c97a2a02494d26ee0737b28364 │ │ │ ├── inputddl1-1-dfe05b7247284b326f39481b3d66a0c3 │ │ │ ├── inputddl1-2-b516db5218781d89aebd2e4813ea3660 │ │ │ ├── inputddl2-0-4519aea06db13ec6780f60b4d101d262 │ │ │ ├── inputddl2-1-f526507cae3cad09c69d20c7f0e36abe │ │ │ ├── inputddl2-2-7c1c0606b5ea8a1c90d46fe221993b57 │ │ │ ├── inputddl3-0-a14253f6c752c9f5e9f56875152f8353 │ │ │ ├── inputddl3-1-f066827dd440213f306ab7d680bc8526 │ │ │ ├── inputddl3-2-73f945a673d2e388847c317f683f160c │ │ │ ├── inputddl4-0-2f5570984afde1a30ff2f794d63d6ab3 │ │ │ ├── inputddl4-1-dd94576788fa50ebcf950cdf837fbcf6 │ │ │ ├── inputddl4-2-7fdf00ff5c22ae284728e0f035396865 │ │ │ ├── inputddl5-0-ebbf2aec5f76af7225c2efaf870b8ba7 │ │ │ ├── inputddl5-1-2691407ccdc5c848a4ba2aecb6dbad75 │ │ │ ├── inputddl5-2-ca2faacf63dc4785f8bfd2ecc397e69b │ │ │ ├── inputddl5-3-4f28c7412a05cff89c0bd86b65aa7ce │ │ │ ├── inputddl5-4-bd7e25cff73f470d2e2336876342b783 │ │ │ ├── inputddl6-0-baa412d895c4fc57d40b338944a0ecd8 │ │ │ ├── inputddl6-1-572c1abb70f09726d1ba77bdc884597b │ │ │ ├── inputddl6-2-3a4def4b370f75c5fcc1174626490363 │ │ │ ├── inputddl6-3-e81b962986706e1c16f059b407e3f05c │ │ │ ├── inputddl6-4-5855e2998e26f63e927854afa86c1f03 │ │ │ ├── inputddl6-5-47e6a8d33932cb014830812e1f7b1f94 │ │ │ ├── inputddl6-6-6eac06a114fe33c1278d47ad8652fe68 │ │ │ ├── inputddl6-7-47e6a8d33932cb014830812e1f7b1f94 │ │ │ ├── inputddl6-8-f9e6ee98eb448f9ab68fa77bea027aa5 │ │ │ ├── inputddl6-9-2164df0b7eab73cd8c4a553a762028e1 │ │ │ ├── inputddl7-0-6a30e2d3fc23ec0c18513265bd8c987f │ │ │ ├── inputddl7-1-7195712efb4910294f63303ebce24453 │ │ │ ├── inputddl7-10-7c9248b56948716913d332bd712d69bd │ │ │ ├── inputddl7-11-6e1f1709d770ed76aee6ff5f76856e63 │ │ │ ├── inputddl7-12-2c56d4a781242b0521f82bb0d2cd277 │ │ │ ├── inputddl7-13-45059a21c202b4658285738ee62a018a │ │ │ ├── inputddl7-14-30c87bc734c2afa4fea0facdf7279145 │ │ │ ├── inputddl7-15-fed9badc255db68c3ed1cd1446d9fbe │ │ │ ├── inputddl7-2-7bc7f4f4a29dc0721ad4bb6fb9b64291 │ │ │ ├── inputddl7-3-b44cf61cbfeb5a4ddf5acbff1429b466 │ │ │ ├── inputddl7-4-68715ba2c11220be62394c86453e6d54 │ │ │ ├── inputddl7-5-e3c5d1248a06e6b33b15fc6ec8c67f68 │ │ │ ├── inputddl7-6-a590512af0ed021d33e2d71b7932a20a │ │ │ ├── inputddl7-7-59dd2d2556769e19bdc0a444f40f8a71 │ │ │ ├── inputddl7-8-495dc87b0bde752c890f213ff9531508 │ │ │ ├── inputddl7-9-c943e781fb448aea5467251ee208fbac │ │ │ ├── inputddl8-0-6de6ae6cbb97de8a2d5674b59a154cf3 │ │ │ ├── inputddl8-1-c70f2d2544633366b76b92bcff18e995 │ │ │ ├── insert into and insert overwrite-0-2e2de36571343c0ebaf02c0c0c61ba8c │ │ │ ├── insert into and insert overwrite-1-548d5a45ef20e066df145944dce3415a │ │ │ ├── insert into and insert overwrite-2-77baf70da8adf8b4b82d076fee937fe1 │ │ │ ├── insert into and insert overwrite-3-b9002c1d71895be765575b62656d1928 │ │ │ ├── insert into and insert overwrite-4-3b8e0155870264d89d275a1d5bd345d0 │ │ │ ├── insert into and insert overwrite-5-b9002c1d71895be765575b62656d1928 │ │ │ ├── insert table with db name-0-a253b1ed35dbf503d1b8902dacbe23ac │ │ │ ├── insert table with db name-1-4f5be7056d8dc15cf2334a7cc146a636 │ │ │ ├── insert table with db name-2-a81aea129f78bc05305b8e887ee88f86 │ │ │ ├── insert table with db name-3-ce780d068b8d24786e639e361101a0c7 │ │ │ ├── insert table with db name-4-afd6e46b6a289c3c24a8eec75a94043c │ │ │ ├── insert table with generator with column name-0-7ac701cf43e73e9e416888e4df694348 │ │ │ ├── insert table with generator with column name-1-5cdf9d51fc0e105e365d82e7611e37f3 │ │ │ ├── insert table with generator with column name-2-f963396461294e06cb7cafe22a1419e4 │ │ │ ├── insert table with generator with multiple column names-0-46bdb27b3359dc81d8c246b9f69d4b82 │ │ │ ├── insert table with generator with multiple column names-1-cdf6989f3b055257f1692c3bbd80dc73 │ │ │ ├── insert table with generator with multiple column names-2-ab3954b69d7a991bc801a509c3166cc5 │ │ │ ├── insert table with generator without column name-0-7ac701cf43e73e9e416888e4df694348 │ │ │ ├── insert table with generator without column name-1-26599718c322ff4f9740040c066d8292 │ │ │ ├── insert table with generator without column name-2-f963396461294e06cb7cafe22a1419e4 │ │ │ ├── insert1-0-7faa9807151781e4207103aa568e321c │ │ │ ├── insert1-1-91d7b05c9024bff60b55f415cbeacc8b │ │ │ ├── insert1-10-64f83491a8fe675ef3a4a9a474ac0439 │ │ │ ├── insert1-11-6f2797b6f81943d3b53b8d247ae8512b │ │ │ ├── insert1-12-7a3c0a3f06484c912b9e951d8a2d8ac6 │ │ │ ├── insert1-13-42b03f938894fdafc7fff640711a9b2f │ │ │ ├── insert1-14-e021dfb28597811870c03b3242972927 │ │ │ ├── insert1-15-c7fca497a4580b54a0a13b3b72da5d7c │ │ │ ├── insert1-16-7a9e67189d3d4151f23b12c22bde06b5 │ │ │ ├── insert1-17-5528e36b3b0f5b14313898cc45f9c23a │ │ │ ├── insert1-18-16d78fba2d86277bc2f804037cc0a8b4 │ │ │ ├── insert1-19-62518ff6810db9cdd8926702192a206b │ │ │ ├── insert1-2-3f1de4475930285c3fdbe3a5ccd4e868 │ │ │ ├── insert1-20-f4dc51ad64bb8662d066a8b9003da3d4 │ │ │ ├── insert1-21-bb7624250ab556f2d40bfb8d419be487 │ │ │ ├── insert1-3-89f8a028e32fae213b575b4df4e26e9c │ │ │ ├── insert1-4-c7a68c0884785d0f5e62b287eb305d64 │ │ │ ├── insert1-5-cb87ee12092fdf05daed82485c32a285 │ │ │ ├── insert1-6-b97ba93a2c9ae671ecfc4fa95c024dda │ │ │ ├── insert1-7-a2cd0615b9e79befd9c1842516150a61 │ │ │ ├── insert1-8-5942e331621fe522fc297844046d2370 │ │ │ ├── insert1-9-5c5132707d7a4fb6e6a3de1a6719721a │ │ │ ├── insert1_overwrite_partitions-0-d5edc0daa94b33915df794df3b710774 │ │ │ ├── insert1_overwrite_partitions-1-9eb9372f4855928fae16f5fa554b3a62 │ │ │ ├── insert1_overwrite_partitions-10-ec2cef3d37146c450c60202a572f5cab │ │ │ ├── insert1_overwrite_partitions-11-8854d6001200fc11529b2e2da755e5a2 │ │ │ ├── insert1_overwrite_partitions-12-71ff68fda0aa7a36cb50d8fab0d70d25 │ │ │ ├── insert1_overwrite_partitions-13-7e4e7d7003fc6ef17bc19c3461ad899 │ │ │ ├── insert1_overwrite_partitions-14-ec2cef3d37146c450c60202a572f5cab │ │ │ ├── insert1_overwrite_partitions-15-a3b2e230efde74e970ae8a3b55f383fc │ │ │ ├── insert1_overwrite_partitions-2-8396c17a66e3d9a374d4361873b9bfe3 │ │ │ ├── insert1_overwrite_partitions-3-3876bb356dd8af7e78d061093d555457 │ │ │ ├── insert1_overwrite_partitions-4-528e23afb272c2e69004c86ddaa70ee │ │ │ ├── insert1_overwrite_partitions-5-de5d56456c28d63775554e56355911d2 │ │ │ ├── insert1_overwrite_partitions-6-3efdc331b3b4bdac3e60c757600fff53 │ │ │ ├── insert1_overwrite_partitions-7-92f6af82704504968de078c133f222f8 │ │ │ ├── insert1_overwrite_partitions-8-316cad7c63ddd4fb043be2affa5b0a67 │ │ │ ├── insert1_overwrite_partitions-9-3efdc331b3b4bdac3e60c757600fff53 │ │ │ ├── insert2_overwrite_partitions-0-5528e36b3b0f5b14313898cc45f9c23a │ │ │ ├── insert2_overwrite_partitions-1-deb504f4f70fd7db975950c3c47959ee │ │ │ ├── insert2_overwrite_partitions-10-fda2e4be738186c0938f92d5072df55a │ │ │ ├── insert2_overwrite_partitions-11-9fb177236623d1b62acff28507033436 │ │ │ ├── insert2_overwrite_partitions-12-99d5ad32bb81640cb284312841b60000 │ │ │ ├── insert2_overwrite_partitions-13-9dda06e1aae1860bd19eee97703a8217 │ │ │ ├── insert2_overwrite_partitions-14-19daabdd4c0d403c8781967248d09c53 │ │ │ ├── insert2_overwrite_partitions-15-812006e1f11e005e5029866d1cf004f6 │ │ │ ├── insert2_overwrite_partitions-2-bd042746328158822a25d711ffed18dd │ │ │ ├── insert2_overwrite_partitions-3-86653b3af59df59f225ee00ff5fc119f │ │ │ ├── insert2_overwrite_partitions-4-e81d45a5bec5642ec4b762f1c1a482af │ │ │ ├── insert2_overwrite_partitions-5-1eb5c694e5a02aa292e24a0849350108 │ │ │ ├── insert2_overwrite_partitions-6-ab49e0665a80a6b34dadc96f1d18ce26 │ │ │ ├── insert2_overwrite_partitions-7-fda2e4be738186c0938f92d5072df55a │ │ │ ├── insert2_overwrite_partitions-8-9fb177236623d1b62acff28507033436 │ │ │ ├── insert2_overwrite_partitions-9-ab49e0665a80a6b34dadc96f1d18ce26 │ │ │ ├── insert_compressed-0-ea607fbed28d20e5726f4501285d698d │ │ │ ├── insert_compressed-1-d20899578068ff4adfee5355cddca819 │ │ │ ├── insert_compressed-2-8dec751fd4148a431af064b7317f1530 │ │ │ ├── insert_compressed-3-35f4fbde823a5664fe9928a685745b35 │ │ │ ├── insert_compressed-4-5133d2457097962811a2adf0ecd9e4ef │ │ │ ├── insert_compressed-5-a60ea2e04d6bcdc99238eeb6ac6365c3 │ │ │ ├── insert_compressed-6-5133d2457097962811a2adf0ecd9e4ef │ │ │ ├── insert_compressed-7-a60ea2e04d6bcdc99238eeb6ac6365c3 │ │ │ ├── insert_compressed-8-5133d2457097962811a2adf0ecd9e4ef │ │ │ ├── insert_compressed-9-d20899578068ff4adfee5355cddca819 │ │ │ ├── join0-0-7fbd114e2fc7f55cf1421698eac39397 │ │ │ ├── join0-1-83f5e512d6058a47f92b5218781f5070 │ │ │ ├── join0-2-52055f2dce8eac4e5249d02c42c0da87 │ │ │ ├── join1-0-43d53504df013e6b35f81811138a167a │ │ │ ├── join1-1-f1293ebf768eb04f2f0bfe6297c4509e │ │ │ ├── join1-2-7b07671864bbfdc627ee794932e32b1e │ │ │ ├── join1-3-f6046c5229e3b0aa21498a3872f43b2 │ │ │ ├── join1-4-35c7611180562dcd9dab834f41654095 │ │ │ ├── join10-0-1e7a0e1d539a39ed19833e6a6d0b1644 │ │ │ ├── join10-1-73136f8e6e9ba82f75570afd15c2828d │ │ │ ├── join11-0-e2cc67c543c1209ebcd3f9048c4cb29 │ │ │ ├── join11-1-b580f87daf1763cd8c5e59ad5b271232 │ │ │ ├── join12-0-12fa53be2c0ddbcfc85212e573a46af1 │ │ │ ├── join12-1-496c8aabaf3261e8fefd7b357f2ac7f │ │ │ ├── join13-0-c4ebf24269e27919f4ba9ce3993e48f7 │ │ │ ├── join13-1-696b36d15c4358145f77c2b15b7507d5 │ │ │ ├── join14-0-c85f3dcbab496811604ea0ab84d0e995 │ │ │ ├── join14-1-9b141c1e5917ca82c6bc36a9a2950a1e │ │ │ ├── join14-2-2b9ccaa793eae0e73bf76335d3d6880 │ │ │ ├── join14-3-bab89dfffa77258e34a595e0e79986e3 │ │ │ ├── join14-4-27f1a57fbb815d169af86ae2f8305cb6 │ │ │ ├── join14-5-4c3f537b4df1ef16788a53cf65574187 │ │ │ ├── join14-6-de39302191b63d7aa8f92885b089fe2 │ │ │ ├── join14-7-4e04dbb8b2e0ee18f6cb4bd89b0ae3d3 │ │ │ ├── join14_hadoop20-0-98b7542190092fafcc8b1ad5b0024a22 │ │ │ ├── join14_hadoop20-1-2b9ccaa793eae0e73bf76335d3d6880 │ │ │ ├── join14_hadoop20-2-bab89dfffa77258e34a595e0e79986e3 │ │ │ ├── join14_hadoop20-3-4c3f537b4df1ef16788a53cf65574187 │ │ │ ├── join14_hadoop20-4-de39302191b63d7aa8f92885b089fe2 │ │ │ ├── join14_hadoop20-5-4e04dbb8b2e0ee18f6cb4bd89b0ae3d3 │ │ │ ├── join15-0-930db2823512f7f8f34cac104f2162e0 │ │ │ ├── join15-1-81d76d3bf59889b07b413b6f88772667 │ │ │ ├── join16-0-1bec3b0892d5c4a174d1b39f6d1b610c │ │ │ ├── join17-0-387dd86b1e13f788ec677a08dc162c97 │ │ │ ├── join17-1-37cef87fe56f66692799ccda8cda2e8b │ │ │ ├── join17-2-478a9f270a5d70f6f82f81e6962fb251 │ │ │ ├── join17-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join18-0-269843197b598569f4b50cbe911960a5 │ │ │ ├── join18-1-49f8ba8d43a6bb1d892ba66a812304f5 │ │ │ ├── join19-0-26ba1cd9acfcd799239da60c38e68a39 │ │ │ ├── join19-1-7e7d1f07c34dd4be5425264196201766 │ │ │ ├── join2-0-3d1692c4710db1ff716d35e921f2bcca │ │ │ ├── join2-1-87896c3f04a259b81b1cfde3eec7d64c │ │ │ ├── join2-2-d4673c03d04084b838fcd8149f59ad9a │ │ │ ├── join2-3-cac2c9e0f8601dd56822c990774e0696 │ │ │ ├── join20-0-16cda49c2b2cd0c0cdae40af4d5c900e │ │ │ ├── join20-1-9685f2d31ffe922d3ea217de32ca3049 │ │ │ ├── join20-2-222655137ca9242f063c7717acbe4c65 │ │ │ ├── join20-3-3331a020843caccf2fa32a1225c5c3a9 │ │ │ ├── join21-0-d89bb8082a39fcaf8ed23a0f5b1cb410 │ │ │ ├── join21-1-3536b7d78713e86ee67f5f6c9b88958f │ │ │ ├── join22-0-97081b5f73052a612fb391a57ad9b7b │ │ │ ├── join23-0-1fb76d3404f09a5c2b10422157c3cf5d │ │ │ ├── join23-1-91b8e7fe75a7e3ba8147c56734436681 │ │ │ ├── join24-0-721dfa03bfea05e55506c571b6c3585b │ │ │ ├── join24-1-36de83b0ed6c9fdc03661b2f65b23a3d │ │ │ ├── join24-2-d79325ef6494aa87843fdfd78de7c812 │ │ │ ├── join25-0-8934d9b821aa4b34b760f73eff56cd06 │ │ │ ├── join25-1-360b3676605ccb3d89cf555342db87af │ │ │ ├── join25-2-ef930bed933341636c71622e6f89e9e9 │ │ │ ├── join25-3-e39577008d28ddd5741d8518b92eaa94 │ │ │ ├── join25-4-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join26-0-775b1af8eae9b2250052be1b72b4086 │ │ │ ├── join26-1-10fbe6c99e93cfeafcd454261744728e │ │ │ ├── join26-2-8aa0193a2a80d4efe4c66bca19218a4d │ │ │ ├── join26-3-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join27-0-360b3676605ccb3d89cf555342db87af │ │ │ ├── join27-1-d56d8bbececcf48417b7dde9292a9cc6 │ │ │ ├── join27-2-6d139e1aa07ff8d02bdf52b409956879 │ │ │ ├── join27-3-e86808fdbd54120d1e2356f8f61c02f9 │ │ │ ├── join28-0-7f2c5c987bc8e918f7b6fc222e1abc62 │ │ │ ├── join28-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join28-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join28-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join28-4-bd4e19a3608681b0270668fe68b7d124 │ │ │ ├── join28-5-24cc9ff9485313ade08ee83ecc4c0621 │ │ │ ├── join28-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join29-0-e78402f7585b17c76c32790571d749eb │ │ │ ├── join29-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join29-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join29-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join29-4-b0524de7985cdb7b57fd995721654856 │ │ │ ├── join29-5-9e35870a3bc8224cde6b1ab322568d2 │ │ │ ├── join29-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join3-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── join3-1-4ef57a9e40b2e7fd01e1778bed71b5b2 │ │ │ ├── join3-2-e9f6d17b15064f953a588fb40aee2f90 │ │ │ ├── join3-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join30-0-54a7280ab9eed0d2e3b33df35a721b66 │ │ │ ├── join30-1-5859eba43fb180c2142035cd4c77ea4d │ │ │ ├── join30-2-194edec0592cf441617ca7caf9756baa │ │ │ ├── join30-3-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join31-0-619db2f9dd69aa236aa804cced726c9a │ │ │ ├── join31-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join31-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join31-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join31-4-34e30fa5d6f35a20561c7754197f0626 │ │ │ ├── join31-5-a2082be28be44e2bfa9a58fb45c23f07 │ │ │ ├── join31-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join32-0-775b1af8eae9b2250052be1b72b4086 │ │ │ ├── join32-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join32-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join32-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join32-4-fc6880e4e0750a3daa7fc108b72d11bb │ │ │ ├── join32-5-425c5c35b23c42254dabec49aa6613bf │ │ │ ├── join32-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join32_lessSize-0-775b1af8eae9b2250052be1b72b4086 │ │ │ ├── join32_lessSize-1-7a874b25490d3e1e186803646eb6a789 │ │ │ ├── join32_lessSize-10-e4ca54ef5e9c845b5bd7fb6b56cdc45a │ │ │ ├── join32_lessSize-11-79c0e9faf5798c465fedee25c72e7ca │ │ │ ├── join32_lessSize-12-83544f47197cccad30dd4f0ede433b8 │ │ │ ├── join32_lessSize-13-ed70124968560328930327ecb108c4e9 │ │ │ ├── join32_lessSize-14-ac014eb214f762f1a61125af1964788a │ │ │ ├── join32_lessSize-15-78edd67daa31711374b4c25faf89f77e │ │ │ ├── join32_lessSize-16-ed70124968560328930327ecb108c4e9 │ │ │ ├── join32_lessSize-17-b6bd9e2ca2bfabec16846b4a1fa3ea20 │ │ │ ├── join32_lessSize-18-f9b31c552044d8e5cc193121eb71024d │ │ │ ├── join32_lessSize-19-ed70124968560328930327ecb108c4e9 │ │ │ ├── join32_lessSize-2-24ca942f094b14b92086305cc125e833 │ │ │ ├── join32_lessSize-20-ecf04f68517b6104d9cc8995796b424 │ │ │ ├── join32_lessSize-21-f6822e1bb0b193eec397ebb9c79fbf47 │ │ │ ├── join32_lessSize-22-ed70124968560328930327ecb108c4e9 │ │ │ ├── join32_lessSize-3-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join32_lessSize-4-7f7f3daa7ff45944c3d534f9feff3bb6 │ │ │ ├── join32_lessSize-5-fc6880e4e0750a3daa7fc108b72d11bb │ │ │ ├── join32_lessSize-6-425c5c35b23c42254dabec49aa6613bf │ │ │ ├── join32_lessSize-7-e4ca54ef5e9c845b5bd7fb6b56cdc45a │ │ │ ├── join32_lessSize-8-5e277b322f831494ecd6f51a0c727c7b │ │ │ ├── join32_lessSize-9-e22030c2383aa7f16b7cf89bebb1e85 │ │ │ ├── join33-0-775b1af8eae9b2250052be1b72b4086 │ │ │ ├── join33-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join33-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join33-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join33-4-fc6880e4e0750a3daa7fc108b72d11bb │ │ │ ├── join33-5-425c5c35b23c42254dabec49aa6613bf │ │ │ ├── join33-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join34-0-775b1af8eae9b2250052be1b72b4086 │ │ │ ├── join34-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join34-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join34-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join34-4-51cc5d253befd784a9d466c0b402f47a │ │ │ ├── join34-5-abf5cf110d6a0eb85ae257768c805f39 │ │ │ ├── join34-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join35-0-1ef68e1b8dd5f69f4a5149f3ebec42b9 │ │ │ ├── join35-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── join35-2-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join35-3-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── join35-4-99cb704ccc2813400908a62571891dc7 │ │ │ ├── join35-5-60956f3307651237f52ffbe41c827c1c │ │ │ ├── join35-6-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join36-0-8934d9b821aa4b34b760f73eff56cd06 │ │ │ ├── join36-1-3aba153d62042206c0f001ea74980da │ │ │ ├── join36-2-5b1cac8ef7857d2f8c675ed6f0224471 │ │ │ ├── join36-3-c87d5b10b6ce87ac8ee2ab0d2b3755e8 │ │ │ ├── join36-4-fbe7d714e988877ebe6202a60e8ef776 │ │ │ ├── join36-5-9353d3e0b11c781f782af4013e8569e3 │ │ │ ├── join36-6-d76aff886201d223c7dbed2b0f0d5512 │ │ │ ├── join36-7-171ede21302050a33468d95e329a38a3 │ │ │ ├── join36-8-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join37-0-8934d9b821aa4b34b760f73eff56cd06 │ │ │ ├── join37-1-360b3676605ccb3d89cf555342db87af │ │ │ ├── join37-2-2310f2b8726137811543e04db98dd1db │ │ │ ├── join37-3-c4b3a85965108ad7013ac3931598af09 │ │ │ ├── join37-4-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join38-0-42e6ad674a5142d05258a2d29578e046 │ │ │ ├── join38-1-d8ba5ec8a5a0bb702958400a3b3e458f │ │ │ ├── join38-2-eacdb3417c4a563982c488812d654c9 │ │ │ ├── join38-3-22ead86c36dcd9ac9403fb52ac752046 │ │ │ ├── join38-4-53d219706847e890de1dcd369563ebef │ │ │ ├── join39-0-54e9f7924abb40d1c601de908de6f25b │ │ │ ├── join39-1-60178dec03adcbccbd4e5cae936c38f2 │ │ │ ├── join39-2-7fe3308e0a153b36c8eb21edcd3dbe96 │ │ │ ├── join39-3-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join4-0-531e91e11b3891627c2675935fda14cd │ │ │ ├── join4-1-8884a9b112b0c767aa0bd8e745bd7b21 │ │ │ ├── join4-2-dc967001beb776f3a859e9360823c361 │ │ │ ├── join4-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join40-0-d2b5e23edec42a62e61750b110ecbaac │ │ │ ├── join40-1-4b663d50fee0a8afd32cdf25c3b82de8 │ │ │ ├── join40-10-1d1f79e8e773d630f355c1a89d84b5aa │ │ │ ├── join40-11-c8c5b97a744acf897888ab2d51d33a80 │ │ │ ├── join40-12-aaddbef9069aba3ebeb310be74671cda │ │ │ ├── join40-2-507b1d9f6abbdb756a589d7bc4826251 │ │ │ ├── join40-3-4ef939dcda3b87f66c1bb3b2ebe32ec6 │ │ │ ├── join40-4-61fb097bda1751910de966d6a4a8f0b7 │ │ │ ├── join40-5-16cda49c2b2cd0c0cdae40af4d5c900e │ │ │ ├── join40-6-9685f2d31ffe922d3ea217de32ca3049 │ │ │ ├── join40-7-222655137ca9242f063c7717acbe4c65 │ │ │ ├── join40-8-3331a020843caccf2fa32a1225c5c3a9 │ │ │ ├── join40-9-6b7404af014eeb4de196577f14ef18cc │ │ │ ├── join41-0-b74d94933c6670ccc4a1ad8161185686 │ │ │ ├── join41-1-25e434b6d05e08fdd5f4d9957438917 │ │ │ ├── join41-2-e02c931c8bb07ad765d0a6cd73abc2a │ │ │ ├── join41-3-1dc98363e7da167dc45711a87ef3a988 │ │ │ ├── join41-4-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join41-5-f18ea17bcfafde311a4bdc589362e00e │ │ │ ├── join41-6-1dc98363e7da167dc45711a87ef3a988 │ │ │ ├── join5-0-531e91e11b3891627c2675935fda14cd │ │ │ ├── join5-1-76feff1282895f38b673f52acfd7429e │ │ │ ├── join5-2-b07bb1fdcd0eeeb62a8f7acb70cd2330 │ │ │ ├── join5-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join6-0-531e91e11b3891627c2675935fda14cd │ │ │ ├── join6-1-c3702956d2a1ff2bf1ae967b9f04bad3 │ │ │ ├── join6-2-bc6b6640b266ebe9b73702d3baf09c20 │ │ │ ├── join6-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join7-0-8f82881057bec4abf5a4d770a6f35838 │ │ │ ├── join7-1-1aa2f2b13c2522b0457c0dd2ceb615d8 │ │ │ ├── join7-2-56a30a1aa948bcf5ee54481897fc2208 │ │ │ ├── join7-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join8-0-531e91e11b3891627c2675935fda14cd │ │ │ ├── join8-1-13f11eaafaa42f8bdf0ed0a446f5bfa7 │ │ │ ├── join8-2-f1196bca86a749375da35f134206a8ca │ │ │ ├── join8-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join9-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── join9-1-fb3387ec28fc9d527e773c8b70bdf67a │ │ │ ├── join9-2-971c44e81ce17eb0849850b72ebd20f1 │ │ │ ├── join9-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── join_1to1-0-7ea7cf54372f262b952108113a97a294 │ │ │ ├── join_1to1-1-789b2636cfb6a08965e0bd190e419762 │ │ │ ├── join_1to1-10-a1caf8c546f519e2dfb5e17c8addf62e │ │ │ ├── join_1to1-11-ce1542ccec99ccfdc9b5c3f713ab1c0e │ │ │ ├── join_1to1-12-6081eb976b4aef2132418510756a385b │ │ │ ├── join_1to1-13-281b888188eac90c4bf670417f25cc0c │ │ │ ├── join_1to1-14-2bc944d7dcc8eba8f25794d99ea35b84 │ │ │ ├── join_1to1-15-5e48ba086f1376939535081b60f82727 │ │ │ ├── join_1to1-16-9914f44ecb6ae7587b62e5349ff60d04 │ │ │ ├── join_1to1-17-ce1542ccec99ccfdc9b5c3f713ab1c0e │ │ │ ├── join_1to1-18-6081eb976b4aef2132418510756a385b │ │ │ ├── join_1to1-19-281b888188eac90c4bf670417f25cc0c │ │ │ ├── join_1to1-2-1c35d445eca04025196ea700d02f9987 │ │ │ ├── join_1to1-20-2bc944d7dcc8eba8f25794d99ea35b84 │ │ │ ├── join_1to1-21-5e48ba086f1376939535081b60f82727 │ │ │ ├── join_1to1-22-5a065a27a36bb0ff980fa7ffef3a2600 │ │ │ ├── join_1to1-23-ce1542ccec99ccfdc9b5c3f713ab1c0e │ │ │ ├── join_1to1-24-6081eb976b4aef2132418510756a385b │ │ │ ├── join_1to1-25-281b888188eac90c4bf670417f25cc0c │ │ │ ├── join_1to1-26-2bc944d7dcc8eba8f25794d99ea35b84 │ │ │ ├── join_1to1-27-5e48ba086f1376939535081b60f82727 │ │ │ ├── join_1to1-28-a1caf8c546f519e2dfb5e17c8addf62e │ │ │ ├── join_1to1-29-ce1542ccec99ccfdc9b5c3f713ab1c0e │ │ │ ├── join_1to1-3-6228e662e573a00ed04550d049d97a3b │ │ │ ├── join_1to1-30-6081eb976b4aef2132418510756a385b │ │ │ ├── join_1to1-31-281b888188eac90c4bf670417f25cc0c │ │ │ ├── join_1to1-32-2bc944d7dcc8eba8f25794d99ea35b84 │ │ │ ├── join_1to1-33-5e48ba086f1376939535081b60f82727 │ │ │ ├── join_1to1-34-9914f44ecb6ae7587b62e5349ff60d04 │ │ │ ├── join_1to1-35-ce1542ccec99ccfdc9b5c3f713ab1c0e │ │ │ ├── join_1to1-36-6081eb976b4aef2132418510756a385b │ │ │ ├── join_1to1-37-281b888188eac90c4bf670417f25cc0c │ │ │ ├── join_1to1-38-2bc944d7dcc8eba8f25794d99ea35b84 │ │ │ ├── join_1to1-39-5e48ba086f1376939535081b60f82727 │ │ │ ├── join_1to1-4-5a065a27a36bb0ff980fa7ffef3a2600 │ │ │ ├── join_1to1-5-ce1542ccec99ccfdc9b5c3f713ab1c0e │ │ │ ├── join_1to1-6-6081eb976b4aef2132418510756a385b │ │ │ ├── join_1to1-7-281b888188eac90c4bf670417f25cc0c │ │ │ ├── join_1to1-8-2bc944d7dcc8eba8f25794d99ea35b84 │ │ │ ├── join_1to1-9-5e48ba086f1376939535081b60f82727 │ │ │ ├── join_array-0-60904bf2bd7bbfa8739d8e047e83e038 │ │ │ ├── join_array-1-2c086fcf118fd2538bfa00724209091e │ │ │ ├── join_array-2-16840a0266cad03a1a0b134d105b854f │ │ │ ├── join_array-3-a6ca6b64324596831033fdfe5b63a942 │ │ │ ├── join_array-4-b235265cd6bd58fd743c27b02e547d62 │ │ │ ├── join_array-5-a9b9419b94631f8fe1c2297ebf103a9a │ │ │ ├── join_array-6-6eded94bd39189ea6d67fe383f9b865c │ │ │ ├── join_casesensitive-0-3c6c18f40c89c8fe9891869f2f6acb48 │ │ │ ├── join_casesensitive-1-d1e9ae71a3ed691c39bb8f77ab28edbf │ │ │ ├── join_casesensitive-2-d508d777b4e4156bff9774925a6ca4d │ │ │ ├── join_casesensitive-3-93300f4a9242fa2804a5b368538d83f │ │ │ ├── join_casesensitive-4-c880b2256f97413b8fe68d19d99747fd │ │ │ ├── join_empty-0-3fef0a906d6618ab28406d1edf0dc9ad │ │ │ ├── join_empty-1-9bcf09f835d785760c0d4da0680837f2 │ │ │ ├── join_empty-2-ff98d5f09dd67ae5f1bd8d09a3c4db8e │ │ │ ├── join_empty-3-3b2231f25886c152f222856256ac3473 │ │ │ ├── join_empty-4-df2401785dfa257de49c3ad80b0f480a │ │ │ ├── join_empty-5-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── join_empty-6-e807e73f2636bf03a572c9e0b8430b5a │ │ │ ├── join_empty-7-7d6e4e5bc4cae56192cc737fb6dc9c72 │ │ │ ├── join_filters-0-5644ab44e5ba9f2941216b8d5dc33a99 │ │ │ ├── join_filters-1-bee6095f42de6a16708c2f9addc1b9bd │ │ │ ├── join_filters-10-f0c5c51de4151a17a77c780be0c13e01 │ │ │ ├── join_filters-100-a4c7cd87175222bea19fd33018890efe │ │ │ ├── join_filters-101-f086409eb336282af5a00f4c7192ef2b │ │ │ ├── join_filters-102-634888c4fa78ce10181c9514c6393554 │ │ │ ├── join_filters-103-c020d3461658ae8e118281f40264ae5b │ │ │ ├── join_filters-104-c9b79f30e1f25672ec89014f966b41b0 │ │ │ ├── join_filters-105-b3d9dcbb7e1caef97646eb89edf82eb │ │ │ ├── join_filters-106-870999978978b22f21997899f1e652b8 │ │ │ ├── join_filters-107-94824a62d882227f270a66ec7ef28cd4 │ │ │ ├── join_filters-108-d793c1514545499f58fb1b355cbd3f0e │ │ │ ├── join_filters-109-2709001b4aa57ed01ba975e83b556475 │ │ │ ├── join_filters-11-6fb35e1a65211e68de5df4a1cb9c7117 │ │ │ ├── join_filters-110-86868ef0f28c5b42f04fb9ca64aaa3ba │ │ │ ├── join_filters-111-fd3188d025e4c84d45cbb265d08ca569 │ │ │ ├── join_filters-112-a0cd07949ff7dbc2287dc060bedb1942 │ │ │ ├── join_filters-113-48c4978768872751832149d72cdf0ba │ │ │ ├── join_filters-114-58b8db46ea5080791c7416838d3e8f95 │ │ │ ├── join_filters-115-98e45a3167d19d09219076a2d93afa49 │ │ │ ├── join_filters-116-bec2950fff2c1b3c4dc5be846653ea6 │ │ │ ├── join_filters-117-ee8471d93c3778f4b48c5c59f473dd35 │ │ │ ├── join_filters-118-9b395d7db8722a467d46588d0f27fc9e │ │ │ ├── join_filters-119-7688784396db55ff148292a9755c918a │ │ │ ├── join_filters-12-4c29d6be8717481332cd1ee7ca17690e │ │ │ ├── join_filters-120-6578651ffbf95c0b02825e2125e32709 │ │ │ ├── join_filters-121-6dc4977da7f8dc7c636a03d7ad892ada │ │ │ ├── join_filters-122-64bb9f9a0eef32d2392b80b93c9b2c98 │ │ │ ├── join_filters-13-c6a291879bdb37f0c84f6074f257d52 │ │ │ ├── join_filters-14-ef8255dcad808f9128d79e6ee9f368cf │ │ │ ├── join_filters-15-a83678913c62249c8fdf2dac1f6e3046 │ │ │ ├── join_filters-16-a6511579b5e4c2d845664f0c4a6ce622 │ │ │ ├── join_filters-17-c22aab929016fa6f4b6d1e14cc3a4940 │ │ │ ├── join_filters-18-8ef51af7455eaeeaefff1c98e16dcc65 │ │ │ ├── join_filters-19-e164192e6538b428c8b53e008a978d3f │ │ │ ├── join_filters-2-67fff9e6931a7320444e857e01b3d496 │ │ │ ├── join_filters-20-7a5da20822bf51ed69ccf640cbb816cf │ │ │ ├── join_filters-21-13d6d5335625fc3386a8011dc557002e │ │ │ ├── join_filters-22-f12ffd6cc9213d9c64cbea1b6db0632e │ │ │ ├── join_filters-23-a800b885358695758afdb719cdefa94f │ │ │ ├── join_filters-24-df3db5a91f3f4e88e18d2b1cc5b47113 │ │ │ ├── join_filters-25-435ecfc7f9cb5f32019fe498c21ccad3 │ │ │ ├── join_filters-26-da36fab3d1686aedd415a7a0f0253eca │ │ │ ├── join_filters-27-5f4a5437696f2a60bec9ac1443244242 │ │ │ ├── join_filters-28-2acf41a9f6efac0d800df557db716359 │ │ │ ├── join_filters-29-cf5fef4ddc313209f5ab1e5ea3763e35 │ │ │ ├── join_filters-3-989b3dbd15ba601ae80fe454e03213d7 │ │ │ ├── join_filters-30-97f94f35ebc30f776a19bed59c7fb4bf │ │ │ ├── join_filters-31-4923f8ba429f0c71ad9b6b9499e73a7f │ │ │ ├── join_filters-32-5978cd7936c296493a16a31b926043ab │ │ │ ├── join_filters-33-607d64d50ef9aad424bd22b358efe027 │ │ │ ├── join_filters-34-35c2c8d74bc0ebc4710c81333cb254a9 │ │ │ ├── join_filters-35-a4c7cd87175222bea19fd33018890efe │ │ │ ├── join_filters-36-f086409eb336282af5a00f4c7192ef2b │ │ │ ├── join_filters-37-634888c4fa78ce10181c9514c6393554 │ │ │ ├── join_filters-38-c020d3461658ae8e118281f40264ae5b │ │ │ ├── join_filters-39-c9b79f30e1f25672ec89014f966b41b0 │ │ │ ├── join_filters-4-33bfcd576019d7e32683556f66e3757 │ │ │ ├── join_filters-40-b3d9dcbb7e1caef97646eb89edf82eb │ │ │ ├── join_filters-41-870999978978b22f21997899f1e652b8 │ │ │ ├── join_filters-42-94824a62d882227f270a66ec7ef28cd4 │ │ │ ├── join_filters-43-d793c1514545499f58fb1b355cbd3f0e │ │ │ ├── join_filters-44-6d8955591f62d9cfc6af17df63d3d88e │ │ │ ├── join_filters-45-23ab7ac8229a53d391195be7ca092429 │ │ │ ├── join_filters-46-268d8fb3cb9b04eb269fe7ec40a24dfe │ │ │ ├── join_filters-47-6dc6866a65c74d69538b776b41b06c16 │ │ │ ├── join_filters-48-e884480a0f7273d3e2f2de2ba46b855c │ │ │ ├── join_filters-49-98fd86aea9cacaa82d43c7468109dd33 │ │ │ ├── join_filters-5-f0c0d07019afb1bbe162e3183e18023e │ │ │ ├── join_filters-50-3e6612a89e9124592e790594775054b1 │ │ │ ├── join_filters-51-60a5f56f33fc8854a2b687005f0d96ac │ │ │ ├── join_filters-52-64cabe5164130a94f387288f37b62d71 │ │ │ ├── join_filters-53-2709001b4aa57ed01ba975e83b556475 │ │ │ ├── join_filters-54-86868ef0f28c5b42f04fb9ca64aaa3ba │ │ │ ├── join_filters-55-fd3188d025e4c84d45cbb265d08ca569 │ │ │ ├── join_filters-56-a0cd07949ff7dbc2287dc060bedb1942 │ │ │ ├── join_filters-57-48c4978768872751832149d72cdf0ba │ │ │ ├── join_filters-58-58b8db46ea5080791c7416838d3e8f95 │ │ │ ├── join_filters-59-98e45a3167d19d09219076a2d93afa49 │ │ │ ├── join_filters-6-c0c40d001cac0bc91095dddda1513ad9 │ │ │ ├── join_filters-60-bec2950fff2c1b3c4dc5be846653ea6 │ │ │ ├── join_filters-61-ee8471d93c3778f4b48c5c59f473dd35 │ │ │ ├── join_filters-62-9b395d7db8722a467d46588d0f27fc9e │ │ │ ├── join_filters-63-7688784396db55ff148292a9755c918a │ │ │ ├── join_filters-64-6578651ffbf95c0b02825e2125e32709 │ │ │ ├── join_filters-65-6dc4977da7f8dc7c636a03d7ad892ada │ │ │ ├── join_filters-66-64bb9f9a0eef32d2392b80b93c9b2c98 │ │ │ ├── join_filters-67-67fff9e6931a7320444e857e01b3d496 │ │ │ ├── join_filters-68-989b3dbd15ba601ae80fe454e03213d7 │ │ │ ├── join_filters-69-33bfcd576019d7e32683556f66e3757 │ │ │ ├── join_filters-7-89963646509154a2fb1ddbbf1f55349d │ │ │ ├── join_filters-70-f0c0d07019afb1bbe162e3183e18023e │ │ │ ├── join_filters-71-c0c40d001cac0bc91095dddda1513ad9 │ │ │ ├── join_filters-72-89963646509154a2fb1ddbbf1f55349d │ │ │ ├── join_filters-73-69e0235472d7cee7d83037cd083544a5 │ │ │ ├── join_filters-74-b6372cc006844e8488a3b7836c67daaa │ │ │ ├── join_filters-75-f0c5c51de4151a17a77c780be0c13e01 │ │ │ ├── join_filters-76-6fb35e1a65211e68de5df4a1cb9c7117 │ │ │ ├── join_filters-77-4c29d6be8717481332cd1ee7ca17690e │ │ │ ├── join_filters-78-c6a291879bdb37f0c84f6074f257d52 │ │ │ ├── join_filters-79-ef8255dcad808f9128d79e6ee9f368cf │ │ │ ├── join_filters-8-69e0235472d7cee7d83037cd083544a5 │ │ │ ├── join_filters-80-a83678913c62249c8fdf2dac1f6e3046 │ │ │ ├── join_filters-81-a6511579b5e4c2d845664f0c4a6ce622 │ │ │ ├── join_filters-82-c22aab929016fa6f4b6d1e14cc3a4940 │ │ │ ├── join_filters-83-8ef51af7455eaeeaefff1c98e16dcc65 │ │ │ ├── join_filters-84-e164192e6538b428c8b53e008a978d3f │ │ │ ├── join_filters-85-7a5da20822bf51ed69ccf640cbb816cf │ │ │ ├── join_filters-86-13d6d5335625fc3386a8011dc557002e │ │ │ ├── join_filters-87-f12ffd6cc9213d9c64cbea1b6db0632e │ │ │ ├── join_filters-88-a800b885358695758afdb719cdefa94f │ │ │ ├── join_filters-89-df3db5a91f3f4e88e18d2b1cc5b47113 │ │ │ ├── join_filters-9-b6372cc006844e8488a3b7836c67daaa │ │ │ ├── join_filters-90-435ecfc7f9cb5f32019fe498c21ccad3 │ │ │ ├── join_filters-91-da36fab3d1686aedd415a7a0f0253eca │ │ │ ├── join_filters-92-5f4a5437696f2a60bec9ac1443244242 │ │ │ ├── join_filters-93-2acf41a9f6efac0d800df557db716359 │ │ │ ├── join_filters-94-cf5fef4ddc313209f5ab1e5ea3763e35 │ │ │ ├── join_filters-95-97f94f35ebc30f776a19bed59c7fb4bf │ │ │ ├── join_filters-96-4923f8ba429f0c71ad9b6b9499e73a7f │ │ │ ├── join_filters-97-5978cd7936c296493a16a31b926043ab │ │ │ ├── join_filters-98-607d64d50ef9aad424bd22b358efe027 │ │ │ ├── join_filters-99-35c2c8d74bc0ebc4710c81333cb254a9 │ │ │ ├── join_hive_626-0-3491c764e44ee92af3a88d301a1bd498 │ │ │ ├── join_hive_626-1-2b67cd3c7cec844a7ceb19e8dbb0e164 │ │ │ ├── join_hive_626-2-42997e626819de9cdad544d7fe132c6e │ │ │ ├── join_hive_626-3-4a2f2f2858540afea9a195b5322941ee │ │ │ ├── join_hive_626-4-4bb73b33747da4ed852df381b7b45a71 │ │ │ ├── join_hive_626-5-c6a3ae6f3539ab48b996060fb51d8ebe │ │ │ ├── join_hive_626-6-392f6f482886b2e7be5903d44bfba3f1 │ │ │ ├── join_hive_626-7-d9c817eebc533bedc3ef9172d325a2c2 │ │ │ ├── join_map_ppr-0-775b1af8eae9b2250052be1b72b4086 │ │ │ ├── join_map_ppr-1-7b9086c721214279a2f0c64d6d35df77 │ │ │ ├── join_map_ppr-10-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join_map_ppr-2-e3e5db334ed33b17026b43f776daee1e │ │ │ ├── join_map_ppr-3-c9859bf9c9942c59f3b19d82bd1a3afa │ │ │ ├── join_map_ppr-4-1230f694ae20d2a21e41ac609471b8c5 │ │ │ ├── join_map_ppr-5-b7e6358104eceede7389c7d2a212b058 │ │ │ ├── join_map_ppr-6-6aab4a0b43b769d7f6b6f5ad6dc0558a │ │ │ ├── join_map_ppr-7-45704df71b70e3f5aa31966ac96b9db │ │ │ ├── join_map_ppr-8-e790d28a6c0818b1bafbe252879bd8ed │ │ │ ├── join_map_ppr-9-921ba3c3c23751ac1d724319a1b9b22a │ │ │ ├── join_nulls-0-5644ab44e5ba9f2941216b8d5dc33a99 │ │ │ ├── join_nulls-1-75b1f5331b62fedb7dbbe6ac93a3c83f │ │ │ ├── join_nulls-10-39071d8e6b246cfd405714dbf0b5337b │ │ │ ├── join_nulls-11-545dff878ea0d79cdfee517572c9e0c8 │ │ │ ├── join_nulls-12-5e1ca8627aa685435142d8e339e77062 │ │ │ ├── join_nulls-13-5f670a20cbec42a34685ee0398ad7e2d │ │ │ ├── join_nulls-14-e97ba69145da387a4a66635b8499077 │ │ │ ├── join_nulls-15-e9f9be8be6e936fb832483dfa0be5126 │ │ │ ├── join_nulls-16-b000ccd6c2c05af1875e21428aa3d9b9 │ │ │ ├── join_nulls-17-2b0bfe5754456475ceb6af4694165f │ │ │ ├── join_nulls-18-321cf9d31dac835c3def6ca3b3b860a2 │ │ │ ├── join_nulls-19-739bf8e440e698540d18c29226c3564c │ │ │ ├── join_nulls-2-f4b71841cfff5294bc1e5ac163eadbe5 │ │ │ ├── join_nulls-20-fff960f1cb832bc93e3d1de519e573d5 │ │ │ ├── join_nulls-21-62a25fb819ae5c1ea757b6e759082a2e │ │ │ ├── join_nulls-22-5b2df5518994ae86c041484561857da0 │ │ │ ├── join_nulls-23-982c3e55235cafa3d89b5dee4366fdf8 │ │ │ ├── join_nulls-24-86ad66543a735d396f7336cb5bdfa495 │ │ │ ├── join_nulls-25-45bd90c71bc44c2accf0009f1ceb5f56 │ │ │ ├── join_nulls-26-3fb736c1d060bbf9ec7ce58be4531dc9 │ │ │ ├── join_nulls-27-6ee7affed896b1c539628ab081842b83 │ │ │ ├── join_nulls-28-455aace3472c5840a885b6fab6a046cb │ │ │ ├── join_nulls-29-2c278a88713aef5cd30ff3720ef3eeeb │ │ │ ├── join_nulls-3-88d2da3bcb2c8b04df1b6f18ff2226c4 │ │ │ ├── join_nulls-30-2c0c41da38714d1b16feffb00fa08bb1 │ │ │ ├── join_nulls-31-a33c48d38817ee3a7aca511dc7793486 │ │ │ ├── join_nulls-32-e6b104ae96622ff75d510efc6efc9352 │ │ │ ├── join_nulls-33-1284a11bf6aeef8ff87b471d41985f26 │ │ │ ├── join_nulls-34-aeb90811861431cadc5512637793afc1 │ │ │ ├── join_nulls-35-2d1d18d4e9775ec69333947fbd62bc82 │ │ │ ├── join_nulls-36-7c029c91141b36af79ba0dc1de73a257 │ │ │ ├── join_nulls-37-fa84731f5a6beec20d64a7981815b9bc │ │ │ ├── join_nulls-38-6d8955591f62d9cfc6af17df63d3d88e │ │ │ ├── join_nulls-39-23ab7ac8229a53d391195be7ca092429 │ │ │ ├── join_nulls-4-a1f20b4863428627bae1316755cc2d94 │ │ │ ├── join_nulls-40-268d8fb3cb9b04eb269fe7ec40a24dfe │ │ │ ├── join_nulls-41-6dc6866a65c74d69538b776b41b06c16 │ │ │ ├── join_nulls-42-e884480a0f7273d3e2f2de2ba46b855c │ │ │ ├── join_nulls-43-98fd86aea9cacaa82d43c7468109dd33 │ │ │ ├── join_nulls-44-2db30531137611e06fdba478ca7a8412 │ │ │ ├── join_nulls-45-e58b2754e8d9c56a473557a549d0d2b9 │ │ │ ├── join_nulls-46-64cabe5164130a94f387288f37b62d71 │ │ │ ├── join_nulls-47-ebf794e8b51be738e2d664f249869de1 │ │ │ ├── join_nulls-48-979c3ee0ee49bfd246d5372b8873fd3 │ │ │ ├── join_nulls-49-2d20d8f4221281a6b1cd579e761f81b7 │ │ │ ├── join_nulls-5-5ec6e3df7181e0738244623cc01bf22c │ │ │ ├── join_nulls-50-8b26343e74c161cf74ece5f0bd21470 │ │ │ ├── join_nulls-51-75339d2eb2afabf5dd088074b2563d8f │ │ │ ├── join_nulls-52-caad1db99085760daaf8f96c0ce5564 │ │ │ ├── join_nulls-53-ec965e66e7fad403cd0ea388c3e70363 │ │ │ ├── join_nulls-54-6f15c794b5587430ebb685cc61c502 │ │ │ ├── join_nulls-55-a1c73326f8c8d9beccda3ba365352564 │ │ │ ├── join_nulls-56-f7b9629093c818b6c384c79d1458d178 │ │ │ ├── join_nulls-57-cf353446d7f358a508f17d0984b90158 │ │ │ ├── join_nulls-58-5f9a59160a76f9b649102a97987ed33a │ │ │ ├── join_nulls-59-8753a39412ac59c7a05951aeeea73b24 │ │ │ ├── join_nulls-6-7eea211c80e7f1146098e80ffb890d67 │ │ │ ├── join_nulls-7-1692e12155c37a8d94d63d274a9eb8e0 │ │ │ ├── join_nulls-8-609f6bd812a44b20da0a39c827e4d870 │ │ │ ├── join_nulls-9-ef4b27a877efc377cd5750af6725194b │ │ │ ├── join_nullsafe-0-869726b703f160eabdb7763700b53e60 │ │ │ ├── join_nullsafe-1-5644ab44e5ba9f2941216b8d5dc33a99 │ │ │ ├── join_nullsafe-10-b6de4e85dcc1d1949c7431d39fa1b919 │ │ │ ├── join_nullsafe-11-3aa243002a5363b84556736ef71613b1 │ │ │ ├── join_nullsafe-12-3cc55b14e8256d2c51361b61986c291e │ │ │ ├── join_nullsafe-13-69d94e229191e7b9b1a3e7eae46eb993 │ │ │ ├── join_nullsafe-14-cf9ff6ee72a701a8e2f3e7fb0667903c │ │ │ ├── join_nullsafe-15-507d0fa6d7ce39e2d9921555cea6f8da │ │ │ ├── join_nullsafe-16-1c714fc339304de4db630530e5d1ce97 │ │ │ ├── join_nullsafe-17-8a4b0dc781a28ad11a0db9805fe03aa8 │ │ │ ├── join_nullsafe-18-10b2051e65cac50ee1ea1c138ec192c8 │ │ │ ├── join_nullsafe-19-23ab7ac8229a53d391195be7ca092429 │ │ │ ├── join_nullsafe-2-5bb63fafa390b1d4c20e225a8a648dcf │ │ │ ├── join_nullsafe-20-88faf8a93ba6759bd6f2bbcbdcfecda0 │ │ │ ├── join_nullsafe-21-24332b9390108fb3379e1acc599293a1 │ │ │ ├── join_nullsafe-22-4be80634a6bd916e3ebd60a124f0a48e │ │ │ ├── join_nullsafe-23-e4425d56be43c21124d95160653ce0ac │ │ │ ├── join_nullsafe-24-2db30531137611e06fdba478ca7a8412 │ │ │ ├── join_nullsafe-25-e58b2754e8d9c56a473557a549d0d2b9 │ │ │ ├── join_nullsafe-26-64cabe5164130a94f387288f37b62d71 │ │ │ ├── join_nullsafe-27-e8ed4a1b574a6ca70cbfb3f7b9980aa6 │ │ │ ├── join_nullsafe-28-5a0c946cd7033857ca99e5fb800f8525 │ │ │ ├── join_nullsafe-29-514043c2ddaf6ea8f16a764adc92d1cf │ │ │ ├── join_nullsafe-3-ae378fc0f875a21884e58fa35a6d52cd │ │ │ ├── join_nullsafe-30-fcbf92cb1b85ab01102fbbc6caba9a88 │ │ │ ├── join_nullsafe-31-1cb03e1106f79d14f22bc89d386cedcf │ │ │ ├── join_nullsafe-32-6a0bf6127d4b042e67ae8ee15125fb87 │ │ │ ├── join_nullsafe-33-63157d43422fcedadba408537ccecd5c │ │ │ ├── join_nullsafe-34-9265f806b71c03061f93f9fbc88aa223 │ │ │ ├── join_nullsafe-35-95815bafb81cccb8129c20d399a446fc │ │ │ ├── join_nullsafe-36-c4762c60cc93236b7647ebd32a40ce57 │ │ │ ├── join_nullsafe-37-a87893adfc73c9cc63ceab200bb56245 │ │ │ ├── join_nullsafe-38-e3dfe0044b44c8a49414479521acf762 │ │ │ ├── join_nullsafe-39-9a7e1f373b9c02e632d6c7c550b908ec │ │ │ ├── join_nullsafe-4-644c616d87ae426eb2f8c71638045185 │ │ │ ├── join_nullsafe-40-3c868718e4c120cb9a72ab7318c75be3 │ │ │ ├── join_nullsafe-41-1f7d8737c3e2d74d5ad865535d729811 │ │ │ ├── join_nullsafe-5-1e393de94850e92b3b00536aacc9371f │ │ │ ├── join_nullsafe-6-d66451815212e7d17744184e74c6b0a0 │ │ │ ├── join_nullsafe-7-a3ad3cc301d9884898d3e6ab6c792d4c │ │ │ ├── join_nullsafe-8-cc7527bcf746ab7e2cd9f28db0ead0ac │ │ │ ├── join_nullsafe-9-88f6f40959b0d2faabd9d4b3cd853809 │ │ │ ├── join_rc-0-fcbbe26c6881f81800fe86abbfe6aa87 │ │ │ ├── join_rc-1-6a7685f30de00ebb4867a4002d641a5e │ │ │ ├── join_rc-2-88aabbe1fcd7735ae8cc97418b4a59a3 │ │ │ ├── join_rc-3-4a737f3e518f5322ba41a189e79c1dee │ │ │ ├── join_rc-4-f60f7fdd08e85fae90af59475192b725 │ │ │ ├── join_rc-5-1aef75afe38d512addb44dbf9a650263 │ │ │ ├── join_reorder2-0-caf1c5fd299fdbdb655234d01d44caf2 │ │ │ ├── join_reorder2-1-744a018c78bae6e09853dd202981e850 │ │ │ ├── join_reorder2-10-45349471e0e919bd2185f584e87b891d │ │ │ ├── join_reorder2-11-f8460b061fa00f6afbfe8eeccf4d3564 │ │ │ ├── join_reorder2-2-fa53198d9eecb9d274b09d4351b9274e │ │ │ ├── join_reorder2-3-38a5e7f36d579835f9c2b1c52efd9643 │ │ │ ├── join_reorder2-4-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── join_reorder2-5-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── join_reorder2-6-8eb53fb8f05a43ee377aa1c927857e7c │ │ │ ├── join_reorder2-7-5f4cfbbe53c5e808ee08b26514272034 │ │ │ ├── join_reorder2-8-68b763a6f1f673daa35fee55aeae84a1 │ │ │ ├── join_reorder2-9-26ffed826eceda953b7124ee39ace828 │ │ │ ├── join_reorder3-0-caf1c5fd299fdbdb655234d01d44caf2 │ │ │ ├── join_reorder3-1-744a018c78bae6e09853dd202981e850 │ │ │ ├── join_reorder3-10-ff036400019164ed743ecd9cfc222ce1 │ │ │ ├── join_reorder3-11-d6392b851f7dd5e3705e8ff51e1c6583 │ │ │ ├── join_reorder3-2-fa53198d9eecb9d274b09d4351b9274e │ │ │ ├── join_reorder3-3-38a5e7f36d579835f9c2b1c52efd9643 │ │ │ ├── join_reorder3-4-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── join_reorder3-5-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── join_reorder3-6-8eb53fb8f05a43ee377aa1c927857e7c │ │ │ ├── join_reorder3-7-5f4cfbbe53c5e808ee08b26514272034 │ │ │ ├── join_reorder3-8-743fefaadfe31ce43cd2dead85b7d741 │ │ │ ├── join_reorder3-9-9d45e66a3990b7c53fd780f07cd52e13 │ │ │ ├── join_reorder4-0-799a471861f35cb065a6b1105c7d9ccf │ │ │ ├── join_reorder4-1-ee3326e9aa49562ac854bbd0b3f3d90a │ │ │ ├── join_reorder4-10-1d6b948747ac31296710a491a5652e3f │ │ │ ├── join_reorder4-11-7ec0f5b60991a54d86ec9f8a27809c3 │ │ │ ├── join_reorder4-12-203aed2c4298eba4a3c51816a21a1c1 │ │ │ ├── join_reorder4-2-8b4643dd260f09d32af5d79de7359c0c │ │ │ ├── join_reorder4-3-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── join_reorder4-4-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── join_reorder4-5-8eb53fb8f05a43ee377aa1c927857e7c │ │ │ ├── join_reorder4-6-24ca942f094b14b92086305cc125e833 │ │ │ ├── join_reorder4-7-58a3ea3c82886b1eb7cee7403b1f96a5 │ │ │ ├── join_reorder4-8-4bbb8e937245e2fa7cafbb423814754 │ │ │ ├── join_reorder4-9-b401eef67c1c04f875c084c9e0fda9ba │ │ │ ├── join_star-0-6001f83f7780835737e3262a34c2b832 │ │ │ ├── join_star-1-9f29849fe78f15b7594378a10fe3ed9d │ │ │ ├── join_star-10-a9e579038e3d4826fdae475d7058ab82 │ │ │ ├── join_star-11-72730ecdad9c0fd4c6ce64a0cb89fb74 │ │ │ ├── join_star-12-f581d6d305d652cd0f4e4fa912eb578d │ │ │ ├── join_star-13-7268564732cbb7489248f9d818f80c14 │ │ │ ├── join_star-14-2ee0fcf000f8687fc8941bf212477e57 │ │ │ ├── join_star-15-43b0b3b5e40044f8dbaeef2c7fc9e3e9 │ │ │ ├── join_star-16-24ca942f094b14b92086305cc125e833 │ │ │ ├── join_star-17-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── join_star-18-1c22e451845667bd6b4eac3c49c36965 │ │ │ ├── join_star-19-a1209595ce68e24a111c2a0d27863bfa │ │ │ ├── join_star-2-75d7e03808482c11361ce72f2dd38de0 │ │ │ ├── join_star-20-76473cb68a69b9408207fd43ddae9339 │ │ │ ├── join_star-21-6b8dbb1dbcf0096f0af3209bb6efd2c6 │ │ │ ├── join_star-22-429cfd140488242d569aee6594aae76b │ │ │ ├── join_star-23-bada259628918dbfb4837bcb58258530 │ │ │ ├── join_star-24-e11ab68d72d874c7c6c658c1018f5a49 │ │ │ ├── join_star-25-be5af28b6bccf529a31ef68619de699e │ │ │ ├── join_star-26-a412a0620a359a62e2ab4e45fa8e0330 │ │ │ ├── join_star-27-9ae4ebb8ceaa724bdbc88126f86692f1 │ │ │ ├── join_star-28-98a3f4d8a2209e771c57462d4b723ff9 │ │ │ ├── join_star-3-4f4ca11033af3894cc2e720ebb69e5da │ │ │ ├── join_star-4-aaba115af7543b214820a48a694f2463 │ │ │ ├── join_star-5-c72a8aff3a51f9e59bb62fd99807d8da │ │ │ ├── join_star-6-73d96ed451a4964e5c364dbdb56d487a │ │ │ ├── join_star-7-b007c3d4b6ed10df9e875e23644b673a │ │ │ ├── join_star-8-c3d53a4daab9614a09870dc8e9571f74 │ │ │ ├── join_star-9-3f7ccccc2488de5f33a38cb3cc3eb628 │ │ │ ├── lateral view1-0-85bfbfd635aee807ede359073fb26dee │ │ │ ├── lateral view2-0-6d92d10040c715df89db0f61ae4250bb │ │ │ ├── lateral view3-0-55b6de1dbad92682804e98524c0d6c12 │ │ │ ├── lateral view4-0-3ed6bfa23add415990b443fc232b4ba0 │ │ │ ├── lateral view4-1-6ced0ab5d543a2c5c6c7f7e27ed04814 │ │ │ ├── lateral view4-2-ed9961425eee97a5f35c5b6e69dc368e │ │ │ ├── lateral view5-0-f797cf9d04a98cfe477d14703aeb294b │ │ │ ├── lateral view6-0-f92fe6429a6630d4991f8ad76ff1d79a │ │ │ ├── lateral_view-0-bc2e73d1da334f7bf550244ce6f6e77b │ │ │ ├── lateral_view-1-82287db1270c77c3af7a60d65c4bdc80 │ │ │ ├── lateral_view-10-1f2df08433fe12a9ae086e3d9309039e │ │ │ ├── lateral_view-11-d884acac077c5a02ef048069dd8c16d7 │ │ │ ├── lateral_view-12-f539cc98118a276d38c61fcc0ad0b09 │ │ │ ├── lateral_view-13-f1ca785bf643a4a3cd1f2f823da158ba │ │ │ ├── lateral_view-14-f29001fbaafbdc4aaa1e0a0c18481aa7 │ │ │ ├── lateral_view-15-e1fad51e2f77de35d5781d788d70057e │ │ │ ├── lateral_view-16-5eafb0317b6974eb588075d152719a79 │ │ │ ├── lateral_view-17-4c6ff06840694c274bf8a91bade677ab │ │ │ ├── lateral_view-18-a98a136672c920c0463bd49b4ec7b65e │ │ │ ├── lateral_view-19-9b417d5554cbeb8f536a1613879295f7 │ │ │ ├── lateral_view-2-bfd7354229ac8a934c8f978b43b28565 │ │ │ ├── lateral_view-20-d75015d8e44499526fec784ec00b905 │ │ │ ├── lateral_view-21-9eec1a93e07de6acbc36b1156424ca11 │ │ │ ├── lateral_view-3-16a7be14adbb71fb9e6c7e0f00cfe86e │ │ │ ├── lateral_view-4-f5855ce2bc7877c698e7f94504d12d62 │ │ │ ├── lateral_view-5-857f93a5c8d5ba00d214384117147bae │ │ │ ├── lateral_view-6-e78723941c3b42349f9eb804b4b82d15 │ │ │ ├── lateral_view-7-7c88418f83112c55d08a0727d6248825 │ │ │ ├── lateral_view-8-d2bff21465d3db7bbff8b9913c012452 │ │ │ ├── lateral_view-9-60290e9a3b75a39c21dd44817d90d4a7 │ │ │ ├── lateral_view_cp-0-6ae48c990343343aad4145203c364f79 │ │ │ ├── lateral_view_cp-1-72a14433dd2f25dd8c38107235fe1756 │ │ │ ├── lateral_view_cp-2-647d019098d676b2fdb8a5127b633287 │ │ │ ├── lateral_view_cp-3-3622d591963e6a7f021d07c7c35a1cd2 │ │ │ ├── lateral_view_cp-4-507876b610812506343e9d251645170b │ │ │ ├── lateral_view_noalias-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── lateral_view_noalias-1-72509f06e1f7c5d5ccc292f775f8eea7 │ │ │ ├── lateral_view_noalias-2-6d5806dd1d2511911a5de1e205523f42 │ │ │ ├── lateral_view_noalias-3-155b3cc2f5054725a9c2acca3c38c00a │ │ │ ├── lateral_view_noalias-4-3b7045ace234af8e5e86d8ac23ccee56 │ │ │ ├── lateral_view_noalias-5-e1eca4e08216897d090259d4fd1e3fe │ │ │ ├── lateral_view_noalias-6-16d227442dd775615c6ecfceedc6c612 │ │ │ ├── lateral_view_noalias-7-66cb5ab20690dd85b2ed95bbfb9481d3 │ │ │ ├── lateral_view_ppd-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── lateral_view_ppd-1-cd326124717660a333f0915395f96768 │ │ │ ├── lateral_view_ppd-10-a537ad7282d1c9957cdae74ad87c790b │ │ │ ├── lateral_view_ppd-2-25c2f5138fc88cf7fc34339a501de05f │ │ │ ├── lateral_view_ppd-3-a7d1b9240892d32ae3adf6ff2289a760 │ │ │ ├── lateral_view_ppd-4-c746547306ed67a5e8a0fce57023c9c9 │ │ │ ├── lateral_view_ppd-5-2d087c55c7ad9f3dc51d8406833feb1f │ │ │ ├── lateral_view_ppd-6-63f8025bbf66831e84b98f9429e6c7fa │ │ │ ├── lateral_view_ppd-7-b8eb877331710c06ebc7dbaab5a7155b │ │ │ ├── lateral_view_ppd-8-fe627f796b01fe05ef7ccc30afe7c510 │ │ │ ├── lateral_view_ppd-9-dc6fea663d875b082d38bd326d21cd95 │ │ │ ├── leftsemijoin-0-80b6466213face7fbcb0de044611e1f5 │ │ │ ├── leftsemijoin-1-d1f6a3dea28a5f0fee08026bf33d9129 │ │ │ ├── leftsemijoin-10-89737a8857b5b61cc909e0c797f86aea │ │ │ ├── leftsemijoin-11-80b6466213face7fbcb0de044611e1f5 │ │ │ ├── leftsemijoin-12-d1f6a3dea28a5f0fee08026bf33d9129 │ │ │ ├── leftsemijoin-2-43d53504df013e6b35f81811138a167a │ │ │ ├── leftsemijoin-3-b07d292423312aafa5e5762a579decd2 │ │ │ ├── leftsemijoin-4-3ac2226efe7cb5d999c1c5e4ac2114be │ │ │ ├── leftsemijoin-5-aba449db0d4fe6dc9771426e102bb543 │ │ │ ├── leftsemijoin-6-9f50dce576b019c0be997055b8876621 │ │ │ ├── leftsemijoin-7-fff6ca40e6048d52dc2d3afc68e8353e │ │ │ ├── leftsemijoin-8-73cad58a10a1483ccb15e94a857013 │ │ │ ├── leftsemijoin-9-c5efa6b8771a51610d655be461670e1e │ │ │ ├── leftsemijoin_mr-0-7087fb6281a34d00f1812d2ff4ba8b75 │ │ │ ├── leftsemijoin_mr-1-5b2e555868faa404ea09928936178181 │ │ │ ├── leftsemijoin_mr-10-9914f44ecb6ae7587b62e5349ff60d04 │ │ │ ├── leftsemijoin_mr-11-2027ecb1495d5550c5d56abf6b95b0a7 │ │ │ ├── leftsemijoin_mr-2-3f65953ae60375156367c54533978782 │ │ │ ├── leftsemijoin_mr-3-c019cb2a855138da0d0b1e5c67cd6354 │ │ │ ├── leftsemijoin_mr-4-333895fe6abca27c8edb5c91bfe10d2f │ │ │ ├── leftsemijoin_mr-5-896d0948c1df849df9764a6d8ad8fff9 │ │ │ ├── leftsemijoin_mr-6-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── leftsemijoin_mr-7-6b9861b999092f1ea4fa1fd27a666af6 │ │ │ ├── leftsemijoin_mr-8-c61b972d4409babe41d8963e841af45b │ │ │ ├── leftsemijoin_mr-9-2027ecb1495d5550c5d56abf6b95b0a7 │ │ │ ├── length.udf-0-e85ebb8ce5d939964fd87bd13b326c02 │ │ │ ├── limit_pushdown_negative-0-79b294d0081c3dfd36c5b8b5e78dc7fb │ │ │ ├── limit_pushdown_negative-1-f87339637a48bd1533493ebbed5432a7 │ │ │ ├── limit_pushdown_negative-2-de7e5ac581b870fff10dc82c75c1c79e │ │ │ ├── limit_pushdown_negative-3-be440c3f959ca53b758481aa90551984 │ │ │ ├── limit_pushdown_negative-4-4dedc8057d76af264c198beaacd7f000 │ │ │ ├── limit_pushdown_negative-5-543a20e69bd8987bc37a22c1c7ef33f1 │ │ │ ├── limit_pushdown_negative-6-3f8274466914ad200b33a2c83fa6dab5 │ │ │ ├── lineage1-0-c021950f995f1d6a7b83ffe044daa750 │ │ │ ├── lineage1-1-aeb863486b8fe899ee741fc8c8418fc9 │ │ │ ├── lineage1-2-f92e96c6357273ea6cbb2195a418df9c │ │ │ ├── literal_double-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── literal_double-1-10ef1098e35d900983be3814de8f974f │ │ │ ├── literal_double-2-3863c17e03c9c1cd68452106a8721d13 │ │ │ ├── literal_ints-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── literal_ints-1-5ffd1b49cdda4149aef2c61c53a56890 │ │ │ ├── literal_ints-2-b41c42ce2f6ba483b68bb08752b95ec4 │ │ │ ├── literal_string-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── literal_string-1-9b48d41e5c9e41ddc070e2fd31ace15 │ │ │ ├── literal_string-2-2cf4b7268b47246afdf6c792acca379d │ │ │ ├── load_dyn_part1-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part1-1-cd849c4fe1229428da98947e3e43b46d │ │ │ ├── load_dyn_part1-10-c66fea7ad025cd1f513a98a4cc1036b1 │ │ │ ├── load_dyn_part1-11-8b6be78ae0527e5b7efd7db758966853 │ │ │ ├── load_dyn_part1-2-9c0d4354b6a9be351fa32a66ff58a177 │ │ │ ├── load_dyn_part1-3-e17dba1884f6a1d2b5002925afd7c2d3 │ │ │ ├── load_dyn_part1-4-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part1-5-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part1-6-255ad4511130fb8c9ee9d65b7c95743f │ │ │ ├── load_dyn_part1-7-a33b2c9d962e4921c98e62387f3989f7 │ │ │ ├── load_dyn_part1-8-ea921e0af59a4940a11c94143b1c4b32 │ │ │ ├── load_dyn_part1-9-30bc31441828a053d1a675b225a5d617 │ │ │ ├── load_dyn_part10-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part10-1-a5b30075b6c79d1a02e240f46ea1d318 │ │ │ ├── load_dyn_part10-2-151ba0c3b8317902f1235ac07d58135e │ │ │ ├── load_dyn_part10-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part10-4-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part10-5-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part10-6-48d24be440fbbd48f82efeeb05f663c9 │ │ │ ├── load_dyn_part10-7-17d0630e1125ac326c5a7a83e6b8bcc3 │ │ │ ├── load_dyn_part10-8-245027204484e281e1cfaf74386d2967 │ │ │ ├── load_dyn_part10-9-a646fd106fe73b8753fe3fee86d56ebf │ │ │ ├── load_dyn_part11-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part11-1-bcf9e49f6a630b18108da59b243455f7 │ │ │ ├── load_dyn_part11-2-4301f87a8dbf9576788637386e26f9a2 │ │ │ ├── load_dyn_part11-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part11-4-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── load_dyn_part11-5-ea607fbed28d20e5726f4501285d698d │ │ │ ├── load_dyn_part11-6-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part11-7-b377ea0092e921e5c07e8f34d7c9f920 │ │ │ ├── load_dyn_part11-8-9a4433518ac9ff49cb4b71812705adbb │ │ │ ├── load_dyn_part11-9-3889a0cba1cf3c8f8c2e67957e69406a │ │ │ ├── load_dyn_part12-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part12-1-37e5641a1239a05bbd1fb9707f69cd59 │ │ │ ├── load_dyn_part12-2-4a10b19bdc478379bb8c8c9e5fe52c9b │ │ │ ├── load_dyn_part12-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part12-4-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── load_dyn_part12-5-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part12-6-e5c79bdfc92b7b754b003d718d9717a1 │ │ │ ├── load_dyn_part12-7-fd1422a86c9b12ce915a7fa2f2b7fc97 │ │ │ ├── load_dyn_part12-8-fd656b581b8f8fbb8ac22f444dbc345 │ │ │ ├── load_dyn_part13-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part13-1-55bf30e1b5f1aeac9ef284e5e4f19c28 │ │ │ ├── load_dyn_part13-2-d52536b8ac62f6e8152e394fe135a3e0 │ │ │ ├── load_dyn_part13-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part13-4-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── load_dyn_part13-5-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part13-6-67ee926bc6b325a6bfc952bb81752a3d │ │ │ ├── load_dyn_part13-7-99993811a25b02e7904a9403f51775d5 │ │ │ ├── load_dyn_part13-8-930d8e7a94f0cdf922322dae4a02e16 │ │ │ ├── load_dyn_part13-9-c8de411bc094b37b59a2eb0baf6de55d │ │ │ ├── load_dyn_part14-0-ff0d0473e56406f7cb66e83b9af25a6a │ │ │ ├── load_dyn_part14-1-253e2a15bfaef9aa781dc29fa324b51e │ │ │ ├── load_dyn_part14-2-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part14-3-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part14-4-584fc7f440280f67bf5bfdb23370cafd │ │ │ ├── load_dyn_part14-5-ce75e50bda381af53c8549b0d8662d94 │ │ │ ├── load_dyn_part14-6-3fd73cd9f8f9b991b7e72405c00cf5d6 │ │ │ ├── load_dyn_part14-7-7c931249465f330d51ef0610f214429e │ │ │ ├── load_dyn_part14_win-0-a58efbee279cc96fb5738e6ab389927 │ │ │ ├── load_dyn_part14_win-1-253e2a15bfaef9aa781dc29fa324b51e │ │ │ ├── load_dyn_part14_win-2-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part14_win-3-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part14_win-4-584fc7f440280f67bf5bfdb23370cafd │ │ │ ├── load_dyn_part14_win-5-ce75e50bda381af53c8549b0d8662d94 │ │ │ ├── load_dyn_part14_win-6-3fd73cd9f8f9b991b7e72405c00cf5d6 │ │ │ ├── load_dyn_part14_win-7-7c931249465f330d51ef0610f214429e │ │ │ ├── load_dyn_part2-0-294e3beb0241f9f8eac7f54e1bfd775f │ │ │ ├── load_dyn_part2-1-845923af04bb331c9f5995a3a3e84424 │ │ │ ├── load_dyn_part2-2-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part2-3-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── load_dyn_part2-4-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part2-5-fdb342199af53c5c18529c3a0472a38b │ │ │ ├── load_dyn_part2-6-60864ea22e1173981ed651ddc2d944c4 │ │ │ ├── load_dyn_part2-7-86ffa99b03fa88235b61bf1af7062c33 │ │ │ ├── load_dyn_part2-8-a1ff8a12d94378e7e1165bd78cf724cf │ │ │ ├── load_dyn_part2-9-3f29de9877006f9448272ef2422d6132 │ │ │ ├── load_dyn_part3-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part3-1-ce25d1f46dd5e5d9147e39566581514f │ │ │ ├── load_dyn_part3-2-dbbba335c008a61a13c1472b34470397 │ │ │ ├── load_dyn_part3-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part3-4-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part3-5-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part3-6-17dee8c004f1e7db4542fbf4241edce3 │ │ │ ├── load_dyn_part3-7-867958e24e25ad098c5001bbc7102762 │ │ │ ├── load_dyn_part3-8-c32770da4784bfea4d0dd77fdcba4f0a │ │ │ ├── load_dyn_part4-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part4-1-50822afef6986cfea20523ea6092e455 │ │ │ ├── load_dyn_part4-10-297cf42ec45b5aa78b80d9c35a79555a │ │ │ ├── load_dyn_part4-11-24618a43c4656b72f81683b45708045e │ │ │ ├── load_dyn_part4-2-9893d8c02ab8bd59d3e9fb0665f508bd │ │ │ ├── load_dyn_part4-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part4-4-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part4-5-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part4-6-2869679fad49c57ba08169ea32271379 │ │ │ ├── load_dyn_part4-7-f31c7a56b50a5ba425e85480e13c39e1 │ │ │ ├── load_dyn_part4-8-cdff1da8e9e1e9242c49d895751af0a9 │ │ │ ├── load_dyn_part4-9-3c344e5840c1df354a2a71722c27f0a0 │ │ │ ├── load_dyn_part5-0-d9a2e2fa436aaf37e91ccf52e04226b3 │ │ │ ├── load_dyn_part5-1-9a4d1f6a14227bb66bd01557a464da8b │ │ │ ├── load_dyn_part5-10-be7953ca7bd26623d3897f5060e13737 │ │ │ ├── load_dyn_part5-11-6da8fa1e639db104128ba7e2f88f764d │ │ │ ├── load_dyn_part5-2-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part5-3-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part5-4-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part5-5-67f2c7448db01b6804c846f9f4f76928 │ │ │ ├── load_dyn_part5-6-f6dcb13dead8bb4c003eb19099908190 │ │ │ ├── load_dyn_part5-7-3ca3cc56a27939d62db1b52d86309df │ │ │ ├── load_dyn_part5-8-669ccdcc0e0f3162ee44d51ff449fdd9 │ │ │ ├── load_dyn_part5-9-854026d1c2add692f2f90ad74668bbf6 │ │ │ ├── load_dyn_part6-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part6-1-9657a48a4266c176f84c7aaf115fbc30 │ │ │ ├── load_dyn_part6-2-779aa345cf2875089312ec26b046415d │ │ │ ├── load_dyn_part6-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part6-4-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── load_dyn_part6-5-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part6-6-559ff31031a6a0ff6959655c6acd07a3 │ │ │ ├── load_dyn_part6-7-17cbb9aeb8dfaa3f4ba31f4b5d871dd1 │ │ │ ├── load_dyn_part6-8-1009bd2cbd88ddba97186fb76e96a4f │ │ │ ├── load_dyn_part7-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part7-1-e31d34a1b14d706d2b78d083ea858c81 │ │ │ ├── load_dyn_part7-2-5d4c3c48f53d55e26ca142ee70d1706a │ │ │ ├── load_dyn_part7-3-ad94ac1192dbace6b5cf5915387e94e2 │ │ │ ├── load_dyn_part7-4-e98039d0d4ef775fb5594bebffacf4f6 │ │ │ ├── load_dyn_part7-5-b3615ce72a55dba805303145030c8a93 │ │ │ ├── load_dyn_part8-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part8-1-ff5ce932ae5ba496badee7f2465f272c │ │ │ ├── load_dyn_part8-2-9e1df41acabef83f62464f52c2396c8a │ │ │ ├── load_dyn_part8-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part8-4-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part8-5-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part8-6-86db06cb739ceef70c8885469d847495 │ │ │ ├── load_dyn_part8-7-be6ace08b68bc4346456103640308cf7 │ │ │ ├── load_dyn_part8-8-cc6aa0fc59ede89158d4f19752660b8b │ │ │ ├── load_dyn_part8-9-704bd110d9aaa2ac678b7fbf645abdb9 │ │ │ ├── load_dyn_part9-0-463330cf55370dbe92d6ed74ef91302 │ │ │ ├── load_dyn_part9-1-2c61920dcd46ece096fd12875871709f │ │ │ ├── load_dyn_part9-2-748ac33315295f8e55f2480f7714c27a │ │ │ ├── load_dyn_part9-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── load_dyn_part9-4-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── load_dyn_part9-5-16367c381d4b189b3640c92511244bfe │ │ │ ├── load_dyn_part9-6-3c2f7b27f021441c1d6b174a6e2c3045 │ │ │ ├── load_dyn_part9-7-ffe5e03b1884bf7285a7e5463bf31e1b │ │ │ ├── load_dyn_part9-8-504a475a583d33f7c71db57e6774919 │ │ │ ├── load_dyn_part9-9-6954f5fc8dd82ca2c076ab8bcdbc148 │ │ │ ├── load_file_with_space_in_the_name-0-8b3d200fd29aeafd07f16e7a732585a6 │ │ │ ├── load_file_with_space_in_the_name-1-d19201e2fcaee4d451292bd740e6c637 │ │ │ ├── load_file_with_space_in_the_name-2-ad8795e50f5998ea1d2eb64a0c02e6e5 │ │ │ ├── loadpart1-0-fa705a031ff5d97558f29c2b5b9de282 │ │ │ ├── loadpart1-1-6cc94d19c536a996592629f7c82c2ac9 │ │ │ ├── loadpart1-2-b0ebbe71c220979b8fd4a36ffa501bf6 │ │ │ ├── loadpart1-3-21f4ee91fa1c65e8579e4cbe4777d7a0 │ │ │ ├── loadpart1-4-e2e5e7a0378c6f0c28391c447ec9cee9 │ │ │ ├── loadpart1-5-892cb7ecc26e84f1c033b95a3ee3edc │ │ │ ├── loadpart1-6-ca5e3149f2b190d7df923a3e5c1cb07 │ │ │ ├── loadpart1-7-c6493490f898e72dc7ed1bc2d4721aa4 │ │ │ ├── loadpart1-8-ca5e3149f2b190d7df923a3e5c1cb07 │ │ │ ├── loadpart1-9-c012b29f0d7720fbc515aa5fe2759ac7 │ │ │ ├── louter_join_ppr-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── louter_join_ppr-1-498e526f13a05a053a338d766f7351cd │ │ │ ├── louter_join_ppr-2-3d41e966f69a64babb783d1aad0f1b73 │ │ │ ├── louter_join_ppr-3-ac75aeb98d142f514ed7b9b44e78c7c2 │ │ │ ├── louter_join_ppr-4-a4f0ff6d2a367242836379fa9e3fe3ef │ │ │ ├── louter_join_ppr-5-1209db6544b421ea32a360d863becd94 │ │ │ ├── louter_join_ppr-6-dedfbaea184f5e3a29226e6e6bc6735 │ │ │ ├── louter_join_ppr-7-9548b9e389f361ac8eccb3de7255da42 │ │ │ ├── louter_join_ppr-8-6fca189c46645f124d5fcb82564b703 │ │ │ ├── macro-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── macro-1-5ff5e8795c13303db5d3ea88e1e918b6 │ │ │ ├── macro-10-45148a37f6ee9cf498dc7308cbd81a1c │ │ │ ├── macro-11-f55b8684c77f6eefc2618ba79e5e0587 │ │ │ ├── macro-12-62b999122975c2a5de8e49fee089c041 │ │ │ ├── macro-13-87e53d2b4c84098e662779e8f0a59084 │ │ │ ├── macro-14-3a31df84432674ad410f44b137e32c2d │ │ │ ├── macro-15-56966c45104c0d9bc407e79538c2c029 │ │ │ ├── macro-16-56966c45104c0d9bc407e79538c2c029 │ │ │ ├── macro-17-b3864f1d19fdb88b3b74f6d74a0ba548 │ │ │ ├── macro-18-bddb2fe17cd4d850c4462b7eb2b9bc2a │ │ │ ├── macro-19-e3c828c372607b8bf7be00a99359b662 │ │ │ ├── macro-2-fde44c7854a9897acb4c2f78f24c8eec │ │ │ ├── macro-20-cb252a243d59809930a4ff371cbfa292 │ │ │ ├── macro-21-cb252a243d59809930a4ff371cbfa292 │ │ │ ├── macro-3-ddc4cb920b0a68e06551cd34ae4e29ff │ │ │ ├── macro-4-86292bbb7f147393c38bca051768dbda │ │ │ ├── macro-5-ca270bff813e5ab18a6a799016693aa8 │ │ │ ├── macro-6-8976be22af3aba0cc4905e014b4e24fe │ │ │ ├── macro-7-decde0a59183a393e580941c633d3c5c │ │ │ ├── macro-8-3d25ffda9ab348f3e39ad967fc0e5020 │ │ │ ├── macro-9-db5f5172704da1e6dd5d59c136b83e7e │ │ │ ├── mapjoin_distinct-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── mapjoin_distinct-1-a00d1791b7fa7ac5a0505d95c3d12257 │ │ │ ├── mapjoin_distinct-10-53a3e706e797dc6b9e7f5ee8b100fa56 │ │ │ ├── mapjoin_distinct-11-4489654b888efc588b13ee1cda1b6a9f │ │ │ ├── mapjoin_distinct-12-1d351f7e821fcaf66c6f7503e42fb291 │ │ │ ├── mapjoin_distinct-13-a7dc16cb82c595b18d4258a38a304b1e │ │ │ ├── mapjoin_distinct-14-53a3e706e797dc6b9e7f5ee8b100fa56 │ │ │ ├── mapjoin_distinct-15-4489654b888efc588b13ee1cda1b6a9f │ │ │ ├── mapjoin_distinct-2-53a3e706e797dc6b9e7f5ee8b100fa56 │ │ │ ├── mapjoin_distinct-3-4489654b888efc588b13ee1cda1b6a9f │ │ │ ├── mapjoin_distinct-4-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── mapjoin_distinct-5-a7dc16cb82c595b18d4258a38a304b1e │ │ │ ├── mapjoin_distinct-6-53a3e706e797dc6b9e7f5ee8b100fa56 │ │ │ ├── mapjoin_distinct-7-4489654b888efc588b13ee1cda1b6a9f │ │ │ ├── mapjoin_distinct-8-1d351f7e821fcaf66c6f7503e42fb291 │ │ │ ├── mapjoin_distinct-9-a00d1791b7fa7ac5a0505d95c3d12257 │ │ │ ├── mapjoin_filter_on_outerjoin-0-407016bf2679fb9e9d076a2d115e859d │ │ │ ├── mapjoin_filter_on_outerjoin-1-8c68ce10095a8924c68c8ee4b3c0071a │ │ │ ├── mapjoin_filter_on_outerjoin-2-8e5d5472f2e214c091c879f6830a0c │ │ │ ├── mapjoin_filter_on_outerjoin-3-381cc29f131d8caba744dd9fe6c121e7 │ │ │ ├── mapjoin_filter_on_outerjoin-4-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── mapjoin_filter_on_outerjoin-5-82cbc3186de23f3a2411e9ab87c0008c │ │ │ ├── mapjoin_filter_on_outerjoin-6-c6844de37be0926316f5fbf36a905306 │ │ │ ├── mapjoin_mapjoin-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── mapjoin_mapjoin-1-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── mapjoin_mapjoin-2-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── mapjoin_mapjoin-3-cb38700198e89779e4dc1b25026d92a1 │ │ │ ├── mapjoin_mapjoin-4-5166a5b9d30dfacbe33dd909c0df6310 │ │ │ ├── mapjoin_mapjoin-5-5ee898cab883074f3297198c52445ee4 │ │ │ ├── mapjoin_mapjoin-6-dca8c08a235b45d1cdcb94e363afb17 │ │ │ ├── mapjoin_mapjoin-7-fddbdea343a9ddb5f8dedc18147640b7 │ │ │ ├── mapjoin_mapjoin-8-2be637ed4f6146e8525ae1a863e72736 │ │ │ ├── mapjoin_mapjoin-9-c47698bac140454637a999e583941ce7 │ │ │ ├── mapjoin_subquery-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── mapjoin_subquery-1-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── mapjoin_subquery-2-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── mapjoin_subquery-3-4422532005e909173a4799d8d5091f1b │ │ │ ├── mapjoin_subquery-4-7df121f9774cb23edc557b98ad1e1924 │ │ │ ├── mapjoin_subquery-5-d9e59bfa950495629b7ba4bc6700405c │ │ │ ├── mapjoin_subquery-6-dcdc6b87a9b87b0ab10ad0e44a197f1b │ │ │ ├── mapjoin_subquery2-0-59fdb2842fbf4f530366f0237ff235e2 │ │ │ ├── mapjoin_subquery2-1-c0a9763a930555f846a2576d003fb517 │ │ │ ├── mapjoin_subquery2-10-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── mapjoin_subquery2-11-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── mapjoin_subquery2-12-7ebf0bee394756c0e0c78bdd1034f183 │ │ │ ├── mapjoin_subquery2-13-c876a518451059f17fc15e29f6f57951 │ │ │ ├── mapjoin_subquery2-14-59fdb2842fbf4f530366f0237ff235e2 │ │ │ ├── mapjoin_subquery2-15-c0a9763a930555f846a2576d003fb517 │ │ │ ├── mapjoin_subquery2-16-2f8ecc54049960ee4707f5e6f491fdf4 │ │ │ ├── mapjoin_subquery2-2-2f8ecc54049960ee4707f5e6f491fdf4 │ │ │ ├── mapjoin_subquery2-3-681c6f08aac965e4156dbd5800064a68 │ │ │ ├── mapjoin_subquery2-4-ab6020d67f5a99c0a87e630790507345 │ │ │ ├── mapjoin_subquery2-5-c0e460b0c5bceeeb5820a1240fa9f7d9 │ │ │ ├── mapjoin_subquery2-6-9bf06af695892b0d7067d5b30e0b2425 │ │ │ ├── mapjoin_subquery2-7-c6b0cdb137f13f8362c0c49c544151a4 │ │ │ ├── mapjoin_subquery2-8-131ae5ecfff2733b04bdfada0108cf40 │ │ │ ├── mapjoin_subquery2-9-24ca942f094b14b92086305cc125e833 │ │ │ ├── mapjoin_test_outer-0-407016bf2679fb9e9d076a2d115e859d │ │ │ ├── mapjoin_test_outer-1-b1ac944eac23eb8af1f1f659659c7bcc │ │ │ ├── mapjoin_test_outer-10-ce1ef910fff98f174931cc641f7cef3a │ │ │ ├── mapjoin_test_outer-11-cfaaae6c3ef2a5eb8cd7ec5065ca7795 │ │ │ ├── mapjoin_test_outer-12-80993ab7f757001e1f058bf8609f8420 │ │ │ ├── mapjoin_test_outer-13-a5d200c74f7000ad3e36fac90c980d34 │ │ │ ├── mapjoin_test_outer-14-7fe52008c4a98853d086d17fc3c21906 │ │ │ ├── mapjoin_test_outer-2-43561759b314d02b2dba5eb49a65c515 │ │ │ ├── mapjoin_test_outer-3-6ee8075ac3ad15ad1ac103d815544e7f │ │ │ ├── mapjoin_test_outer-4-9e1f369b391b4a050250e0a954ffbb8 │ │ │ ├── mapjoin_test_outer-5-c95eb9bb8b40a43691c4ef432d8f38b0 │ │ │ ├── mapjoin_test_outer-6-7fe52008c4a98853d086d17fc3c21906 │ │ │ ├── mapjoin_test_outer-7-ab7726921abfa43bb20ddfbc05f73c24 │ │ │ ├── mapjoin_test_outer-8-dfb08d397d3fe163d75c3b758097b68a │ │ │ ├── mapjoin_test_outer-9-6c45ce60b3dfce0e8bd19eedd57ee017 │ │ │ ├── mapreduce1-0-904b34e86c266384dc261655162dde3c │ │ │ ├── mapreduce1-1-e43492b1834d823a66b0f6499b7d2fe │ │ │ ├── mapreduce1-2-c32bd8b1734c410b3686469a7a3500e │ │ │ ├── mapreduce1-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── mapreduce2-0-904b34e86c266384dc261655162dde3c │ │ │ ├── mapreduce2-1-22edb61e7c8a162887c58ebbdc4e4a45 │ │ │ ├── mapreduce2-2-3442d32acb17e007a8f844b38fda9a1b │ │ │ ├── mapreduce2-3-adea843673e541da8a735a5a34e7c7dc │ │ │ ├── mapreduce3-0-904b34e86c266384dc261655162dde3c │ │ │ ├── mapreduce3-1-efaeccafc3db890b344dc6037266b71b │ │ │ ├── mapreduce3-2-51905797c8299159dc1cf1ef69cd7a9a │ │ │ ├── mapreduce3-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── mapreduce4-0-904b34e86c266384dc261655162dde3c │ │ │ ├── mapreduce4-1-7fed3aa9a8e544556f5b58f301d8bd2f │ │ │ ├── mapreduce4-2-6906be683bdd3666075760de019ac5ab │ │ │ ├── mapreduce4-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── mapreduce5-0-904b34e86c266384dc261655162dde3c │ │ │ ├── mapreduce5-1-52bff54eba53868ef3fd026cc6301a13 │ │ │ ├── mapreduce5-2-2cfcb0d4e390cd5fdd6d8a9bb26555ca │ │ │ ├── mapreduce5-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── mapreduce6-0-904b34e86c266384dc261655162dde3c │ │ │ ├── mapreduce6-1-d5ed2c0aafd39b76fa414194add93ffb │ │ │ ├── mapreduce6-2-c55bb2d4c519d62331671a5d7685f2b8 │ │ │ ├── mapreduce6-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── mapreduce7-0-78c8b5bf2d2a258066786ba03696ab82 │ │ │ ├── mapreduce7-1-8b7f1f886b749e43460052c98acd082a │ │ │ ├── mapreduce7-2-b57470174a24aa3861df022375754e90 │ │ │ ├── mapreduce7-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── mapreduce8-0-78c8b5bf2d2a258066786ba03696ab82 │ │ │ ├── mapreduce8-1-301e5bdcbbcdaea60348b3c24336629b │ │ │ ├── mapreduce8-2-ec9012d7823a6b1d0e97315c275e2ad8 │ │ │ ├── mapreduce8-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── merge1-0-593999fae618b6b38322bc9ae4e0c027 │ │ │ ├── merge1-1-2c73c923962b91afdf0004a705432550 │ │ │ ├── merge1-10-49d94c94e0a08155c9e5cb6e4efc6501 │ │ │ ├── merge1-11-dcc5d9564bb8df6bac382c82c33ccd87 │ │ │ ├── merge1-12-2e8e4adbfb21f25e7557dd86363c7138 │ │ │ ├── merge1-13-cb13a05d07f9f1ad6c43edfc8b0e9359 │ │ │ ├── merge1-14-dcc5d9564bb8df6bac382c82c33ccd87 │ │ │ ├── merge1-2-34854e1283de8e9ada3edd6bf897bc67 │ │ │ ├── merge1-3-1f560722f18ef618a0343313a0cac462 │ │ │ ├── merge1-4-3277fe538b66923cd879b45371838d2b │ │ │ ├── merge1-5-2f16345a20407b01e5cc5ae26ea902b0 │ │ │ ├── merge1-6-1c02b26792354eae7fb53fa3cb752ac1 │ │ │ ├── merge1-7-5570ef5461d4a5cd01ec91da3a474dd2 │ │ │ ├── merge1-8-37bd183ad3b7ad1e8550a138f7beb88a │ │ │ ├── merge1-9-64678b0928c4fd054e1578458001c86 │ │ │ ├── merge2-0-b12e5c70d6d29757471b900b6160fa8a │ │ │ ├── merge2-1-593999fae618b6b38322bc9ae4e0c027 │ │ │ ├── merge2-10-9f60e54bc4add2b1aff8473e2a756c79 │ │ │ ├── merge2-11-1c02b26792354eae7fb53fa3cb752ac1 │ │ │ ├── merge2-12-d2a36a13f8531cde3c66d4003048416 │ │ │ ├── merge2-13-37bd183ad3b7ad1e8550a138f7beb88a │ │ │ ├── merge2-14-64678b0928c4fd054e1578458001c86 │ │ │ ├── merge2-15-aaaf38f80d7313738a51a49bd5aa14c3 │ │ │ ├── merge2-16-d75f4405b860e4187882a72418ed6c83 │ │ │ ├── merge2-17-2e8e4adbfb21f25e7557dd86363c7138 │ │ │ ├── merge2-18-945682265ce2c1fe7fa69aeb57b4290f │ │ │ ├── merge2-19-d75f4405b860e4187882a72418ed6c83 │ │ │ ├── merge2-2-6142f47d3fcdd4323162014d5eb35e07 │ │ │ ├── merge2-3-10266e3d5dd4c841c0d65030b1edba7c │ │ │ ├── merge2-4-9cbd6d400fb6c3cd09010e3dbd76601 │ │ │ ├── merge2-5-1ba2d6f3bb3348da3fee7fab4f283f34 │ │ │ ├── merge2-6-319e3c6b684d2abd4dfd7314a05d4307 │ │ │ ├── merge2-7-fa2f100bc67426120cb97cfc75a5fb36 │ │ │ ├── merge2-8-7435e0bf03e747705b0858d5dcccfcc1 │ │ │ ├── merge2-9-b81efaa65e1263e48278ef9062cca1dd │ │ │ ├── merge4-0-b12e5c70d6d29757471b900b6160fa8a │ │ │ ├── merge4-1-593999fae618b6b38322bc9ae4e0c027 │ │ │ ├── merge4-10-692a197bd688b48f762e72978f54aa32 │ │ │ ├── merge4-11-f407e661307b23a5d52a08a3e7af19b │ │ │ ├── merge4-12-62541540a18d68a3cb8497a741061d11 │ │ │ ├── merge4-13-ed1103f06609365b40e78d13c654cc71 │ │ │ ├── merge4-14-ba5dbcd0527b8ddab284bc322255bfc7 │ │ │ ├── merge4-15-68f50dc2ad6ff803a372bdd88dd8e19a │ │ │ ├── merge4-2-43d53504df013e6b35f81811138a167a │ │ │ ├── merge4-3-a4fb8359a2179ec70777aad6366071b7 │ │ │ ├── merge4-4-16367c381d4b189b3640c92511244bfe │ │ │ ├── merge4-5-3d24d877366c42030f6d9a596665720d │ │ │ ├── merge4-6-b3a76420183795720ab3a384046e5af │ │ │ ├── merge4-7-631a45828eae3f5f562d992efe4cd56d │ │ │ ├── merge4-8-f407e661307b23a5d52a08a3e7af19b │ │ │ ├── merge4-9-ad3dc168c8b6f048717e39ab16b0a319 │ │ │ ├── mergejoins-0-90c36ed2dea064c1951856a1a2cd3d38 │ │ │ ├── mergejoins-1-63de7fdfd7513d63a4eadafc8534f69b │ │ │ ├── mergejoins-2-6b9f3810606db1e9036561f1173ac75c │ │ │ ├── mergejoins-3-c408f69470d652da283442a62b384e46 │ │ │ ├── mergejoins-4-80b6c6ce31a4d4e26f6d4be49beae996 │ │ │ ├── mergejoins-5-adae80fe415023783fca5499e3edf6e │ │ │ ├── mergejoins-6-6169410e9f077097d1a766724dfc51df │ │ │ ├── modulus-0-6afd4a359a478cfa3ebd9ad00ae3868e │ │ │ ├── multiMapJoin1-0-d2ea84f719d9ae2fb19e9e2a72c3d834 │ │ │ ├── multiMapJoin1-1-10b9657a205f63e6127e29e8b477b30a │ │ │ ├── multiMapJoin1-10-24ca942f094b14b92086305cc125e833 │ │ │ ├── multiMapJoin1-11-d814d6eb99b04dc19ae83dadf372c7aa │ │ │ ├── multiMapJoin1-12-204073e1287b0582d50e652d466f1e66 │ │ │ ├── multiMapJoin1-13-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── multiMapJoin1-14-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── multiMapJoin1-15-4ab52efffec4d72a5b01bd253eeddcf4 │ │ │ ├── multiMapJoin1-16-c14b300770b329ecb71e0275c88532d3 │ │ │ ├── multiMapJoin1-17-17e0bad549b265f8237e6c539b848dd5 │ │ │ ├── multiMapJoin1-18-49bc7f430b2591978067ca8f7d181cee │ │ │ ├── multiMapJoin1-19-51acc9734833601aa37e8da9f3a06b91 │ │ │ ├── multiMapJoin1-2-feca2d1242cf09e54dc177881a708842 │ │ │ ├── multiMapJoin1-20-6fb5b848305f559c6377cb7d34cc3216 │ │ │ ├── multiMapJoin1-21-79973475ca07cb9932f752f6547779ac │ │ │ ├── multiMapJoin1-22-25e434b6d05e08fdd5f4d9957438917 │ │ │ ├── multiMapJoin1-23-be8d26e5f6d5d41d5ce20b0ad443f0a │ │ │ ├── multiMapJoin1-24-feed626e3216bcbda66b17f48305b5a1 │ │ │ ├── multiMapJoin1-25-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── multiMapJoin1-26-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── multiMapJoin1-27-36bd62bd41b1a0dd13f12d8d813f1943 │ │ │ ├── multiMapJoin1-28-feed626e3216bcbda66b17f48305b5a1 │ │ │ ├── multiMapJoin1-29-ea23403b9eb55e8b06d1c198e439569f │ │ │ ├── multiMapJoin1-3-9280a4b7f1087dda801c81f3a5827785 │ │ │ ├── multiMapJoin1-30-d8c886592f60bedef5d8cb967adcead3 │ │ │ ├── multiMapJoin1-31-feed626e3216bcbda66b17f48305b5a1 │ │ │ ├── multiMapJoin1-32-e93301ee4ba157b466d7460775f3d350 │ │ │ ├── multiMapJoin1-33-7be587cefa8323cbe42cbf469b998f7b │ │ │ ├── multiMapJoin1-34-feed626e3216bcbda66b17f48305b5a1 │ │ │ ├── multiMapJoin1-4-53b81d2e161acea2ee58b7ac849ffe48 │ │ │ ├── multiMapJoin1-5-1e0b02b515a588ea99f6027f0aca36fe │ │ │ ├── multiMapJoin1-6-74628c956e66e192e0cfeb7bd09f8b73 │ │ │ ├── multiMapJoin1-7-23813f3b8b47a1f5c4a8ee57cc8a66ba │ │ │ ├── multiMapJoin1-8-273de5cc585b04ea2210d90c1755568c │ │ │ ├── multiMapJoin1-9-3df5ed60d70bc1a826a0e32c8019dc49 │ │ │ ├── multiMapJoin2-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── multiMapJoin2-1-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── multiMapJoin2-10-1905c7759350b107679aef86226739f8 │ │ │ ├── multiMapJoin2-11-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── multiMapJoin2-12-1d4f22cb25ffe3d84e73fe2acc81a92e │ │ │ ├── multiMapJoin2-13-6b984427a771fe650fa875be98722cbe │ │ │ ├── multiMapJoin2-14-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── multiMapJoin2-15-a4ac00f2a50cd08e7dd5543adb81972b │ │ │ ├── multiMapJoin2-16-6b984427a771fe650fa875be98722cbe │ │ │ ├── multiMapJoin2-17-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── multiMapJoin2-18-cb1f964731ee7ac045db89266a919586 │ │ │ ├── multiMapJoin2-19-77324702b091d514ca16d029f65d3d56 │ │ │ ├── multiMapJoin2-2-7f7f3daa7ff45944c3d534f9feff3bb6 │ │ │ ├── multiMapJoin2-20-777edd9d575f3480ca6cebe4be57b1f6 │ │ │ ├── multiMapJoin2-21-3db633aa7d2c47682bb15024d6abdd33 │ │ │ ├── multiMapJoin2-22-77324702b091d514ca16d029f65d3d56 │ │ │ ├── multiMapJoin2-23-18139096bb78fa5080054686f27e5e9 │ │ │ ├── multiMapJoin2-24-e148026f8994e22ca756c68753a0cc26 │ │ │ ├── multiMapJoin2-25-b04195464e014cb47fd20a76b5f9ac0 │ │ │ ├── multiMapJoin2-26-2136f3783a9764de762e49c1ca28637f │ │ │ ├── multiMapJoin2-27-d28d0f671f5d913a56d75812d24cca8e │ │ │ ├── multiMapJoin2-28-c14792ccac2ca64e3e9e21af4fd12d2c │ │ │ ├── multiMapJoin2-29-b9d963d24994c47c3776dda6f7d3881f │ │ │ ├── multiMapJoin2-3-622f276b2eb5d55649a7a8689aacea5d │ │ │ ├── multiMapJoin2-30-6d1c7f7014fc709148b0f401c5f23cb3 │ │ │ ├── multiMapJoin2-31-2e9c4d5e2bd709e96f311488ada116b0 │ │ │ ├── multiMapJoin2-4-5ede8243cc4ba2fbd24a77578502a656 │ │ │ ├── multiMapJoin2-5-21f96f651fb4f28ae5e2999fc1f82192 │ │ │ ├── multiMapJoin2-6-d7733ae25ad6fcb1bac1135271732502 │ │ │ ├── multiMapJoin2-7-5ede8243cc4ba2fbd24a77578502a656 │ │ │ ├── multiMapJoin2-8-7f7f3daa7ff45944c3d534f9feff3bb6 │ │ │ ├── multiMapJoin2-9-e14b355524f37fe25ebbb59b52e12c74 │ │ │ ├── multi_insert_gby-0-18cb60d5d7080d1eda9b830f50cfa782 │ │ │ ├── multi_insert_gby-1-9e61989d717403353689cbbb2816210d │ │ │ ├── multi_insert_gby-2-fdf89a7c60b9edcb2250efdfd1033a17 │ │ │ ├── multi_insert_gby-3-ed2c89fc9e4cfc07730c312b9e07d721 │ │ │ ├── multi_insert_gby-4-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── multi_insert_gby-5-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── multi_insert_gby-6-b601e40a9c3bb8144a0447ec829ae49c │ │ │ ├── multi_insert_gby-7-6c0583ab6194b67a00b19a8ec9deec5f │ │ │ ├── multi_insert_gby-8-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── multi_insert_gby-9-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── multi_insert_gby3-0-60cf2dfb2a416f328a2fd58710eb6f01 │ │ │ ├── multi_insert_gby3-1-cb42e494ade413e7bd1e426e5d6f60a │ │ │ ├── multi_insert_gby3-10-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── multi_insert_gby3-11-717e2a1f7f5b7e8a0ef61cad13af4acc │ │ │ ├── multi_insert_gby3-12-33d7e716735d24b7493209810d0b865f │ │ │ ├── multi_insert_gby3-2-e2ee7089ea7db95d7bd86cae6f3f4bb6 │ │ │ ├── multi_insert_gby3-3-5ae64ea7cfb7bef5a99d788016213fca │ │ │ ├── multi_insert_gby3-4-6d713dc60fa4c07fb9de4a93db36fed0 │ │ │ ├── multi_insert_gby3-5-a66621daa1b2479beee5681a22d9d712 │ │ │ ├── multi_insert_gby3-6-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── multi_insert_gby3-7-a9a491ed99b4629ee15bce994d5c6c63 │ │ │ ├── multi_insert_gby3-8-2ed91b92a6ca38b4ccb4acf52ee4e47b │ │ │ ├── multi_insert_gby3-9-521e0c1054cfa35116c02245874a4e69 │ │ │ ├── multi_insert_lateral_view-0-531b7044d2fdaba4fff0094c4efdaf54 │ │ │ ├── multi_insert_lateral_view-1-3ed6bfa23add415990b443fc232b4ba0 │ │ │ ├── multi_insert_lateral_view-10-f26c10c6495fc3e86319cd5815caab4f │ │ │ ├── multi_insert_lateral_view-11-6c6b1588ab62ad11aef3a1147a2c7874 │ │ │ ├── multi_insert_lateral_view-12-622f0dd66c8633307fe56ccf9015f430 │ │ │ ├── multi_insert_lateral_view-13-2c71748cfcdb9cc773d9ee61ae508b91 │ │ │ ├── multi_insert_lateral_view-14-f26c10c6495fc3e86319cd5815caab4f │ │ │ ├── multi_insert_lateral_view-15-6c6b1588ab62ad11aef3a1147a2c7874 │ │ │ ├── multi_insert_lateral_view-16-33963ba7aefb7ab9a25afd540ecbbe98 │ │ │ ├── multi_insert_lateral_view-17-3219cf4fab8bf343bd273bd3a681fa46 │ │ │ ├── multi_insert_lateral_view-18-bfe7dcb00f8b27e00d406de603635c8a │ │ │ ├── multi_insert_lateral_view-19-f26c10c6495fc3e86319cd5815caab4f │ │ │ ├── multi_insert_lateral_view-2-6ced0ab5d543a2c5c6c7f7e27ed04814 │ │ │ ├── multi_insert_lateral_view-20-6c6b1588ab62ad11aef3a1147a2c7874 │ │ │ ├── multi_insert_lateral_view-21-33963ba7aefb7ab9a25afd540ecbbe98 │ │ │ ├── multi_insert_lateral_view-22-283e0f384d0a015c252b34f79a895286 │ │ │ ├── multi_insert_lateral_view-23-2f3b8b5fd961ee336d893cd45dc2696d │ │ │ ├── multi_insert_lateral_view-24-4ed7df348bd8bf3fd275e15b6689c5df │ │ │ ├── multi_insert_lateral_view-25-f26c10c6495fc3e86319cd5815caab4f │ │ │ ├── multi_insert_lateral_view-26-6c6b1588ab62ad11aef3a1147a2c7874 │ │ │ ├── multi_insert_lateral_view-27-33963ba7aefb7ab9a25afd540ecbbe98 │ │ │ ├── multi_insert_lateral_view-28-24e041343e158735db6262136de0e8b8 │ │ │ ├── multi_insert_lateral_view-3-a60af91a18d481fe1244e21108133489 │ │ │ ├── multi_insert_lateral_view-4-67a95497041a0e81b4d5756731d8b27d │ │ │ ├── multi_insert_lateral_view-5-b847c5dfb2f0395cfdd21f93de611b91 │ │ │ ├── multi_insert_lateral_view-6-f26c10c6495fc3e86319cd5815caab4f │ │ │ ├── multi_insert_lateral_view-7-6c6b1588ab62ad11aef3a1147a2c7874 │ │ │ ├── multi_insert_lateral_view-8-a3eabeb4435c69ec4e242b8857c84e31 │ │ │ ├── multi_insert_lateral_view-9-59102a6d824074da6cc85ca760385975 │ │ │ ├── multi_join_union-0-24ca942f094b14b92086305cc125e833 │ │ │ ├── multi_join_union-1-af5c56bf13aaeff13d2bd7d3b9315d3b │ │ │ ├── multi_join_union-2-97ea2263579f8d63dfdb1a6992fe0284 │ │ │ ├── multi_join_union-3-a164ae7bcb7c95beb8045b7064c9ab14 │ │ │ ├── multi_join_union-4-8c17422bd7041c596677251a46fa4085 │ │ │ ├── multi_join_union-5-9e89b8619411f46f675a9fab73298627 │ │ │ ├── multigroupby_singlemr-0-ae394b9d8cf6106b68fb2f40e8f1fae │ │ │ ├── multigroupby_singlemr-1-e67c221c0c19df7b3dc48b99426cf667 │ │ │ ├── multigroupby_singlemr-2-31e7358a9f1e474e67155396fe803967 │ │ │ ├── multigroupby_singlemr-3-d676a455ef6e9ec68756b0c1487dc3b1 │ │ │ ├── multigroupby_singlemr-4-13bade1e01aed5d7e1af33a28a3b3574 │ │ │ ├── multigroupby_singlemr-5-c5f3f0a3ff1730f6daf04dcd78b74651 │ │ │ ├── multigroupby_singlemr-6-80cb19f7a801a82add47a501756c8af7 │ │ │ ├── multigroupby_singlemr-7-f8a4f52cd86ee679923248e09dd312e3 │ │ │ ├── multigroupby_singlemr-8-985e6ff98c02a64d47b25817e9fef310 │ │ │ ├── multigroupby_singlemr-9-faa99964430e2aee836221de1abe1c5e │ │ │ ├── no from clause-0-b42b408a87b258921240058f880a721a │ │ │ ├── noalias_subq1-0-da2a1169620860b3dc558d21c6c5ea50 │ │ │ ├── noalias_subq1-1-f91e87acd51f7477d96620b5f9deece6 │ │ │ ├── nomore_ambiguous_table_col-0-535a12e87c72793bfba96520a0ea251b │ │ │ ├── nomore_ambiguous_table_col-1-8535e6c322e40f46b9a6e02fe6033ee0 │ │ │ ├── nomore_ambiguous_table_col-2-c2b97a35777322fe4a08d8c2216cb223 │ │ │ ├── nomore_ambiguous_table_col-3-29a7783c88e234ba32eaf1401ca8cc22 │ │ │ ├── nonblock_op_deduplicate-0-61c5ece0d210cf6158094f0f6fa24532 │ │ │ ├── nonblock_op_deduplicate-1-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── nonblock_op_deduplicate-2-11ee085c0190a4007f410ddf96803ec0 │ │ │ ├── nonblock_op_deduplicate-3-a873d2d6991308b21ecdc46ac777c716 │ │ │ ├── nonblock_op_deduplicate-4-24ca942f094b14b92086305cc125e833 │ │ │ ├── nonblock_op_deduplicate-5-250d196b4449c835ddc518db2d2ab726 │ │ │ ├── nonblock_op_deduplicate-6-a873d2d6991308b21ecdc46ac777c716 │ │ │ ├── notable_alias1-0-695de796f21dce21056f8ba27cbadb0d │ │ │ ├── notable_alias1-1-c4d51044e6802df266aa0dc137b825cd │ │ │ ├── notable_alias1-2-bea59f268594a034d06b826c7a8e516e │ │ │ ├── notable_alias1-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── notable_alias2-0-695de796f21dce21056f8ba27cbadb0d │ │ │ ├── notable_alias2-1-20b7bf01acc8d88670d347e6759aa407 │ │ │ ├── notable_alias2-2-19c4fba994e06b28e0d912a6aa13ab78 │ │ │ ├── notable_alias2-3-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── null case-0-581cdfe70091e546414b202da2cebdcb │ │ │ ├── nullformatCTAS-0-36f9196395758cebfed837a1c391a1e │ │ │ ├── nullformatCTAS-1-b5a31d4cb34218b8de1ac3fed59fa75b │ │ │ ├── nullformatCTAS-10-7f4f04b87c7ef9653b4646949b24cf0b │ │ │ ├── nullformatCTAS-11-4a4c16b53c612d00012d338c97bf5281 │ │ │ ├── nullformatCTAS-12-7f4f04b87c7ef9653b4646949b24cf0b │ │ │ ├── nullformatCTAS-13-2e59caa113585495d8684fee69d88bc0 │ │ │ ├── nullformatCTAS-14-ad9fe9d68c2cf492259af4f6167c1b12 │ │ │ ├── nullformatCTAS-2-aa2bdbd93668dceae43d1a02f2ede68d │ │ │ ├── nullformatCTAS-3-b0057150f237050f38c1efa1f2d6b273 │ │ │ ├── nullformatCTAS-4-16c7086f39d6458b6c5cf2479f0473bd │ │ │ ├── nullformatCTAS-5-183d77b734ce6a373de5b3ebe1cd04c9 │ │ │ ├── nullformatCTAS-6-159fff36b548e00ee952d1df8ef19833 │ │ │ ├── nullformatCTAS-7-46900b082b02ce3e58087d1f41128f65 │ │ │ ├── nullformatCTAS-8-7f26cbd6be5631a3acce26f667d1c5d8 │ │ │ ├── nullformatCTAS-9-22e1b3899de7087b39c24d9d8f643b47 │ │ │ ├── nullgroup-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── nullgroup-10-3994c1896dace613fa9f837b2f1676c0 │ │ │ ├── nullgroup-11-54a5fd76cdeff565c8c7724695aca302 │ │ │ ├── nullgroup-12-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup-13-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup-14-3994c1896dace613fa9f837b2f1676c0 │ │ │ ├── nullgroup-15-54a5fd76cdeff565c8c7724695aca302 │ │ │ ├── nullgroup-2-3994c1896dace613fa9f837b2f1676c0 │ │ │ ├── nullgroup-3-54a5fd76cdeff565c8c7724695aca302 │ │ │ ├── nullgroup-4-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup-5-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup-6-3994c1896dace613fa9f837b2f1676c0 │ │ │ ├── nullgroup-7-54a5fd76cdeff565c8c7724695aca302 │ │ │ ├── nullgroup-8-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup-9-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── nullgroup2-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup2-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── nullgroup2-10-751fa56a198ad840868c76ad7ce2a6a0 │ │ │ ├── nullgroup2-11-644b68261df70bbb46a3045a8abde17a │ │ │ ├── nullgroup2-12-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup2-13-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup2-14-751fa56a198ad840868c76ad7ce2a6a0 │ │ │ ├── nullgroup2-15-644b68261df70bbb46a3045a8abde17a │ │ │ ├── nullgroup2-2-751fa56a198ad840868c76ad7ce2a6a0 │ │ │ ├── nullgroup2-3-644b68261df70bbb46a3045a8abde17a │ │ │ ├── nullgroup2-4-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup2-5-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup2-6-751fa56a198ad840868c76ad7ce2a6a0 │ │ │ ├── nullgroup2-7-644b68261df70bbb46a3045a8abde17a │ │ │ ├── nullgroup2-8-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup2-9-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── nullgroup3-0-d7ed4ae23442da095677d751a2b86c99 │ │ │ ├── nullgroup3-1-61ead7f73d525e0d9e21beba91a3d39e │ │ │ ├── nullgroup3-10-a6455ec10891deb352bca6ccab2a8bf8 │ │ │ ├── nullgroup3-11-d7ed4ae23442da095677d751a2b86c99 │ │ │ ├── nullgroup3-12-61ead7f73d525e0d9e21beba91a3d39e │ │ │ ├── nullgroup3-13-a5e12cfbc1799ce9fa9628d81b8c0b06 │ │ │ ├── nullgroup3-14-d4e815f44f6369c991ea4390c481f31e │ │ │ ├── nullgroup3-15-cd90e16da918bac569e9f04faaedd280 │ │ │ ├── nullgroup3-16-af767d7cfb4601ace72a3ed718071931 │ │ │ ├── nullgroup3-17-45699aee54227552bb3ec84d92dfe450 │ │ │ ├── nullgroup3-18-113e2b587784d54d2a5b5f091389397e │ │ │ ├── nullgroup3-19-77de4b2d65eee228848625cdd422178d │ │ │ ├── nullgroup3-2-a5e12cfbc1799ce9fa9628d81b8c0b06 │ │ │ ├── nullgroup3-20-29fb8e3c12b8a705bc67d55a10566141 │ │ │ ├── nullgroup3-21-e09c6bf2f6112981793fbd4386d43ff6 │ │ │ ├── nullgroup3-3-d4e815f44f6369c991ea4390c481f31e │ │ │ ├── nullgroup3-4-cd90e16da918bac569e9f04faaedd280 │ │ │ ├── nullgroup3-5-45699aee54227552bb3ec84d92dfe450 │ │ │ ├── nullgroup3-6-113e2b587784d54d2a5b5f091389397e │ │ │ ├── nullgroup3-7-77de4b2d65eee228848625cdd422178d │ │ │ ├── nullgroup3-8-29fb8e3c12b8a705bc67d55a10566141 │ │ │ ├── nullgroup3-9-e09c6bf2f6112981793fbd4386d43ff6 │ │ │ ├── nullgroup4-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup4-1-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── nullgroup4-10-3a3f180144fead81b9e8b232b4132762 │ │ │ ├── nullgroup4-11-a37f94e6d2b4c99053d29a576ebaa56 │ │ │ ├── nullgroup4-12-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup4-13-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup4-14-3a3f180144fead81b9e8b232b4132762 │ │ │ ├── nullgroup4-15-a37f94e6d2b4c99053d29a576ebaa56 │ │ │ ├── nullgroup4-2-3a3f180144fead81b9e8b232b4132762 │ │ │ ├── nullgroup4-3-a37f94e6d2b4c99053d29a576ebaa56 │ │ │ ├── nullgroup4-4-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup4-5-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup4-6-3a3f180144fead81b9e8b232b4132762 │ │ │ ├── nullgroup4-7-a37f94e6d2b4c99053d29a576ebaa56 │ │ │ ├── nullgroup4-8-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup4-9-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── nullgroup4_multi_distinct-0-dbcec232623048c7748b708123e18bf0 │ │ │ ├── nullgroup4_multi_distinct-1-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup4_multi_distinct-2-43dec71d76c386394196a0e9d69457e5 │ │ │ ├── nullgroup4_multi_distinct-3-c39b8f64123f56a05cdb0022a69f29b3 │ │ │ ├── nullgroup4_multi_distinct-4-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── nullgroup4_multi_distinct-5-85c4f90b754cd88147d6b74e17d22063 │ │ │ ├── nullgroup4_multi_distinct-6-43dec71d76c386394196a0e9d69457e5 │ │ │ ├── nullgroup4_multi_distinct-7-c39b8f64123f56a05cdb0022a69f29b3 │ │ │ ├── nullgroup5-0-d7ed4ae23442da095677d751a2b86c99 │ │ │ ├── nullgroup5-1-642e12a05bf01a6716bfa15ed0012629 │ │ │ ├── nullgroup5-2-45699aee54227552bb3ec84d92dfe450 │ │ │ ├── nullgroup5-3-35517978e09aa1bd1d15f51d11e08fd5 │ │ │ ├── nullgroup5-4-14e2854b364b68e7526a52e6e8f7c94e │ │ │ ├── nullgroup5-5-60d7180632a63c79eeba47e30b854f4c │ │ │ ├── nullinput-0-2be9511f8cb3c9edaf50353187f24c11 │ │ │ ├── nullinput-1-bf48040d6cc6213cba90dbd76a796a66 │ │ │ ├── nullinput-2-61efe55ed8fef84e4cb8f9d7c317fabf │ │ │ ├── nullinput2-0-40b73200f853b473855e85eba391f008 │ │ │ ├── nullinput2-1-507c5a854d930361d8db66a3b90a5388 │ │ │ ├── nullinput2-2-21058230c4992a682c4adef9881fa9a2 │ │ │ ├── nullscript-0-4477b1566208a6805bb20630755a9375 │ │ │ ├── nullscript-1-f07dfd6ef687e038083deca5941d8174 │ │ │ ├── nullscript-2-bb1abcf2f4a2a5cd5c058104901627bb │ │ │ ├── nullscript-3-56d47cf9468111b12fcef408bc767271 │ │ │ ├── nullscript-4-472199a0c6b8f760a90863deb69e9710 │ │ │ ├── optional_outer-0-c157cc7014eda416b6248cf56165b62a │ │ │ ├── optional_outer-1-25aa8f4a1194304b0afc57a6b2c80205 │ │ │ ├── optional_outer-2-7871ab752b7065f13fb808c8d7cdb35f │ │ │ ├── optional_outer-3-4815a6c9014b80a79f61ab983dcdd23a │ │ │ ├── optional_outer-4-9519008c6ef6e8ed651c7f4405589c34 │ │ │ ├── optional_outer-5-4a868da4f3f6d96124bff2cf50a2673e │ │ │ ├── orc_dictionary_threshold-0-a399c0ef0f1578f9d2456727008dee16 │ │ │ ├── orc_dictionary_threshold-1-a2f8227aafaee48079235d466c5049a0 │ │ │ ├── orc_dictionary_threshold-2-939fd158d52e04da7ff5c13e74f51a8c │ │ │ ├── orc_dictionary_threshold-3-1a7f96f49e2992b93d97edcbdb0075d │ │ │ ├── orc_dictionary_threshold-4-f3df937417e80909d4a4b220779173b0 │ │ │ ├── orc_dictionary_threshold-5-f5387ae613d41813186d7f1399545b02 │ │ │ ├── orc_dictionary_threshold-6-6ced6a6f5189c7a315d92ebf3dcc68d3 │ │ │ ├── orc_dictionary_threshold-7-acf39b28d4b76382acf5c56c21932ff9 │ │ │ ├── orc_dictionary_threshold-8-fe11a21ffbfa65e71ab62263077192a8 │ │ │ ├── orc_dictionary_threshold-9-f7b722063a6948d22aaaab0707cddde1 │ │ │ ├── orc_empty_files-0-eedb40290338ab680a930542cc7ddf0c │ │ │ ├── orc_empty_files-1-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── orc_empty_files-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── orc_empty_files-3-86a409d8b868dc5f1a3bd1e04c2bc28c │ │ │ ├── orc_empty_files-4-9c1451024d868c99833bbe1173c703d4 │ │ │ ├── orc_empty_files-5-8c5d1eb83ebab33e284d70b11c4bc722 │ │ │ ├── order-0-5c2fda577771db3b316e0d2bd02d048a │ │ │ ├── order-1-57d93bd7619dfc460dfa763c12142bb9 │ │ │ ├── order-2-fe90320d98850ea5e9b6100f6d259fbf │ │ │ ├── order-3-8f2ca0c3a07d78ebfff23a7bc77e85e5 │ │ │ ├── order2-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── order2-1-484c94d6b57ccc9fffda150bee0bccdf │ │ │ ├── order2-2-4162aa366dc0836eed15cc819226907f │ │ │ ├── outer_join_ppr-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── outer_join_ppr-1-1a374dec627d7109276f008f31be517c │ │ │ ├── outer_join_ppr-2-b60ab17f7372863504804717c4276595 │ │ │ ├── outer_join_ppr-3-5924d0d5ab868c05f488ed741a1955ba │ │ │ ├── outer_join_ppr-4-be64a45a645ea5363109323a378d335 │ │ │ ├── parallel-0-6dc30e2de057022e63bd2a645fbec4c2 │ │ │ ├── parallel-1-851e262128626126ae1ad87869db7c54 │ │ │ ├── parallel-10-d196279de0b7c4b42521aa23634ca506 │ │ │ ├── parallel-11-6230286bc168af7b010968b543690a2a │ │ │ ├── parallel-12-73a915d42e62c0e895a82602a502ee43 │ │ │ ├── parallel-2-43d53504df013e6b35f81811138a167a │ │ │ ├── parallel-3-195007722f0c2921f9c6c1eb461b6d2a │ │ │ ├── parallel-4-fcf032bbe1f1569d934da7090db60a83 │ │ │ ├── parallel-5-e27b511ffc5828b09069121031d17a2f │ │ │ ├── parallel-6-d196279de0b7c4b42521aa23634ca506 │ │ │ ├── parallel-7-6230286bc168af7b010968b543690a2a │ │ │ ├── parallel-8-73a915d42e62c0e895a82602a502ee43 │ │ │ ├── parallel-9-86a409d8b868dc5f1a3bd1e04c2bc28c │ │ │ ├── parenthesis_star_by-0-57a4ea931689f9475b687292f34abfa4 │ │ │ ├── parenthesis_star_by-1-41d474f5e6d7c61c36f74b4bec4e9e44 │ │ │ ├── parenthesis_star_by-2-7a45831bf96814d9a7fc3d78fb7bd8dc │ │ │ ├── parenthesis_star_by-3-498e2973594ccf45448ba19552bfb1cd │ │ │ ├── parenthesis_star_by-4-dc9d9d8bbb6259c89a97065902a345ec │ │ │ ├── parenthesis_star_by-5-41d474f5e6d7c61c36f74b4bec4e9e44 │ │ │ ├── parenthesis_star_by-6-6b7a4fa7be24cf775fae1b8c540c3b02 │ │ │ ├── parenthesis_star_by-7-f36c71c612ab8da4f4191980c1b61fea │ │ │ ├── part_inherit_tbl_props-0-8ea0fbf5d1f4c19b56bda7f05764a0c0 │ │ │ ├── part_inherit_tbl_props-1-797247d3ab7d2f3cd6fb33ad57ac7298 │ │ │ ├── part_inherit_tbl_props-2-7bf3b5a09ed6cd06f27a0616de64ceb │ │ │ ├── part_inherit_tbl_props-3-7e6487ca8473fa3264fdd9fa3e4a2db2 │ │ │ ├── part_inherit_tbl_props-4-c04c695a6ebed215889ce75edcb33eb4 │ │ │ ├── part_inherit_tbl_props_empty-0-c367ba7f534037ab96efc7f2273508c7 │ │ │ ├── part_inherit_tbl_props_empty-1-d697ec36ecf73b0ee789972e6980e460 │ │ │ ├── part_inherit_tbl_props_empty-2-7bf3b5a09ed6cd06f27a0616de64ceb │ │ │ ├── part_inherit_tbl_props_empty-3-7e6487ca8473fa3264fdd9fa3e4a2db2 │ │ │ ├── part_inherit_tbl_props_with_star-0-9131f0b22a7303a9f3bd9ec0d1c85b06 │ │ │ ├── part_inherit_tbl_props_with_star-1-797247d3ab7d2f3cd6fb33ad57ac7298 │ │ │ ├── part_inherit_tbl_props_with_star-2-7bf3b5a09ed6cd06f27a0616de64ceb │ │ │ ├── part_inherit_tbl_props_with_star-3-7e6487ca8473fa3264fdd9fa3e4a2db2 │ │ │ ├── part_inherit_tbl_props_with_star-4-c04c695a6ebed215889ce75edcb33eb4 │ │ │ ├── partcols1-0-e234d14f9b1beb190c3c13d22ff02a0a │ │ │ ├── partcols1-1-b562ff3e36de23a686d122967a1f91c8 │ │ │ ├── partcols1-2-1fac765c5b4e1a8e4358f3babafd14e5 │ │ │ ├── partition_based_table_scan_with_different_serde-0-1436cccda63b78dd6e43a399da6cc474 │ │ │ ├── partition_based_table_scan_with_different_serde-1-8d9bf54373f45bc35f8cb6e82771b154 │ │ │ ├── partition_based_table_scan_with_different_serde-2-7816c17905012cf381abf93d230faa8d │ │ │ ├── partition_based_table_scan_with_different_serde-3-90089a6db3c3d8ee5ff5ea6b9153b3cc │ │ │ ├── partition_based_table_scan_with_different_serde-4-8caed2a6e80250a6d38a59388679c298 │ │ │ ├── partition_date-0-7ec1f3a845e2c49191460e15af30aa30 │ │ │ ├── partition_date-1-6b0952309c3ebdd6dcb7066891d1bd74 │ │ │ ├── partition_date-1-916193405ce5e020dcd32c58325db6fe │ │ │ ├── partition_date-10-a8dde9c0b5746dd770c9c262d23ffb10 │ │ │ ├── partition_date-10-aad6078a09b7bd8f5141437e86bb229f │ │ │ ├── partition_date-11-a01c3791f59e819c750e213b6c65d084 │ │ │ ├── partition_date-11-fdface2fb6eef67f15bb7d0de2294957 │ │ │ ├── partition_date-12-2662a237c86cf9e4a150a4f1856b8239 │ │ │ ├── partition_date-12-9b945f8ece6e09ad28c866ff3a10cc24 │ │ │ ├── partition_date-13-aa513c8ee1cbfd1c94f5772c110d4dc9 │ │ │ ├── partition_date-13-b7cb91c7c459798078a79071d329dbf │ │ │ ├── partition_date-14-3f187dad9a2fdfc6f7a3566309016f9c │ │ │ ├── partition_date-14-e4366325f3a0c4a8e92be59f4de73fce │ │ │ ├── partition_date-15-a062a6e87867d8c8cfbdad97bedcbe5f │ │ │ ├── partition_date-15-e4366325f3a0c4a8e92be59f4de73fce │ │ │ ├── partition_date-16-22a5627d9ac112665eae01d07a91c89c │ │ │ ├── partition_date-16-32cf81c1a36451eccb07b20dffd930ac │ │ │ ├── partition_date-17-8654528691598a5eef8e3c1059d24117 │ │ │ ├── partition_date-17-b9ce94ef93cb16d629af7d7f8ee637e │ │ │ ├── partition_date-18-72c6e9a4e0b434cef67144825346c687 │ │ │ ├── partition_date-18-a1e769630ac3caed7325a3a256713b24 │ │ │ ├── partition_date-19-44e5165eb210559e420105073bc96125 │ │ │ ├── partition_date-19-95f1399e12124840caee7492c0f3036d │ │ │ ├── partition_date-2-220048240a7050a98411ddbc6b1f82cf │ │ │ ├── partition_date-2-e2e70ac0f4e0ea987b49b86f73d819c9 │ │ │ ├── partition_date-20-7ec1f3a845e2c49191460e15af30aa30 │ │ │ ├── partition_date-20-e734eb4fc8894c9a2b2b9cdac4270fba │ │ │ ├── partition_date-21-b60c0a3677591991152a0aa500bdce68 │ │ │ ├── partition_date-22-fe277bd0a30e016826d242fd5bd61714 │ │ │ ├── partition_date-23-7f014b494185e4c2a6048efb89131344 │ │ │ ├── partition_date-24-7ec1f3a845e2c49191460e15af30aa30 │ │ │ ├── partition_date-3-c938b08f57d588926a5d5fbfa4531012 │ │ │ ├── partition_date-3-f8887dd18c21bf0306e293d463b3e1d7 │ │ │ ├── partition_date-4-a93eff99ce43bb939ec1d6464c0ef0b3 │ │ │ ├── partition_date-4-f7c20c208e052305c1710a5e1e80c5c8 │ │ │ ├── partition_date-5-59355f4e222dcd4f77f51d15bd896f11 │ │ │ ├── partition_date-5-a855aba47876561fd4fb095e09580686 │ │ │ ├── partition_date-6-1405c311915f27b0cc616c83d39eaacc │ │ │ ├── partition_date-6-416ab10ac818d432cd3a81870d6e5164 │ │ │ ├── partition_date-7-1405c311915f27b0cc616c83d39eaacc │ │ │ ├── partition_date-7-2ac950d8d5656549dd453e5464cb8530 │ │ │ ├── partition_date-8-7703adfcfdd44c9250f9eba478004714 │ │ │ ├── partition_date-8-a425c11c12c9ce4c9c43d4fbccee5347 │ │ │ ├── partition_date-9-a425c11c12c9ce4c9c43d4fbccee5347 │ │ │ ├── partition_date-9-aad6078a09b7bd8f5141437e86bb229f │ │ │ ├── partition_serde_format-0-65b98f7ed3ca5907e7ca5206de94939d │ │ │ ├── partition_serde_format-1-37d3a88b6b22de326dbc1f4cba6b7cd1 │ │ │ ├── partition_serde_format-2-47b559b01e389cc9e327a2fd29255acf │ │ │ ├── partition_serde_format-3-54d18742b4eab85edd1946ef139771b4 │ │ │ ├── partition_type_check-0-b500f9a7ff3ef4ea3046cbaee22f434c │ │ │ ├── partition_type_check-1-e676cfebd53fcc4c86407028dff8ddaa │ │ │ ├── partition_type_check-10-d51791c8b809ac86dc5b0f493a938fc │ │ │ ├── partition_type_check-11-60aad884be613d18d3b89fca3b90dc94 │ │ │ ├── partition_type_check-12-7e053ba4f9dea1e74c1d04c557c3adac │ │ │ ├── partition_type_check-13-45fb706ff448da1fe609c7ff76a80d4d │ │ │ ├── partition_type_check-2-3a6bb204d9524299f28adf1cc35d6f4d │ │ │ ├── partition_type_check-3-7880e06d5cff6ea961dba5ff533cf346 │ │ │ ├── partition_type_check-4-45fb706ff448da1fe609c7ff76a80d4d │ │ │ ├── partition_type_check-5-4a0b90a674d255ce00dd417dfefc46d4 │ │ │ ├── partition_type_check-6-663051c7106b8ee6913ca1b007157941 │ │ │ ├── partition_type_check-7-7880e06d5cff6ea961dba5ff533cf346 │ │ │ ├── partition_type_check-8-45fb706ff448da1fe609c7ff76a80d4d │ │ │ ├── partition_type_check-9-57b300095c52fd652e1d414724523587 │ │ │ ├── partition_varchar1-0-ec359154c4bad3bfce1b7ab4914d1554 │ │ │ ├── partition_varchar1-1-5064ea12af064b5e040d7b9ebd08b940 │ │ │ ├── partition_varchar1-10-1839df813809f21d8e0a0dd0006c7eb1 │ │ │ ├── partition_varchar1-11-83bf857460d5f49bf4bf6e480d9ce36 │ │ │ ├── partition_varchar1-12-299a7b630adb14d0f6a8ea8f2e528489 │ │ │ ├── partition_varchar1-13-4b9a64b41647af09b2f420c3b23b811c │ │ │ ├── partition_varchar1-14-c07f977014280e92c02f24bb3ea0ec68 │ │ │ ├── partition_varchar1-15-6442628796f33b87ef1ca11945fa4b48 │ │ │ ├── partition_varchar1-16-3300093c71a371aed6225ffa9e05fc3d │ │ │ ├── partition_varchar1-17-367ed375dd11bf57d5ab4288289a11d2 │ │ │ ├── partition_varchar1-18-3df8ffe4c220764e59efb874bab97b9a │ │ │ ├── partition_varchar1-19-ec359154c4bad3bfce1b7ab4914d1554 │ │ │ ├── partition_varchar1-2-bca5c9edccc3a84e0a9ef92ebcbe746 │ │ │ ├── partition_varchar1-3-9cec4b1d156f5a9cb587470b98de15 │ │ │ ├── partition_varchar1-4-e9c4530e270db6d44cc54292e4eff680 │ │ │ ├── partition_varchar1-5-661aefd18c44c1eb02c2aaf8fab59f73 │ │ │ ├── partition_varchar1-6-ad21f89ac813692cf47343c66e302ea6 │ │ │ ├── partition_varchar1-7-be5b3ad809173ec5dab8fb3d29b6cb0e │ │ │ ├── partition_varchar1-8-6b968247a2c615af03fc6a386d72db9b │ │ │ ├── partition_varchar1-9-45412c7f1eb448dfd5d5eb636fa1d8a0 │ │ │ ├── partition_wise_fileformat9-0-66ee62178e3576fb38cb09800cb610bf │ │ │ ├── partition_wise_fileformat9-1-22e3d59a0423473051535684bca72b27 │ │ │ ├── partition_wise_fileformat9-2-55ae9fbf6daa36225dd386e34025dd38 │ │ │ ├── partition_wise_fileformat9-3-92bfcf88ca528eb6c9259142bf6541e5 │ │ │ ├── partition_wise_fileformat9-4-ae71ce67b5d4a91bce1b34acde830268 │ │ │ ├── partition_wise_fileformat9-5-d1a5913edaaec9654edb333e8207f57b │ │ │ ├── partition_wise_fileformat9-6-624b059dfaa86e2c78f065169de325cd │ │ │ ├── partitioned table scan-0-3e8898a13ccef627603f340d1f8bdd80 │ │ │ ├── plan_json-0-74146da55d57b22443140e7fbab3375c │ │ │ ├── ppd1-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd1-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd1-2-ae8aea06b05358ef9c486b61c9e30a69 │ │ │ ├── ppd1-3-1d3f71876ba45f942e93a68c0be15ef5 │ │ │ ├── ppd1-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd1-5-ae8aea06b05358ef9c486b61c9e30a69 │ │ │ ├── ppd1-6-1d3f71876ba45f942e93a68c0be15ef5 │ │ │ ├── ppd2-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd2-1-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd2-2-4d5021216c5bc600a8c5344945f55a4 │ │ │ ├── ppd2-3-fccdc7a24b626308d9ec17608f36564b │ │ │ ├── ppd2-4-4e457825319166f3bd2ad07d8f7c2f69 │ │ │ ├── ppd2-5-a2d5e5ec2504041ea1a62856c7086451 │ │ │ ├── ppd2-6-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd2-7-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd2-8-4d5021216c5bc600a8c5344945f55a4 │ │ │ ├── ppd2-9-fccdc7a24b626308d9ec17608f36564b │ │ │ ├── ppd_clusterby-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_clusterby-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_clusterby-10-62979aa9e6b4e6ffb44ec452aabbef65 │ │ │ ├── ppd_clusterby-2-16681f9c2bdd44278817d72c138b6ee1 │ │ │ ├── ppd_clusterby-3-707a2295731e0d631a6c5f71c745c8d5 │ │ │ ├── ppd_clusterby-4-a2d5e5ec2504041ea1a62856c7086451 │ │ │ ├── ppd_clusterby-5-62979aa9e6b4e6ffb44ec452aabbef65 │ │ │ ├── ppd_clusterby-6-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_clusterby-7-16681f9c2bdd44278817d72c138b6ee1 │ │ │ ├── ppd_clusterby-8-707a2295731e0d631a6c5f71c745c8d5 │ │ │ ├── ppd_clusterby-9-a2d5e5ec2504041ea1a62856c7086451 │ │ │ ├── ppd_constant_expr-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_constant_expr-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_constant_expr-2-2ab005b2ee21deedbe7d10904a034468 │ │ │ ├── ppd_constant_expr-3-5b20725caf905c6674759fee7873d627 │ │ │ ├── ppd_constant_expr-4-aded77ef8dced4717d919a949d109b0 │ │ │ ├── ppd_constant_expr-5-7da8c74586c99d96254f6f031bcaeb1c │ │ │ ├── ppd_constant_expr-6-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_constant_expr-7-5b20725caf905c6674759fee7873d627 │ │ │ ├── ppd_constant_expr-8-aded77ef8dced4717d919a949d109b0 │ │ │ ├── ppd_constant_expr-9-7da8c74586c99d96254f6f031bcaeb1c │ │ │ ├── ppd_constant_where-0-345fa30edd72d631fee21c3beeeef3d9 │ │ │ ├── ppd_constant_where-1-84c951641740895ca1c8ddc098805da5 │ │ │ ├── ppd_gby-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_gby-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_gby-2-fea67192aba8704a64a85da47f7f321e │ │ │ ├── ppd_gby-3-97b8d0091058060f5f17cf5e81cce73d │ │ │ ├── ppd_gby-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_gby-5-fea67192aba8704a64a85da47f7f321e │ │ │ ├── ppd_gby-6-97b8d0091058060f5f17cf5e81cce73d │ │ │ ├── ppd_gby2-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_gby2-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_gby2-2-25541db999d8c1d56ba36b63949b6073 │ │ │ ├── ppd_gby2-3-321628d4c52f6992f2680a3a162f19f │ │ │ ├── ppd_gby2-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_gby2-5-25541db999d8c1d56ba36b63949b6073 │ │ │ ├── ppd_gby2-6-321628d4c52f6992f2680a3a162f19f │ │ │ ├── ppd_gby_join-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_gby_join-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_gby_join-2-45e102aabf0e90ac455e2bab3988d8c0 │ │ │ ├── ppd_gby_join-3-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_gby_join-4-45e102aabf0e90ac455e2bab3988d8c0 │ │ │ ├── ppd_join-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_join-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_join-2-4c4dcd0c288653e39cfe077c19c68570 │ │ │ ├── ppd_join-3-aab5d092ca17ed23ee71d3a6ef653998 │ │ │ ├── ppd_join-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_join-5-4c4dcd0c288653e39cfe077c19c68570 │ │ │ ├── ppd_join-6-aab5d092ca17ed23ee71d3a6ef653998 │ │ │ ├── ppd_join2-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_join2-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_join2-2-307ac4f1b13e310dc1c61c05a113945d │ │ │ ├── ppd_join2-3-d03c0ad3ab713691cf9d3b27ae1223f9 │ │ │ ├── ppd_join2-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_join2-5-307ac4f1b13e310dc1c61c05a113945d │ │ │ ├── ppd_join2-6-d03c0ad3ab713691cf9d3b27ae1223f9 │ │ │ ├── ppd_join3-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_join3-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_join3-2-5018d137c74aed08cc4da4cbd1904092 │ │ │ ├── ppd_join3-3-42cd793c031af1f7961d7b5e237de76b │ │ │ ├── ppd_join3-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_join3-5-5018d137c74aed08cc4da4cbd1904092 │ │ │ ├── ppd_join3-6-42cd793c031af1f7961d7b5e237de76b │ │ │ ├── ppd_join_filter-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_join_filter-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_join_filter-10-2c1710aa3e08f618c1930305ebdccc17 │ │ │ ├── ppd_join_filter-11-41debade389a200de226d8ad0fe47d24 │ │ │ ├── ppd_join_filter-12-3bcc51a124f8cbd456620853d808354 │ │ │ ├── ppd_join_filter-13-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_join_filter-14-2c1710aa3e08f618c1930305ebdccc17 │ │ │ ├── ppd_join_filter-15-41debade389a200de226d8ad0fe47d24 │ │ │ ├── ppd_join_filter-2-2c1710aa3e08f618c1930305ebdccc17 │ │ │ ├── ppd_join_filter-3-41debade389a200de226d8ad0fe47d24 │ │ │ ├── ppd_join_filter-4-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_join_filter-5-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_join_filter-6-2c1710aa3e08f618c1930305ebdccc17 │ │ │ ├── ppd_join_filter-7-41debade389a200de226d8ad0fe47d24 │ │ │ ├── ppd_join_filter-8-73819ea1a7c0653a61652b3766afb003 │ │ │ ├── ppd_join_filter-9-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_outer_join1-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_outer_join1-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_outer_join1-2-a239ac7d9503d93e0859043019f3e02e │ │ │ ├── ppd_outer_join1-3-9dfd333c14f82fd71c213e1d39c83524 │ │ │ ├── ppd_outer_join1-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_outer_join1-5-a239ac7d9503d93e0859043019f3e02e │ │ │ ├── ppd_outer_join1-6-9dfd333c14f82fd71c213e1d39c83524 │ │ │ ├── ppd_outer_join2-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_outer_join2-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_outer_join2-2-b5443e75f4473eb3cbe55bf0d58cc999 │ │ │ ├── ppd_outer_join2-3-5340cd2d88dcf41dc18119389a475e36 │ │ │ ├── ppd_outer_join2-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_outer_join2-5-b5443e75f4473eb3cbe55bf0d58cc999 │ │ │ ├── ppd_outer_join2-6-5340cd2d88dcf41dc18119389a475e36 │ │ │ ├── ppd_outer_join3-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_outer_join3-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_outer_join3-2-8f14853ac6ce5f40c98982ace9fa6221 │ │ │ ├── ppd_outer_join3-3-1e3af37cc2d9c2059488b5940a33a1d0 │ │ │ ├── ppd_outer_join3-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_outer_join3-5-8f14853ac6ce5f40c98982ace9fa6221 │ │ │ ├── ppd_outer_join3-6-1e3af37cc2d9c2059488b5940a33a1d0 │ │ │ ├── ppd_outer_join4-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_outer_join4-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_outer_join4-2-7b0e117314e5784ba06b7ab69e689c84 │ │ │ ├── ppd_outer_join4-3-ac57dc2a7151f20029d6a97049d6eebe │ │ │ ├── ppd_outer_join4-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_outer_join4-5-7b0e117314e5784ba06b7ab69e689c84 │ │ │ ├── ppd_outer_join4-6-ac57dc2a7151f20029d6a97049d6eebe │ │ │ ├── ppd_outer_join5-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_outer_join5-1-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_outer_join5-10-b12aa87aaf64b573ce0be7013117651b │ │ │ ├── ppd_outer_join5-11-c8e68d5a524b965c244f01782bc42e97 │ │ │ ├── ppd_outer_join5-12-fd1ebd8150ed40b4b91774f6db42df2 │ │ │ ├── ppd_outer_join5-2-5b859f606230a70698edf52ca814beee │ │ │ ├── ppd_outer_join5-3-2823683e3169487b80e882aa9c4e3bd6 │ │ │ ├── ppd_outer_join5-4-ab457e9f757065dbf6bf66a997ab76a0 │ │ │ ├── ppd_outer_join5-5-ad3dc0900226e1ae9674bec0e054a4d4 │ │ │ ├── ppd_outer_join5-6-c669e5c7ae22c4fb96995c700ebadd9a │ │ │ ├── ppd_outer_join5-7-54d9885a797deb82236499f6bb99ddfd │ │ │ ├── ppd_outer_join5-8-e6949a27ee3c56243c81660de7d97f9c │ │ │ ├── ppd_outer_join5-9-ca16024e6f5399b1d035f5b9fd665163 │ │ │ ├── ppd_random-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_random-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_random-2-a589a2f51ebb3962202698c79db4a33b │ │ │ ├── ppd_random-3-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_random-4-a589a2f51ebb3962202698c79db4a33b │ │ │ ├── ppd_repeated_alias-0-89696914fad2d7b7bfc5b7729a7e7c34 │ │ │ ├── ppd_repeated_alias-1-a299c8b1a9f8c2772989a5454574f4e5 │ │ │ ├── ppd_repeated_alias-2-588c0c8007b156167714d1cb06d10384 │ │ │ ├── ppd_repeated_alias-3-106d8664d84c73f86268cf69e9ba6834 │ │ │ ├── ppd_repeated_alias-4-2cd71603d825cddd0d181bd240c0051f │ │ │ ├── ppd_repeated_alias-5-941a7af885ec77d91a78e03a6a568220 │ │ │ ├── ppd_repeated_alias-6-c3746d419ceaab36dee78f4b4b38eb99 │ │ │ ├── ppd_repeated_alias-7-54b70fb31202186b8984ae2feea299bf │ │ │ ├── ppd_repeated_alias-8-89696914fad2d7b7bfc5b7729a7e7c34 │ │ │ ├── ppd_repeated_alias-9-a299c8b1a9f8c2772989a5454574f4e5 │ │ │ ├── ppd_udf_case-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_udf_case-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_udf_case-2-c44d82e56d50653148bb4f9f98a42137 │ │ │ ├── ppd_udf_col-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_udf_col-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_udf_col-10-53bbac80bbacf419ea971ddbb0f48542 │ │ │ ├── ppd_udf_col-2-1c26c857485a928462c79e1b38ed1d9e │ │ │ ├── ppd_udf_col-3-86fd1e8c9491c6ea0d67e111aa6cf9ed │ │ │ ├── ppd_udf_col-4-c601016163c99a115feaca5fe5b74aae │ │ │ ├── ppd_udf_col-5-53bbac80bbacf419ea971ddbb0f48542 │ │ │ ├── ppd_udf_col-6-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_udf_col-7-1c26c857485a928462c79e1b38ed1d9e │ │ │ ├── ppd_udf_col-8-86fd1e8c9491c6ea0d67e111aa6cf9ed │ │ │ ├── ppd_udf_col-9-c601016163c99a115feaca5fe5b74aae │ │ │ ├── ppd_union-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppd_union-1-f18babdee8d2d4206ce4f2a93b6575f9 │ │ │ ├── ppd_union-2-fbfb76b9e6f2af48dcd227af03dffa89 │ │ │ ├── ppd_union-3-678c8197f458b459171c266f7431683e │ │ │ ├── ppd_union-4-145c2779dadb5bd921dc2baac608b803 │ │ │ ├── ppd_union-5-fbfb76b9e6f2af48dcd227af03dffa89 │ │ │ ├── ppd_union-6-678c8197f458b459171c266f7431683e │ │ │ ├── ppr_allchildsarenull-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── ppr_allchildsarenull-1-965b997838e7cc654cac68baef1be41d │ │ │ ├── ppr_allchildsarenull-2-22b7886d627e6266f5f1415ba239c621 │ │ │ ├── ppr_allchildsarenull-3-73819ea1a7c0653a61652b3766afb003 │ │ │ ├── ppr_allchildsarenull-4-965b997838e7cc654cac68baef1be41d │ │ │ ├── ppr_allchildsarenull-5-22b7886d627e6266f5f1415ba239c621 │ │ │ ├── ppr_pushdown-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── ppr_pushdown-1-855b235f9c760ba9d6d0200bfd1ad08b │ │ │ ├── ppr_pushdown-10-2957fd9b211cee5f0372525a1de55c19 │ │ │ ├── ppr_pushdown-11-b8d6f0ffc8294497c792b26958adee45 │ │ │ ├── ppr_pushdown-12-ab1b9a0cdd9586c96d8856a9d632b89c │ │ │ ├── ppr_pushdown-13-2c316c67fd494d878fbbea107d283c3b │ │ │ ├── ppr_pushdown-14-53b4be82a1538844d03b200429efa02b │ │ │ ├── ppr_pushdown-15-71ab93d38ed2908069091c7c8cc0aba1 │ │ │ ├── ppr_pushdown-16-855cb54d28034fdb20a3615ee0918d63 │ │ │ ├── ppr_pushdown-17-d3ccf2722a8b7281fcee61b2544772c8 │ │ │ ├── ppr_pushdown-18-fcd10fbfc55a2c0aa843fe618f9613c6 │ │ │ ├── ppr_pushdown-19-ff36e3978571ac05f11e8322c024e4b6 │ │ │ ├── ppr_pushdown-2-f689aaf15b08c433d1e93ce977a9b6d5 │ │ │ ├── ppr_pushdown-20-481005cf034ef3d7b998da32eb82aa9a │ │ │ ├── ppr_pushdown-21-9073825e8b9804331f780980d1f9fa92 │ │ │ ├── ppr_pushdown-22-9cb28f0d3a434c9d1ab039192906ec9d │ │ │ ├── ppr_pushdown-23-678f50025924fee7b59f66e2abdb472d │ │ │ ├── ppr_pushdown-24-4d5bfa800ba434f464b07bf9b5d39f20 │ │ │ ├── ppr_pushdown-25-22663f09ea1c1bc303756067e84df5a7 │ │ │ ├── ppr_pushdown-26-e789d9b469aa1fffe4ce0a15a8c1fb9b │ │ │ ├── ppr_pushdown-27-8065c18e387fd8bffae19a80af8dc1d4 │ │ │ ├── ppr_pushdown-28-b72de558c88ae91460989938000e0d27 │ │ │ ├── ppr_pushdown-29-7217735d357770af4ffee730e4e9add4 │ │ │ ├── ppr_pushdown-3-5eede4874e678021938683fc2f5dc900 │ │ │ ├── ppr_pushdown-30-630e2f7918b7727fc4ca057fa21e2eea │ │ │ ├── ppr_pushdown-31-2e062414293b643ea4d7f6df92f939e4 │ │ │ ├── ppr_pushdown-32-5eba4bf10315099129eae319d73636cf │ │ │ ├── ppr_pushdown-33-35af0585a4f98bc222c786688cb6de6b │ │ │ ├── ppr_pushdown-34-a5594625510703427ab8bae5d0563f73 │ │ │ ├── ppr_pushdown-4-c5c542f8ee81cd0afd44e67fc7b4d306 │ │ │ ├── ppr_pushdown-5-f54bebec398f0fdfdbc0393123dba234 │ │ │ ├── ppr_pushdown-6-78af12432bcbf99d4a0d41c25f964de │ │ │ ├── ppr_pushdown-7-58724fbe96a0b3deceef20c8cc5e318d │ │ │ ├── ppr_pushdown-8-14570f946e75924d7926c809485951d1 │ │ │ ├── ppr_pushdown-9-3ba325662296fc455f07f1c835495e4c │ │ │ ├── ppr_pushdown2-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── ppr_pushdown2-1-855b235f9c760ba9d6d0200bfd1ad08b │ │ │ ├── ppr_pushdown2-10-4fa4ba4c739b6f44975d41e4705d4389 │ │ │ ├── ppr_pushdown2-11-ab3e46183487096745d7d90e3020e94c │ │ │ ├── ppr_pushdown2-12-b10b9e14f5a7a7a92c0c68df6dbc656a │ │ │ ├── ppr_pushdown2-13-154f9859bd0822e287fbfdff12fd45ff │ │ │ ├── ppr_pushdown2-14-cf4a30b5c8329d8d79ddf762f318fbb3 │ │ │ ├── ppr_pushdown2-15-8d01597374157f2d3d066840983ba1f8 │ │ │ ├── ppr_pushdown2-16-5614065e1b8e709f68be4fa67666f41 │ │ │ ├── ppr_pushdown2-17-3a67618e47c977f58c9dd8f4b9a576eb │ │ │ ├── ppr_pushdown2-18-44e5f3ac566f60d8b17ef19c18a11ebe │ │ │ ├── ppr_pushdown2-19-e2c7e9b01ec95dfcc685827e24d66775 │ │ │ ├── ppr_pushdown2-2-ffa167b63d612a4986d02f5c0623ea7b │ │ │ ├── ppr_pushdown2-20-bd7e1917f8d2cf50c062a22ef3fa15b5 │ │ │ ├── ppr_pushdown2-21-ece6fe0efc1e658b36ddc10f0653d229 │ │ │ ├── ppr_pushdown2-3-c7753746c190414723d66a8f876499c7 │ │ │ ├── ppr_pushdown2-4-1886675984606b6c972c4a26dca6fd2c │ │ │ ├── ppr_pushdown2-5-33b137b28e7246ec3c2acb937c638910 │ │ │ ├── ppr_pushdown2-6-b5a2518af801f95fe52a75dfc1d3e867 │ │ │ ├── ppr_pushdown2-7-e89a8d1f66fdf9ce68f345de1f728c5b │ │ │ ├── ppr_pushdown2-8-4507a3f200b3ce384191c91acd324dc7 │ │ │ ├── ppr_pushdown2-9-c86940e70f705f50e9091c257ee2bb40 │ │ │ ├── ppr_pushdown3-0-df2401785dfa257de49c3ad80b0f480a │ │ │ ├── ppr_pushdown3-1-cf6ff7dfb16e7d2567e8f83fcc5d08e1 │ │ │ ├── ppr_pushdown3-2-e879051803d0b64139e703e40fb007d0 │ │ │ ├── ppr_pushdown3-3-c6fac1670fbd1ee490867efb1913a12d │ │ │ ├── ppr_pushdown3-4-a1c18483e5f5d2fe351be09af658acbb │ │ │ ├── ppr_pushdown3-5-9b129023196c29071a92e91471872593 │ │ │ ├── ppr_pushdown3-6-67118904e6cc8e9f5210fab88e87fb8f │ │ │ ├── progress_1-0-fe903cc5a573e7aced5ee17b35d2fb04 │ │ │ ├── progress_1-1-e93fbb4cb074376a645dc22075c0eab6 │ │ │ ├── progress_1-2-b6c8c8fc9df98af4dead5efabf5f162c │ │ │ ├── progress_1-3-43d286eebddaee26cf95f26e62a75fe4 │ │ │ ├── protectmode-0-44765a9e389cd7be27e038d257ad2c61 │ │ │ ├── protectmode-1-377270bf028b6a5e8a5a1679421aece6 │ │ │ ├── protectmode-10-b993dfdb8636411e4e9182a5a1931362 │ │ │ ├── protectmode-11-b5aa37f2dd84c363d257ededdcc9a6b6 │ │ │ ├── protectmode-12-d35a2c6ec13dcba7f4856522d2c781a │ │ │ ├── protectmode-13-70e6f4e73e37e6288fafdf6b8da5c62c │ │ │ ├── protectmode-14-f817d21ee3a7646bf107c87bb264586b │ │ │ ├── protectmode-15-c51a200a345ceca9838507176a4a6dd6 │ │ │ ├── protectmode-16-151259dfc1cea42392a7511991c58a5b │ │ │ ├── protectmode-17-6fa385b2d2c6fee674dfff38f7338080 │ │ │ ├── protectmode-18-968e78b685c3b83bf5eb8a3a786657a7 │ │ │ ├── protectmode-19-b6e156f104768706aa587b762a9d4d18 │ │ │ ├── protectmode-2-f450722c47e95d5825d0cb920c212aea │ │ │ ├── protectmode-20-719ec12056901bb0330fec1f05d4a94b │ │ │ ├── protectmode-21-a31442a7d6c6950c137856ab861d622d │ │ │ ├── protectmode-22-8e2cda1a6895512d0c2e72e6b8b283d1 │ │ │ ├── protectmode-23-a31442a7d6c6950c137856ab861d622d │ │ │ ├── protectmode-24-2281fb42e04f3f3b1ae71e76feeb7733 │ │ │ ├── protectmode-25-9095794bb72e75a50f84c7cc79b14df6 │ │ │ ├── protectmode-26-a31442a7d6c6950c137856ab861d622d │ │ │ ├── protectmode-27-af002c5db76382ae7619968eaff3cc91 │ │ │ ├── protectmode-28-a31442a7d6c6950c137856ab861d622d │ │ │ ├── protectmode-29-6fa385b2d2c6fee674dfff38f7338080 │ │ │ ├── protectmode-3-4038060ccc6df535736b4b3cdf722cc │ │ │ ├── protectmode-30-2cf1d601e4e37fa223cc841c0bf443f1 │ │ │ ├── protectmode-31-97f50f7a49ee261db1888e93cf696c27 │ │ │ ├── protectmode-32-b6e156f104768706aa587b762a9d4d18 │ │ │ ├── protectmode-33-151259dfc1cea42392a7511991c58a5b │ │ │ ├── protectmode-34-520cc99451f889b26e12308b956f41e2 │ │ │ ├── protectmode-35-67854bfbea7afeca2987ced73b68e671 │ │ │ ├── protectmode-36-5b68bd2ad93372f1926166bb1eea7ae1 │ │ │ ├── protectmode-37-8c07fbbf528fd9180db5a52474f6683e │ │ │ ├── protectmode-38-da4a5ad43dbf3df8e31d23979af46423 │ │ │ ├── protectmode-39-771f55b9c0dbadc2b8799cb4756c63e9 │ │ │ ├── protectmode-4-b993dfdb8636411e4e9182a5a1931362 │ │ │ ├── protectmode-40-39024332d020339bd9396c9b15403a0c │ │ │ ├── protectmode-41-7643ff9b92368f2cc44ab8b1f5738d24 │ │ │ ├── protectmode-42-3a8863ad6fac90ba48555c1042c92ebb │ │ │ ├── protectmode-43-377270bf028b6a5e8a5a1679421aece6 │ │ │ ├── protectmode-5-2af90060e2a14790441e0716e3372e7c │ │ │ ├── protectmode-6-e2d1fc9c94e0d3597f393aec99850510 │ │ │ ├── protectmode-7-143fafe70e2ec2d10c6eeef114e7fad1 │ │ │ ├── protectmode-8-e2d1fc9c94e0d3597f393aec99850510 │ │ │ ├── protectmode-9-4038060ccc6df535736b4b3cdf722cc │ │ │ ├── push_or-0-82eac35d076df1ee8020d57832f0f895 │ │ │ ├── push_or-1-4c03e0f7fa028897c0caee62167eb68e │ │ │ ├── push_or-2-62abd65e444981a96f7cf3dab3e013f1 │ │ │ ├── push_or-3-34a713b9523589f1eb3205037d56a5b4 │ │ │ ├── push_or-4-22888cdef1b94bde983541c1f3d510d9 │ │ │ ├── push_or-5-c94def4b18b9c8c00e7a93eb19ec694a │ │ │ ├── query_with_semi-0-3731ce715b60549c17b7993927d48436 │ │ │ ├── query_with_semi-1-3f53ec3b276b32cf81729433e47010cb │ │ │ ├── query_with_semi-2-bf8cb175f9b13fcc23ba46be674b5767 │ │ │ ├── quote1-0-54ea0f3c04b185472a38a744d8003c13 │ │ │ ├── quote1-1-965ec21dbb2cdbfb0e8a8cb20ea96416 │ │ │ ├── quote1-2-14d4949bc9215a1004c945885ef10de4 │ │ │ ├── quote1-3-f36bdb38d0c1b79c6113fa0795d14533 │ │ │ ├── quote1-4-582bb2fb4c4ee50eb97bafae452a69a6 │ │ │ ├── quote2-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── quote2-1-ea1a1d0c5f9a3248afbb65e6632c5118 │ │ │ ├── quote2-2-34f3c423b2fb1f0b11457f45a60042b9 │ │ │ ├── quoted alias.attr-0-97b3c408090f758257e4bd20597a525e │ │ │ ├── rcfile_columnar-0-4f3c6c5b4a75c97b8cc0432a56dcafd1 │ │ │ ├── rcfile_columnar-1-5d636fc4682aee89328b7c7be17e1013 │ │ │ ├── rcfile_columnar-2-b2f56374f2ea8a967b38e77b57138d4b │ │ │ ├── rcfile_columnar-3-4653c703effa4cc65743128fa3c65ff │ │ │ ├── rcfile_lazydecompress-0-82f12a09df66752b05e89d3d12ba1e32 │ │ │ ├── rcfile_lazydecompress-1-de09b3ac5ba6a77653eb361496863085 │ │ │ ├── rcfile_lazydecompress-10-fb011a8ee13a82a873039bd28353205b │ │ │ ├── rcfile_lazydecompress-11-25715870c569b0f8c3d483e3a38b3199 │ │ │ ├── rcfile_lazydecompress-12-3a4c24fd561f459025264baa3fb6d87 │ │ │ ├── rcfile_lazydecompress-2-bc4929594297fa2ee82b8ceff9118e46 │ │ │ ├── rcfile_lazydecompress-3-18a2fa22b8cef720cb30d75353b3f276 │ │ │ ├── rcfile_lazydecompress-4-fb011a8ee13a82a873039bd28353205b │ │ │ ├── rcfile_lazydecompress-5-dd959af1968381d0ed90178d349b01a7 │ │ │ ├── rcfile_lazydecompress-6-ea607fbed28d20e5726f4501285d698d │ │ │ ├── rcfile_lazydecompress-7-de09b3ac5ba6a77653eb361496863085 │ │ │ ├── rcfile_lazydecompress-8-bc4929594297fa2ee82b8ceff9118e46 │ │ │ ├── rcfile_lazydecompress-9-18a2fa22b8cef720cb30d75353b3f276 │ │ │ ├── rcfile_null_value-0-69edd47d7cca001865102e3fad925613 │ │ │ ├── rcfile_null_value-1-38ac0f806892e3b25b0038c5f227c8d │ │ │ ├── rcfile_null_value-2-e721b8138774fdefca7171d1051841ee │ │ │ ├── rcfile_null_value-3-3c82d1a57cf295901c6b931278a3760a │ │ │ ├── rcfile_null_value-4-8e839adf91e01e3230e15e9a936c9126 │ │ │ ├── rcfile_null_value-5-d57d9c8882edbb3c6116d89516e4aed │ │ │ ├── rcfile_null_value-6-a7a74aeb8c5cac1f2fd2362398a52d2 │ │ │ ├── rcfile_toleratecorruptions-0-644898731e5228e863236f388ba1aa07 │ │ │ ├── rcfile_toleratecorruptions-1-a9f718201b71fa855fb81a29e1d7bd3b │ │ │ ├── rcfile_toleratecorruptions-2-4a9a9175758ef576804c8b7309b019e8 │ │ │ ├── rcfile_toleratecorruptions-3-ea607fbed28d20e5726f4501285d698d │ │ │ ├── rcfile_toleratecorruptions-4-4df4ea1d1d30dedff582dc5c249dce85 │ │ │ ├── rcfile_toleratecorruptions-5-6a3af12e36cec853c876a2cbae61c23a │ │ │ ├── rcfile_toleratecorruptions-6-718032defb864225dd664b1719f3b590 │ │ │ ├── rcfile_union-0-2a3aaaffda2fb4486871bed84c68fc60 │ │ │ ├── rcfile_union-1-ea555c16ad460f9a8d17b4e448d7c91b │ │ │ ├── rcfile_union-2-e104293998e4d4ea9d69d6b48f9aa6e5 │ │ │ ├── reduce_deduplicate-0-43d53504df013e6b35f81811138a167a │ │ │ ├── reduce_deduplicate-1-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── reduce_deduplicate-10-44d72569675c48e482ff53f45c7526e3 │ │ │ ├── reduce_deduplicate-11-a9591dfbb3d8c6baa66fd9d56389bc81 │ │ │ ├── reduce_deduplicate-12-d6f20dc500809305e7454db01e24ce26 │ │ │ ├── reduce_deduplicate-13-1583df07fff7a2af0a9cc6a681446036 │ │ │ ├── reduce_deduplicate-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── reduce_deduplicate-3-45ca2bb223236cce4dcc7d7d7c96edbe │ │ │ ├── reduce_deduplicate-4-ac9d2110b999fb41f5f0f183742a8b27 │ │ │ ├── reduce_deduplicate-5-e9d5f1694b887c50ef17ba48545faa4d │ │ │ ├── reduce_deduplicate-6-890c5edd947ca276254ef4bd2813b296 │ │ │ ├── reduce_deduplicate-7-e6ae500ce884875bd5f8e4e5200764e7 │ │ │ ├── reduce_deduplicate-8-e15d6f0f5d84bdeb153965cf0cc4fe11 │ │ │ ├── reduce_deduplicate-9-3b77920b01edb72aa3a7fc4f813e5d72 │ │ │ ├── reduce_deduplicate_exclude_gby-0-163aa8a17867cfbd9297cc8825c4f3d5 │ │ │ ├── reduce_deduplicate_exclude_gby-1-a3f3e279ab0be5093f4a926e265c0211 │ │ │ ├── reduce_deduplicate_exclude_gby-2-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── reduce_deduplicate_exclude_gby-3-862d1558d2999ca7ee585f8bdc3dacb2 │ │ │ ├── reduce_deduplicate_exclude_gby-4-ca16024e6f5399b1d035f5b9fd665163 │ │ │ ├── reduce_deduplicate_exclude_join-0-aa047b3a8b40b68b93c4ad11e173c767 │ │ │ ├── reduce_deduplicate_exclude_join-1-24ca942f094b14b92086305cc125e833 │ │ │ ├── reduce_deduplicate_exclude_join-2-f420affa96a8f13a91f6082805cf72a0 │ │ │ ├── reduce_deduplicate_extended-0-aa047b3a8b40b68b93c4ad11e173c767 │ │ │ ├── reduce_deduplicate_extended-1-d0a93f40892e3894460553b443c77428 │ │ │ ├── reduce_deduplicate_extended-10-5a0cbc5744352a117afb34d1754496fa │ │ │ ├── reduce_deduplicate_extended-11-9a4a8559680a45aad0a54144fb200f5e │ │ │ ├── reduce_deduplicate_extended-12-4c2ae1bc1c838240e1f355714ed8e785 │ │ │ ├── reduce_deduplicate_extended-13-ca02f80b104ee3dff445518501d0ee3e │ │ │ ├── reduce_deduplicate_extended-14-fd197d657a19ef5cdcb9cc7b5824035c │ │ │ ├── reduce_deduplicate_extended-15-dbc2b906b6cb99a138175eb4764da6bd │ │ │ ├── reduce_deduplicate_extended-16-22d9cdca0e70becd2ef86db59fc01ebb │ │ │ ├── reduce_deduplicate_extended-17-ffeb52326db68aafe4bb801ef6e7db5f │ │ │ ├── reduce_deduplicate_extended-18-4435a485aa7e3a72b789418e063d4cb8 │ │ │ ├── reduce_deduplicate_extended-19-67e864faaff4c6b2a8e1c9fbd188bb66 │ │ │ ├── reduce_deduplicate_extended-2-dbcec232623048c7748b708123e18bf0 │ │ │ ├── reduce_deduplicate_extended-20-29dc99f23850e9f19368926d621a3029 │ │ │ ├── reduce_deduplicate_extended-21-722d6027daf02b2e40f121a4fec362d2 │ │ │ ├── reduce_deduplicate_extended-22-f3a586e75df55df355982eac0d4d4a63 │ │ │ ├── reduce_deduplicate_extended-23-241faeae86e3e43e3ed8e35fb24e027d │ │ │ ├── reduce_deduplicate_extended-24-dd3ed01a7ac656855ce76b4e6fcd27ed │ │ │ ├── reduce_deduplicate_extended-25-bce36b45ce0c67af052bcf0487a53052 │ │ │ ├── reduce_deduplicate_extended-26-93434017959c1be56608adff9309f02a │ │ │ ├── reduce_deduplicate_extended-27-5a0cbc5744352a117afb34d1754496fa │ │ │ ├── reduce_deduplicate_extended-28-9a4a8559680a45aad0a54144fb200f5e │ │ │ ├── reduce_deduplicate_extended-29-4c2ae1bc1c838240e1f355714ed8e785 │ │ │ ├── reduce_deduplicate_extended-3-290a9fab18a45f29dd84ac3da0a47fb2 │ │ │ ├── reduce_deduplicate_extended-30-ca02f80b104ee3dff445518501d0ee3e │ │ │ ├── reduce_deduplicate_extended-31-fd197d657a19ef5cdcb9cc7b5824035c │ │ │ ├── reduce_deduplicate_extended-32-dbc2b906b6cb99a138175eb4764da6bd │ │ │ ├── reduce_deduplicate_extended-33-22d9cdca0e70becd2ef86db59fc01ebb │ │ │ ├── reduce_deduplicate_extended-34-ffeb52326db68aafe4bb801ef6e7db5f │ │ │ ├── reduce_deduplicate_extended-35-4435a485aa7e3a72b789418e063d4cb8 │ │ │ ├── reduce_deduplicate_extended-4-722d6027daf02b2e40f121a4fec362d2 │ │ │ ├── reduce_deduplicate_extended-5-f3a586e75df55df355982eac0d4d4a63 │ │ │ ├── reduce_deduplicate_extended-6-8801137a557caa5a75cfacd7aaf56bad │ │ │ ├── reduce_deduplicate_extended-7-7e350e31bce459f89b322b3356806174 │ │ │ ├── reduce_deduplicate_extended-8-bce36b45ce0c67af052bcf0487a53052 │ │ │ ├── reduce_deduplicate_extended-9-a94cab7395270afa10d73b5e8c2f4a71 │ │ │ ├── reducesink_dedup-0-d3f50875bd5dff172cf813fdb7d738eb │ │ │ ├── reducesink_dedup-1-dda16565b98926fc3587de937b9401c7 │ │ │ ├── reducesink_dedup-2-971f12c90619b02484c8e7db1b32f050 │ │ │ ├── router_join_ppr-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── router_join_ppr-1-f5d1802919e5f9c2afa606f509d8ff58 │ │ │ ├── router_join_ppr-2-49b8b038ed8f5513405071c532967c47 │ │ │ ├── router_join_ppr-3-a0b1014e173f410923de0d0446dfb4cc │ │ │ ├── router_join_ppr-4-baaf33e5c11c65e1aa2b6be37de6eef6 │ │ │ ├── router_join_ppr-5-89b4fc284984f51c12f15017707ad312 │ │ │ ├── router_join_ppr-6-2edf8e4ca99543089fdacbf506caa94f │ │ │ ├── router_join_ppr-7-defc6eae5ce9ac8bc9f57308e1513f93 │ │ │ ├── router_join_ppr-8-b07ad21f47a74162f438abf579675f8e │ │ │ ├── schema-less transform-0-d5738de14dd6e29da712ec3318f4118f │ │ │ ├── schema-less transform-1-49624ef4e2c3cc2040c06660b926219b │ │ │ ├── select from thrift based table-0-304c4992f5517febd10f43c57df4da49 │ │ │ ├── select null from table-0-5bb53cca754cc8afe9cd22feb8c586d1 │ │ │ ├── select_as_omitted-0-39bd00e50d63ee4ff10427838591730a │ │ │ ├── select_as_omitted-1-99d8c7e0fa02f47d19df6a0d7dabe145 │ │ │ ├── select_unquote_and-0-7299c6986c06fc4a50cb543701527785 │ │ │ ├── select_unquote_and-1-24a5b4c39dbdbfad75c08f201f2b7a70 │ │ │ ├── select_unquote_and-2-8b4aac4293f2092c0661c26cb54b5619 │ │ │ ├── select_unquote_and-3-683007138a712792041ef3c8b84e914e │ │ │ ├── select_unquote_and-4-8417a7b93132e20d468b7948bf46915a │ │ │ ├── select_unquote_and-5-1a5a68a098bfb9c93b76a458a9faf232 │ │ │ ├── select_unquote_and-6-f34f161ad7eda65e2640c1d3ae47cb09 │ │ │ ├── select_unquote_not-0-7299c6986c06fc4a50cb543701527785 │ │ │ ├── select_unquote_not-1-24a5b4c39dbdbfad75c08f201f2b7a70 │ │ │ ├── select_unquote_not-2-8b4aac4293f2092c0661c26cb54b5619 │ │ │ ├── select_unquote_not-3-683007138a712792041ef3c8b84e914e │ │ │ ├── select_unquote_not-4-a6cbbf81715845f61af8fce977c0bcd5 │ │ │ ├── select_unquote_not-5-ceada0d3fa65bb2ec65154e797332cde │ │ │ ├── select_unquote_not-6-f34f161ad7eda65e2640c1d3ae47cb09 │ │ │ ├── select_unquote_or-0-7299c6986c06fc4a50cb543701527785 │ │ │ ├── select_unquote_or-1-24a5b4c39dbdbfad75c08f201f2b7a70 │ │ │ ├── select_unquote_or-2-8b4aac4293f2092c0661c26cb54b5619 │ │ │ ├── select_unquote_or-3-683007138a712792041ef3c8b84e914e │ │ │ ├── select_unquote_or-4-954f604d17e36bbc08c04a0571d33045 │ │ │ ├── select_unquote_or-5-55cd874f705673f9de6ec8e3643c760f │ │ │ ├── select_unquote_or-6-f34f161ad7eda65e2640c1d3ae47cb09 │ │ │ ├── semicolon-0-f104632770dc96b81f00ccdac51fe5a8 │ │ │ ├── semijoin-0-1631b71327abf75b96116036b977b26c │ │ │ ├── semijoin-1-e7c99e1f46d502edbb0925d75aab5f0c │ │ │ ├── semijoin-10-ffd4fb3a903a6725ccb97d5451a3fec6 │ │ │ ├── semijoin-11-246a40dcafe077f02397e30d227c330 │ │ │ ├── semijoin-12-6d93a9d332ba490835b17f261a5467df │ │ │ ├── semijoin-13-18282d38b6efc0017089ab89b661764f │ │ │ ├── semijoin-14-19cfcefb10e1972bec0ffd421cd79de7 │ │ │ ├── semijoin-15-1de6eb3f357bd1c4d02ab4d19d43589 │ │ │ ├── semijoin-16-d3a72a90515ac4a8d8e9ac923bcda3d │ │ │ ├── semijoin-17-f0f8720cfd11fd71af17b310dc2d1019 │ │ │ ├── semijoin-18-f7b2ce472443982e32d954cbb5c96765 │ │ │ ├── semijoin-19-b1f1c7f701abe81c01e72fb98f0bd13f │ │ │ ├── semijoin-2-deb9c3286ae8e851b1fdb270085b16bc │ │ │ ├── semijoin-20-b7a8ebaeb42b2eaba7d97cadc3fd96c1 │ │ │ ├── semijoin-21-480418a0646cf7260b494b9eb4821bb6 │ │ │ ├── semijoin-22-b6aebd98f7636cda7b24e0bf84d7ba41 │ │ │ ├── semijoin-23-ed730ccdf552c07e7a82ba6b7fd3fbda │ │ │ ├── semijoin-24-d16b37134de78980b2bf96029e8265c3 │ │ │ ├── semijoin-25-be2bd011cc80b480b271a08dbf381e9b │ │ │ ├── semijoin-26-f1d3bab29f1ebafa148dbe3816e1da25 │ │ │ ├── semijoin-27-391c256254d171973f02e7f33672ce1d │ │ │ ├── semijoin-28-b56400f6d9372f353cf7292a2182e963 │ │ │ ├── semijoin-29-9efeef3d3c38e22a74d379978178c4f5 │ │ │ ├── semijoin-3-b4d4317dd3a10e18502f20f5c5250389 │ │ │ ├── semijoin-30-dd901d00fce5898b03a57cbc3028a70a │ │ │ ├── semijoin-31-e5dc4d8185e63e984aa4e3a2e08bd67 │ │ │ ├── semijoin-32-23017c7663f2710265a7e2a4a1606d39 │ │ │ ├── semijoin-33-ed499f94c6e6ac847ef5187b3b43bbc5 │ │ │ ├── semijoin-34-5e1b832090ab73c141c1167d5b25a490 │ │ │ ├── semijoin-35-8d5731f26232f6e26dd8012461b08d99 │ │ │ ├── semijoin-36-b1159823dca8025926407f8aa921238d │ │ │ ├── semijoin-37-a15b9074f999ce836be5329591b968d0 │ │ │ ├── semijoin-38-f37547c73a48ce3ba089531b176e6ba │ │ │ ├── semijoin-39-c22a6f11368affcb80a9c80e653a47a8 │ │ │ ├── semijoin-4-dfdad5a2742f93e8ea888191460809c0 │ │ │ ├── semijoin-40-32071a51e2ba6e86b1c5e40de55aae63 │ │ │ ├── semijoin-41-cf74f73a33b1af8902b7970a9350b092 │ │ │ ├── semijoin-42-6b4257a74fca627785c967c99547f4c0 │ │ │ ├── semijoin-43-e8a166ac2e94bf8d1da0fe91b0db2c81 │ │ │ ├── semijoin-44-945aaa3a24359ef73acab1e99500d5ea │ │ │ ├── semijoin-45-3fd94ffd4f1eb6cf83dcc064599bf12b │ │ │ ├── semijoin-46-620e01f81f6e5254b4bbe8fab4043ec0 │ │ │ ├── semijoin-47-f0140e4ee92508ba241f91c157b7af9c │ │ │ ├── semijoin-48-8a04442e84f99a584c2882d0af8c25d8 │ │ │ ├── semijoin-49-df1d6705d3624be72036318a6b42f04c │ │ │ ├── semijoin-5-d3c2f84a12374b307c58a69aba4ec70d │ │ │ ├── semijoin-6-90bb51b1330230d10a14fb7517457aa0 │ │ │ ├── semijoin-7-333d72e8bce6d11a35fc7a30418f225b │ │ │ ├── semijoin-8-d46607be851a6f4e27e98cbbefdee994 │ │ │ ├── semijoin-9-f7adaf0f77ce6ff8c3a4807f428d8de2 │ │ │ ├── serde_regex-0-60462d14b99bb445b02800e9fb22760e │ │ │ ├── serde_regex-1-dea03bd88cbaabcf438b398e23c139f6 │ │ │ ├── serde_regex-10-c5b3ec90419a40660e5f83736241c429 │ │ │ ├── serde_regex-11-b00710a6f7a3e5b92c2e17da54cd9ad1 │ │ │ ├── serde_regex-2-e84d30fcc6cf11e82b54ea63e7d1d611 │ │ │ ├── serde_regex-3-3ee9e78ff563d6b48741a41885f92c81 │ │ │ ├── serde_regex-4-c3e345183543f40a14d2dd742ebd5346 │ │ │ ├── serde_regex-5-e2d14a76a87a6014c6d2d3501a0c9129 │ │ │ ├── serde_regex-6-f818821654f219d1f4e2482951fae4f1 │ │ │ ├── serde_regex-7-bf456bcf6be7334488424dfeadf27d75 │ │ │ ├── serde_regex-8-a4cf34af32b83e40e5c8b6d083938b54 │ │ │ ├── serde_regex-9-f1175f3322abec6f258dd49a5905bce0 │ │ │ ├── serde_reported_schema-0-765ac345199b944a6136273becf29469 │ │ │ ├── serde_reported_schema-1-e8c6de8cd50be582d78c9a8244cd92a1 │ │ │ ├── serde_reported_schema-2-4da45ecbf2b2c9c1cb3ea05cb608710d │ │ │ ├── serde_reported_schema-3-738e1d72a19c3db37ded87ca2fb148fa │ │ │ ├── set_variable_sub-0-b0b2ec9de0599f8dc2eb160299a2699d │ │ │ ├── set_variable_sub-1-e504c8259e45911765541f605c9a46f1 │ │ │ ├── set_variable_sub-10-bf5d1e710ce0974a67b4084aaa868f67 │ │ │ ├── set_variable_sub-2-5b8cd23606e1a38f61eb6410ac6a09d6 │ │ │ ├── set_variable_sub-3-266170978f88a14c20c3944bfb55f5c7 │ │ │ ├── set_variable_sub-4-3839b7ac878ed6bdd4f9d242f965ded7 │ │ │ ├── set_variable_sub-5-ee3a31bb9bb742f90daea98b290c34cd │ │ │ ├── set_variable_sub-6-ee7a7e3d17bb0009f4cf3ffb001b471a │ │ │ ├── set_variable_sub-7-e25bdc67a6d9ea3f5d65676a92d1217b │ │ │ ├── set_variable_sub-8-f321516e93eb0206453465a9b85cf67d │ │ │ ├── set_variable_sub-9-fbb54d457caeaafce723856429bbc0b2 │ │ │ ├── show_columns-0-d84a430d0ab7a63a0a73361f8d188a4b │ │ │ ├── show_columns-1-ac73cff018bf94944244117a2eb76f7f │ │ │ ├── show_columns-10-695a68c82308540eba1d0a04e032cf39 │ │ │ ├── show_columns-11-691b4e6664e6d435233ea4e8c3b585d5 │ │ │ ├── show_columns-12-afc350d459a8f794cc3ca93092163a0c │ │ │ ├── show_columns-13-e86d559aeb84a4cc017a103182c22bfb │ │ │ ├── show_columns-14-7c1d63fa270b4d94b69ad49c3e2378a6 │ │ │ ├── show_columns-15-2c404655e35f7bd7ce54500c832f9d8e │ │ │ ├── show_columns-2-b74990316ec4245fd8a7011e684b39da │ │ │ ├── show_columns-3-6e40309b0ca10f353a68395ccd64d566 │ │ │ ├── show_columns-4-a62fc229d241303bffb29b34ad125f8c │ │ │ ├── show_columns-5-691b4e6664e6d435233ea4e8c3b585d5 │ │ │ ├── show_columns-6-37c88438bd364343a50f64cf39bfcaf6 │ │ │ ├── show_columns-7-afc350d459a8f794cc3ca93092163a0c │ │ │ ├── show_columns-8-9b0b96593ca513c6932f3ed8df68808a │ │ │ ├── show_columns-9-6c0fa8be1c19d4d216dfe7427df1275f │ │ │ ├── show_create_table_alter-0-813886d6cf0875c62e89cd1d06b8b0b4 │ │ │ ├── show_create_table_alter-1-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_alter-10-259d978ed9543204c8b9c25b6e25b0de │ │ │ ├── show_create_table_alter-2-928cc85c025440b731e5ee33e437e404 │ │ │ ├── show_create_table_alter-3-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_alter-4-c2cb6a7d942d4dddd1aababccb1239f9 │ │ │ ├── show_create_table_alter-5-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_alter-6-fdd1bd7f9acf0b2c8c9b7503d4046cb │ │ │ ├── show_create_table_alter-7-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_alter-8-22ab6ed5b15a018756f454dd2294847e │ │ │ ├── show_create_table_alter-9-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_db_table-0-67509558a4b2d39b25787cca33f52635 │ │ │ ├── show_create_table_db_table-1-549981e00a3d95f03dd5a9ef6044aa20 │ │ │ ├── show_create_table_db_table-2-34ae7e611d0aedbc62b6e420347abee │ │ │ ├── show_create_table_db_table-3-7a9e67189d3d4151f23b12c22bde06b5 │ │ │ ├── show_create_table_db_table-4-b585371b624cbab2616a49f553a870a0 │ │ │ ├── show_create_table_db_table-5-964757b7e7f2a69fe36132c1a5712199 │ │ │ ├── show_create_table_db_table-6-ac09cf81e7e734cf10406f30b9fa566e │ │ │ ├── show_create_table_delimited-0-52b0e534c7df544258a1c59df9f816ce │ │ │ ├── show_create_table_delimited-1-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_delimited-2-259d978ed9543204c8b9c25b6e25b0de │ │ │ ├── show_create_table_partitioned-0-4be9a3b1ff0840786a1f001cba170a0c │ │ │ ├── show_create_table_partitioned-1-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_partitioned-2-259d978ed9543204c8b9c25b6e25b0de │ │ │ ├── show_create_table_serde-0-33f15d91810b75ee05c7b9dea0abb01c │ │ │ ├── show_create_table_serde-1-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_serde-2-259d978ed9543204c8b9c25b6e25b0de │ │ │ ├── show_create_table_serde-3-fd12b3e0fe30f5d71c67676791b4a33b │ │ │ ├── show_create_table_serde-4-2a91d52719cf4552ebeb867204552a26 │ │ │ ├── show_create_table_serde-5-259d978ed9543204c8b9c25b6e25b0de │ │ │ ├── show_create_table_view-0-ecef6821e4e9212e553ca38142fd0250 │ │ │ ├── show_create_table_view-1-1e931ea3fa6065107859ffbb29bb0ed7 │ │ │ ├── show_create_table_view-2-ed97e9e56d95c5b3db57485cba5ad17f │ │ │ ├── show_describe_func_quotes-0-65fee14fcf58502241f0772b21096780 │ │ │ ├── show_describe_func_quotes-1-26b98b2901556449d5431d731aaa642d │ │ │ ├── show_describe_func_quotes-2-f795383fcecedf7266cd7aed8283cec3 │ │ │ ├── show_describe_func_quotes-3-7bc53505a4e6587132870d8d0a704d2 │ │ │ ├── show_functions-0-45a7762c39f1b0f26f076220e2764043 │ │ │ ├── show_functions-1-4a6f611305f58bdbafb2fd89ec62d797 │ │ │ ├── show_functions-2-97cbada21ad9efda7ce9de5891deca7c │ │ │ ├── show_functions-3-86945c60aed23626c43b507ee4ee6049 │ │ │ ├── show_functions-4-4deaa213aff83575bbaf859f79bfdd48 │ │ │ ├── show_functions-5-d6dad716f80a2e99ef9fc2e9782ef138 │ │ │ ├── show_partitions-0-73d0fdcea0bd9b828cbc3c2e88acb51a │ │ │ ├── show_partitions-1-e69b801a3c6c5f6692050bcdb0e31db9 │ │ │ ├── show_partitions-2-e94d4100cb64c67f1127b4e255d28ae0 │ │ │ ├── show_partitions-3-a1bde7c2c040b4d45ddceac9983c2ca │ │ │ ├── show_partitions-4-9e3f80cb6ed9883c715ea8aa3f391d70 │ │ │ ├── show_tblproperties-0-ca75bef7d151a44b6a89dd92333eb12a │ │ │ ├── show_tblproperties-1-be4adb893c7f946ebd76a648ce3cc1ae │ │ │ ├── show_tblproperties-2-7c7993eea8e41cf095afae07772cc16e │ │ │ ├── show_tblproperties-3-2b4b8c43ef08bdb418405917d475ac1d │ │ │ ├── show_tblproperties-4-6c63215ea599f6533666c4d70606b139 │ │ │ ├── show_tblproperties-5-be4adb893c7f946ebd76a648ce3cc1ae │ │ │ ├── show_tblproperties-6-9dd8d67460f558955d96a107ca996ad │ │ │ ├── single case-0-c264e319c52f1840a32959d552b99e73 │ │ │ ├── skewjoinopt13-0-cafed8ca348b243372b9114910be1557 │ │ │ ├── skewjoinopt13-1-16a1f74642d7ea4dac66a5ce15469c22 │ │ │ ├── skewjoinopt13-10-b81a7fa7b6158dd4d77fa4c62db1f223 │ │ │ ├── skewjoinopt13-2-114600d46ae86edcb66a500b4cac657d │ │ │ ├── skewjoinopt13-3-caf1c5fd299fdbdb655234d01d44caf2 │ │ │ ├── skewjoinopt13-4-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── skewjoinopt13-5-744a018c78bae6e09853dd202981e850 │ │ │ ├── skewjoinopt13-6-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── skewjoinopt13-7-c329b937ad1d7cf1c838640ef5f4d135 │ │ │ ├── skewjoinopt13-8-8eb53fb8f05a43ee377aa1c927857e7c │ │ │ ├── skewjoinopt13-9-ab816627b2137d1850cf05b6f2b59e2d │ │ │ ├── skewjoinopt18-0-cafed8ca348b243372b9114910be1557 │ │ │ ├── skewjoinopt18-1-16a1f74642d7ea4dac66a5ce15469c22 │ │ │ ├── skewjoinopt18-10-8c180ce74ca1ac0eefab2d70d38e44fa │ │ │ ├── skewjoinopt18-2-114600d46ae86edcb66a500b4cac657d │ │ │ ├── skewjoinopt18-3-32fed3a53e7c15b549a71c0e71d93484 │ │ │ ├── skewjoinopt18-4-abf4b7f158999af331d5dbfddf32fa68 │ │ │ ├── skewjoinopt18-5-dff9d122eb83760f08d1d77814c24c91 │ │ │ ├── skewjoinopt18-6-717b85f496a5cf006cb352f9d884608d │ │ │ ├── skewjoinopt18-7-41ca600110e24166325d9426d974fff7 │ │ │ ├── skewjoinopt18-8-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── skewjoinopt18-9-ae751060e656d20aa1afbe3fac16d304 │ │ │ ├── skewjoinopt9-0-cafed8ca348b243372b9114910be1557 │ │ │ ├── skewjoinopt9-1-16a1f74642d7ea4dac66a5ce15469c22 │ │ │ ├── skewjoinopt9-10-5c8be465ceef8151f172b82a13e81fa8 │ │ │ ├── skewjoinopt9-2-114600d46ae86edcb66a500b4cac657d │ │ │ ├── skewjoinopt9-3-9669bca0e2da11221b2e9eb21322e0c6 │ │ │ ├── skewjoinopt9-4-c0f14def6a135cc50cba364e810ce28e │ │ │ ├── skewjoinopt9-5-744a018c78bae6e09853dd202981e850 │ │ │ ├── skewjoinopt9-6-ade68a23d7b1a4f328623bb5a0f07488 │ │ │ ├── skewjoinopt9-7-350dd4f731e2c4157f83c148c8569203 │ │ │ ├── skewjoinopt9-8-446c5e33062b109341add64a9860207d │ │ │ ├── skewjoinopt9-9-83df7254049bc14de8aa53756850ceb5 │ │ │ ├── small.cartesian-0-e3c7f62795b0e7c14b41b0dc29c47619 │ │ │ ├── smb_mapjoin9-0-31cd5ae86d250c1c873260c4b73d2336 │ │ │ ├── smb_mapjoin9-1-c5c86975c400b3a1ec0f522b75635338 │ │ │ ├── smb_mapjoin9-10-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── smb_mapjoin9-11-43d53504df013e6b35f81811138a167a │ │ │ ├── smb_mapjoin9-12-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin9-13-d0eac0de35b5a7595e4567edec8e555d │ │ │ ├── smb_mapjoin9-14-f0de4fd75ca13f379fbea16010dfd3f9 │ │ │ ├── smb_mapjoin9-15-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin9-16-5645429104736d72293601247e874df7 │ │ │ ├── smb_mapjoin9-17-1018a99eaede08dc2b427d3fb4b91d6b │ │ │ ├── smb_mapjoin9-18-bda1fd3b5d0326dc3a41a8fb480b6c1c │ │ │ ├── smb_mapjoin9-19-823e8f68baaa45d6b761b9b9890bb902 │ │ │ ├── smb_mapjoin9-2-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin9-20-78ea4515eba2d8a79bb6895133a82051 │ │ │ ├── smb_mapjoin9-3-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin9-4-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin9-5-94bc4acde9b9c9944e2eb9a9c57d3450 │ │ │ ├── smb_mapjoin9-6-6c0963a1bdf2def39b79bea21a9cdda9 │ │ │ ├── smb_mapjoin9-7-ba9bc547b5d2a4912f4f8567fea4009c │ │ │ ├── smb_mapjoin9-8-d528ff47621b8c86b370f72512a7cd3c │ │ │ ├── smb_mapjoin9-9-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── smb_mapjoin_1-0-91ac1a1471f9d6dd9059bdc6c18f594a │ │ │ ├── smb_mapjoin_1-1-ef8d866d66ac801be99efef73664cbec │ │ │ ├── smb_mapjoin_1-10-b1114520feaa15ad7621b6a0e571c244 │ │ │ ├── smb_mapjoin_1-11-c9a5aea60b50d31499dc8d8516b3fed │ │ │ ├── smb_mapjoin_1-12-8fb6fea440e845ce23b06deed8f519fa │ │ │ ├── smb_mapjoin_1-13-7dc074e59f87c9e10b552c86eef9c96 │ │ │ ├── smb_mapjoin_1-14-b9e32ef49286a471ae2c4e7e66a2f5e1 │ │ │ ├── smb_mapjoin_1-15-4d7cd71c68715335030bd41244a9cb2c │ │ │ ├── smb_mapjoin_1-16-c120e505c143721a36287bf992dbc1a1 │ │ │ ├── smb_mapjoin_1-17-16c336c72785228fa1e6fcda01b20550 │ │ │ ├── smb_mapjoin_1-18-bcd8f7a7a4a77c8d6a39e38b93e5c5a1 │ │ │ ├── smb_mapjoin_1-19-9597d17924805ff4d34398d3a3d0a097 │ │ │ ├── smb_mapjoin_1-2-31ed4593e624995154d0aedf94aa0f0f │ │ │ ├── smb_mapjoin_1-20-d7979e9ab355d8856c2d12e66e7bb838 │ │ │ ├── smb_mapjoin_1-21-bce103f1a686915c28581717387cfeec │ │ │ ├── smb_mapjoin_1-22-df6bdfe3c5a7927687f4d1fbf0c9c25b │ │ │ ├── smb_mapjoin_1-23-aef0ab90470007f2ae589ca5dddd02fd │ │ │ ├── smb_mapjoin_1-24-558e9ab6324f8082231b2fdd0e12f7ae │ │ │ ├── smb_mapjoin_1-3-bd7036a4c0b57349a588b974ffaa502 │ │ │ ├── smb_mapjoin_1-4-22ace1b9a0302d2b8a4aa57a2c2f6423 │ │ │ ├── smb_mapjoin_1-5-6d835f651b099615df163be284e833de │ │ │ ├── smb_mapjoin_1-6-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_1-7-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_1-8-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_1-9-17098316902a9e99455fa01bd3dae3ea │ │ │ ├── smb_mapjoin_10-0-a2d52f742b171d642bc7b8ec244791c1 │ │ │ ├── smb_mapjoin_10-1-9385271b1309ae1609b41d8a30dbef24 │ │ │ ├── smb_mapjoin_10-10-189aeb9104e89114be759634d51c1a98 │ │ │ ├── smb_mapjoin_10-2-de26fe3669e18e6a170da561687fb514 │ │ │ ├── smb_mapjoin_10-3-68d65d622e45f86d4a6c7d1d09ef823b │ │ │ ├── smb_mapjoin_10-4-d31ad2289181131982ef3e9cd8c6386e │ │ │ ├── smb_mapjoin_10-5-f7fb003fa65cadcd0b13cbdd7b355988 │ │ │ ├── smb_mapjoin_10-6-14b8b2e10032ab2d4a0e7a18979cdb59 │ │ │ ├── smb_mapjoin_10-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_10-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_10-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_13-0-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_13-1-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_13-10-b07488dd0aa9072057d8264271e93495 │ │ │ ├── smb_mapjoin_13-11-c142d1f47152f247d4709b37780c46c4 │ │ │ ├── smb_mapjoin_13-12-fb171dfe3de091a91e347f53cf68c355 │ │ │ ├── smb_mapjoin_13-13-7b9c311217809cbb45a63be3c3e934ee │ │ │ ├── smb_mapjoin_13-14-b92cb43f66838319f5d607c431fe1eb3 │ │ │ ├── smb_mapjoin_13-15-b80660184510c5a283b3c10dcddb9e69 │ │ │ ├── smb_mapjoin_13-16-a05f3678364039a4cec1ced0dbda9884 │ │ │ ├── smb_mapjoin_13-2-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_13-3-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── smb_mapjoin_13-4-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── smb_mapjoin_13-5-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_13-6-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── smb_mapjoin_13-7-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── smb_mapjoin_13-8-721a75e4942a8ea97de6d70e441ce8a8 │ │ │ ├── smb_mapjoin_13-9-71b57a524e9ff17058ab319b18c606f6 │ │ │ ├── smb_mapjoin_14-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── smb_mapjoin_14-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── smb_mapjoin_14-10-fd4343f466f65fe84350a89ea501a8cd │ │ │ ├── smb_mapjoin_14-11-23d2ee09b01309b9cfcd0d625afc535d │ │ │ ├── smb_mapjoin_14-12-2037b594916a80436d571a87d7b5f2e3 │ │ │ ├── smb_mapjoin_14-13-95a09a0af2a77ac6b772c41a0f6a885a │ │ │ ├── smb_mapjoin_14-14-5db39db7bbdeae2d87a2dc1d65e6cd1d │ │ │ ├── smb_mapjoin_14-15-e0f20915e07acf5ddfdbde40ef924e55 │ │ │ ├── smb_mapjoin_14-16-1ae53bf26065f6ae200bd3f8f5702fa2 │ │ │ ├── smb_mapjoin_14-17-5983d1e12e5a2bdd0f41549110e066ee │ │ │ ├── smb_mapjoin_14-18-c58871e5f7179cd903e24ad22198dea9 │ │ │ ├── smb_mapjoin_14-19-163af33279f8d08d747a00ffd1cdfac7 │ │ │ ├── smb_mapjoin_14-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_14-20-b1651139605264c3b15178ae0543f7a │ │ │ ├── smb_mapjoin_14-21-b6c3a3f68f212a966450286e23f59713 │ │ │ ├── smb_mapjoin_14-22-f7839f8bcbb99d5731c9d4174c76b4b │ │ │ ├── smb_mapjoin_14-23-941d6ef1aaf1b2f16cf9b55eaea49068 │ │ │ ├── smb_mapjoin_14-24-46db62b188fef9c6d636e63d64ef0c20 │ │ │ ├── smb_mapjoin_14-25-23f011143d8db18dd0f3d684adf7b8e │ │ │ ├── smb_mapjoin_14-26-8dd1b03e8d405eb4c0c3a8bba78fca1b │ │ │ ├── smb_mapjoin_14-27-ba437062dd6661fc2fdcd41514711093 │ │ │ ├── smb_mapjoin_14-28-db27758cc8bdb4ff80f346ad7e158da3 │ │ │ ├── smb_mapjoin_14-29-d191c9ace84072ef430d7ed36ea8181b │ │ │ ├── smb_mapjoin_14-3-4938d4d724990d16336ee31f0390c7da │ │ │ ├── smb_mapjoin_14-30-377c21706143c1b714eeb0b3634343fb │ │ │ ├── smb_mapjoin_14-31-fde2ad19052435bd8c155f18fe579070 │ │ │ ├── smb_mapjoin_14-32-edfe76bb21077fec096eb60333cec7f7 │ │ │ ├── smb_mapjoin_14-33-fb532dd5af8cfe6b2af5c4752a3b0a44 │ │ │ ├── smb_mapjoin_14-4-378d42317b39c6519f15bd2f99c5ddc4 │ │ │ ├── smb_mapjoin_14-5-9140b367b5680860f4c7c0238377583f │ │ │ ├── smb_mapjoin_14-6-70c1d66123d434d3a1e1801e0b19bc3f │ │ │ ├── smb_mapjoin_14-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_14-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_14-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_15-0-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_15-1-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_15-10-fb63a2ba41589835c01ba5f7570f643b │ │ │ ├── smb_mapjoin_15-11-a8c3244fbb17a900a1bd7f634c90c7e6 │ │ │ ├── smb_mapjoin_15-12-b5a588fb78fda8e3c41bbc4d973c1a7a │ │ │ ├── smb_mapjoin_15-13-5983712d9bdc150d8b1ffe23a555b370 │ │ │ ├── smb_mapjoin_15-14-5455eb67634b186d7d8e54cdd32a9909 │ │ │ ├── smb_mapjoin_15-15-268af28b787b5403a164447cbdbb0720 │ │ │ ├── smb_mapjoin_15-16-98537b81d6e139521541753c3c448404 │ │ │ ├── smb_mapjoin_15-17-c2312024b8de8d40faaf65427fa3d499 │ │ │ ├── smb_mapjoin_15-18-7b1293b3066a5076e91b3d3dfd74259c │ │ │ ├── smb_mapjoin_15-19-f49ef85423bb1766362f05651c9bb37f │ │ │ ├── smb_mapjoin_15-2-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_15-20-7577942157bcb84ad24c51306b046a44 │ │ │ ├── smb_mapjoin_15-21-af3880637379684acd440830c2361f6e │ │ │ ├── smb_mapjoin_15-22-55700b43b9e34f4b8370f76d1b1bb7a0 │ │ │ ├── smb_mapjoin_15-23-e5e54dd17b69773812af376bfec33200 │ │ │ ├── smb_mapjoin_15-24-5983712d9bdc150d8b1ffe23a555b370 │ │ │ ├── smb_mapjoin_15-25-5455eb67634b186d7d8e54cdd32a9909 │ │ │ ├── smb_mapjoin_15-3-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── smb_mapjoin_15-4-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── smb_mapjoin_15-5-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_15-6-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── smb_mapjoin_15-7-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── smb_mapjoin_15-8-c19c008a41a546848f30a27237b124eb │ │ │ ├── smb_mapjoin_15-9-c11393a5b3fa2eba6e5f388e37e31cd3 │ │ │ ├── smb_mapjoin_16-0-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_16-1-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_16-10-fb63a2ba41589835c01ba5f7570f643b │ │ │ ├── smb_mapjoin_16-11-3c64de88fd6329a4346706ea296f7a4c │ │ │ ├── smb_mapjoin_16-12-32f3716e22149e3d0c1f3ac26d414baf │ │ │ ├── smb_mapjoin_16-2-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_16-3-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── smb_mapjoin_16-4-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── smb_mapjoin_16-5-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_16-6-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── smb_mapjoin_16-7-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── smb_mapjoin_16-8-14c221da1d1be2208aec9a641351ed09 │ │ │ ├── smb_mapjoin_16-9-6223202c291504ede983d8b04eafe08e │ │ │ ├── smb_mapjoin_17-0-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_17-1-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_17-10-516ad5af165e0e93b06b7541d35c96b8 │ │ │ ├── smb_mapjoin_17-11-c4daf31f90b01cfac9fb03b8b9de042 │ │ │ ├── smb_mapjoin_17-12-cc5a32c1984378efafe0f05202359b20 │ │ │ ├── smb_mapjoin_17-13-98da74d8dc8c7b722de5d2e25b481581 │ │ │ ├── smb_mapjoin_17-14-672606a44ad31bacc472e7e2825d4fd3 │ │ │ ├── smb_mapjoin_17-15-39292eb609c10f05f5c3dfacf520f485 │ │ │ ├── smb_mapjoin_17-16-da60c2ca6af8844ed44778f4067f4f27 │ │ │ ├── smb_mapjoin_17-17-bfc16d69eac4464e094e416842550590 │ │ │ ├── smb_mapjoin_17-18-cf2846a07aab193ac997eae616373367 │ │ │ ├── smb_mapjoin_17-19-c11dfa50e4541ba7081fd3c57e0bef56 │ │ │ ├── smb_mapjoin_17-2-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_17-20-50d120ef58fd6b737a01fccb3f212e9c │ │ │ ├── smb_mapjoin_17-21-b1069c2d3f38f78fa5c5635a74b4466f │ │ │ ├── smb_mapjoin_17-22-12d1838d39f395dbb212f322e83c49b0 │ │ │ ├── smb_mapjoin_17-23-e366aaa64bcf26a714cc9a451a6e8d6e │ │ │ ├── smb_mapjoin_17-24-ce87a96826f6025541ef71fd88c3d370 │ │ │ ├── smb_mapjoin_17-25-f066907fca3448b27aab623d05258a9a │ │ │ ├── smb_mapjoin_17-26-24ca942f094b14b92086305cc125e833 │ │ │ ├── smb_mapjoin_17-27-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── smb_mapjoin_17-28-b149d0fc9d40c63bb9a0807f5a0e04a6 │ │ │ ├── smb_mapjoin_17-29-65d3ae14a785f319658812b51e4620a3 │ │ │ ├── smb_mapjoin_17-3-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── smb_mapjoin_17-30-59009edb2442f58edebf83c8d047cb1e │ │ │ ├── smb_mapjoin_17-31-783fc1b07f117cd027395cf1c09149bc │ │ │ ├── smb_mapjoin_17-32-168e182e2c3feed13de0346cdeade2ff │ │ │ ├── smb_mapjoin_17-4-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── smb_mapjoin_17-5-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_17-6-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── smb_mapjoin_17-7-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── smb_mapjoin_17-8-14c221da1d1be2208aec9a641351ed09 │ │ │ ├── smb_mapjoin_17-9-6223202c291504ede983d8b04eafe08e │ │ │ ├── smb_mapjoin_2-0-91ac1a1471f9d6dd9059bdc6c18f594a │ │ │ ├── smb_mapjoin_2-1-ef8d866d66ac801be99efef73664cbec │ │ │ ├── smb_mapjoin_2-10-1530d7565a22ace89ed16e0e1f9988ac │ │ │ ├── smb_mapjoin_2-11-9fd2e0578c0a8f705929a4f89d3cc97 │ │ │ ├── smb_mapjoin_2-12-48e7d8fcb2a4c31c5304045517a3bb89 │ │ │ ├── smb_mapjoin_2-13-596594a24f753a66ffd1c87dcd76781d │ │ │ ├── smb_mapjoin_2-14-3e7d435c7a5560abe539918adc4fa922 │ │ │ ├── smb_mapjoin_2-15-2674b0d2498ac9392db40b4b83183d45 │ │ │ ├── smb_mapjoin_2-16-daeabb554f29b77f3c5ff7acff8c58ca │ │ │ ├── smb_mapjoin_2-17-404d18544be565d251a6b0db1601d663 │ │ │ ├── smb_mapjoin_2-18-411bc909c1c29811d184d1f4aceb25b3 │ │ │ ├── smb_mapjoin_2-19-95e94fc54d417dc08c7617642ee9de90 │ │ │ ├── smb_mapjoin_2-2-31ed4593e624995154d0aedf94aa0f0f │ │ │ ├── smb_mapjoin_2-20-43bc9e7e9e4d1bb1f42e7911bd79ea4b │ │ │ ├── smb_mapjoin_2-21-b9609684ffdae8768578849392032ad5 │ │ │ ├── smb_mapjoin_2-22-de0b3ef8ef1c5902908dadd06042b84 │ │ │ ├── smb_mapjoin_2-23-4dec46d167dbc1ac0bc9212e778d090a │ │ │ ├── smb_mapjoin_2-24-709966d157a75ffb1c6ef70d7c72a498 │ │ │ ├── smb_mapjoin_2-3-bd7036a4c0b57349a588b974ffaa502 │ │ │ ├── smb_mapjoin_2-4-22ace1b9a0302d2b8a4aa57a2c2f6423 │ │ │ ├── smb_mapjoin_2-5-6d835f651b099615df163be284e833de │ │ │ ├── smb_mapjoin_2-6-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_2-7-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_2-8-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_2-9-dff8aeed3b5d7577966d965afd6d5408 │ │ │ ├── smb_mapjoin_21-0-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_21-1-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_21-10-75e2e1eb0f45f4fad3e1ce24517dd81e │ │ │ ├── smb_mapjoin_21-11-720e78ad8ffc6620cc89a7e03bea3c4b │ │ │ ├── smb_mapjoin_21-12-c3217069b040b92693a575bc077b6f78 │ │ │ ├── smb_mapjoin_21-13-5e00c7d92c43c135a58a609eb6a4b6cf │ │ │ ├── smb_mapjoin_21-14-720e78ad8ffc6620cc89a7e03bea3c4b │ │ │ ├── smb_mapjoin_21-15-975f27d5b8171d0b1bd441fa5f2e1ddd │ │ │ ├── smb_mapjoin_21-16-c9250f30125e1235cb7ba01d97bbd1a │ │ │ ├── smb_mapjoin_21-17-720e78ad8ffc6620cc89a7e03bea3c4b │ │ │ ├── smb_mapjoin_21-18-471c4e00fbbba3b23158aa4bf7595e79 │ │ │ ├── smb_mapjoin_21-19-c9250f30125e1235cb7ba01d97bbd1a │ │ │ ├── smb_mapjoin_21-2-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── smb_mapjoin_21-20-720e78ad8ffc6620cc89a7e03bea3c4b │ │ │ ├── smb_mapjoin_21-21-ee61731107316feaef2efca38bb43fab │ │ │ ├── smb_mapjoin_21-22-1c43fc5ebecae6e400cbd3bea40e3490 │ │ │ ├── smb_mapjoin_21-23-720e78ad8ffc6620cc89a7e03bea3c4b │ │ │ ├── smb_mapjoin_21-24-c600a123838779df6a5babea49732659 │ │ │ ├── smb_mapjoin_21-25-bc535bc3d5108cdee7d8b670f0e763d5 │ │ │ ├── smb_mapjoin_21-3-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── smb_mapjoin_21-4-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_21-5-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── smb_mapjoin_21-6-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── smb_mapjoin_21-7-c248759cecf0e2c223579f5e37f6669c │ │ │ ├── smb_mapjoin_21-8-724d37bd4a841f1fa4062f4f3e3eb353 │ │ │ ├── smb_mapjoin_21-9-c0c82db5bd80edc57f6b3cb0e807f2ec │ │ │ ├── smb_mapjoin_25-0-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── smb_mapjoin_25-1-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── smb_mapjoin_25-10-bd7036a4c0b57349a588b974ffaa502 │ │ │ ├── smb_mapjoin_25-11-22ace1b9a0302d2b8a4aa57a2c2f6423 │ │ │ ├── smb_mapjoin_25-12-6d835f651b099615df163be284e833de │ │ │ ├── smb_mapjoin_25-13-182e8b532775f6e514195adbea3948a1 │ │ │ ├── smb_mapjoin_25-14-c23ea191ee4d60c0a6252ce763b1beed │ │ │ ├── smb_mapjoin_25-15-442e69416faaea9309bb8c2a3eb73ef │ │ │ ├── smb_mapjoin_25-16-beaea10543cfd753458b43d8aeb7571f │ │ │ ├── smb_mapjoin_25-17-24ca942f094b14b92086305cc125e833 │ │ │ ├── smb_mapjoin_25-18-d0ec6d66ff349db09fd455eec149efdb │ │ │ ├── smb_mapjoin_25-19-16112d7ada2ccc6f4a3b5d627410cb01 │ │ │ ├── smb_mapjoin_25-2-16367c381d4b189b3640c92511244bfe │ │ │ ├── smb_mapjoin_25-20-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── smb_mapjoin_25-21-4d3e60a0e9bd8c12fdba4e010493537d │ │ │ ├── smb_mapjoin_25-22-d0a93f40892e3894460553b443c77428 │ │ │ ├── smb_mapjoin_25-23-ae45f6382268c1035c11aa4fc8a23e2 │ │ │ ├── smb_mapjoin_25-24-d5ad76f9178cb787cee037f25b19b270 │ │ │ ├── smb_mapjoin_25-25-a59d19c2438bddb97dc54c08dcf1d8e6 │ │ │ ├── smb_mapjoin_25-26-5a5aa75e424b6b5e3a2988e52bf3eff6 │ │ │ ├── smb_mapjoin_25-3-bcde511b8d560ca83888265b96a781ff │ │ │ ├── smb_mapjoin_25-4-8067b7ab260021bc70af9ab47309ee35 │ │ │ ├── smb_mapjoin_25-5-545c0ea2ebd7a141526ee13059a857f6 │ │ │ ├── smb_mapjoin_25-6-dbcec232623048c7748b708123e18bf0 │ │ │ ├── smb_mapjoin_25-7-91ac1a1471f9d6dd9059bdc6c18f594a │ │ │ ├── smb_mapjoin_25-8-ef8d866d66ac801be99efef73664cbec │ │ │ ├── smb_mapjoin_25-9-31ed4593e624995154d0aedf94aa0f0f │ │ │ ├── smb_mapjoin_3-0-91ac1a1471f9d6dd9059bdc6c18f594a │ │ │ ├── smb_mapjoin_3-1-ef8d866d66ac801be99efef73664cbec │ │ │ ├── smb_mapjoin_3-10-efadb45f09b92d27233601394d53d79 │ │ │ ├── smb_mapjoin_3-11-52555bc44b4359aacfc42669bc5e4d12 │ │ │ ├── smb_mapjoin_3-12-77988b41de4b5a165c93942fbb2220d6 │ │ │ ├── smb_mapjoin_3-13-812a0834a0e6546d5d0c8123d35c260f │ │ │ ├── smb_mapjoin_3-14-5456a3a43bfabcfdbb57257b633e299e │ │ │ ├── smb_mapjoin_3-15-adc9940d6a104bca6ec791e57bdb09c0 │ │ │ ├── smb_mapjoin_3-16-fff1acc77150f6ea92fe8eefc04b079a │ │ │ ├── smb_mapjoin_3-17-1f00c63a1df29100d6e5fc4dcb4b0cfe │ │ │ ├── smb_mapjoin_3-18-96a658e934543dd77020ad264ec9b8c1 │ │ │ ├── smb_mapjoin_3-19-bc0ddeb7b24fc7ed3fbcf77ced76ba07 │ │ │ ├── smb_mapjoin_3-2-31ed4593e624995154d0aedf94aa0f0f │ │ │ ├── smb_mapjoin_3-20-867845ed2cb38b55928f5310b4ae91bd │ │ │ ├── smb_mapjoin_3-21-da48411b3e139037e171654fc9861755 │ │ │ ├── smb_mapjoin_3-22-5826f60da3a4b0c731c53340d50b0a06 │ │ │ ├── smb_mapjoin_3-23-3e229e8219fe44b4a01f64b0967d7b31 │ │ │ ├── smb_mapjoin_3-24-c73176ea199d4d20934cf2659d42ec25 │ │ │ ├── smb_mapjoin_3-3-bd7036a4c0b57349a588b974ffaa502 │ │ │ ├── smb_mapjoin_3-4-22ace1b9a0302d2b8a4aa57a2c2f6423 │ │ │ ├── smb_mapjoin_3-5-6d835f651b099615df163be284e833de │ │ │ ├── smb_mapjoin_3-6-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_3-7-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_3-8-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_3-9-8928717d58becd4fd358f3fec65d60af │ │ │ ├── smb_mapjoin_4-0-91ac1a1471f9d6dd9059bdc6c18f594a │ │ │ ├── smb_mapjoin_4-1-ef8d866d66ac801be99efef73664cbec │ │ │ ├── smb_mapjoin_4-10-73afe8a2334d1dbb7d4af749875e2f24 │ │ │ ├── smb_mapjoin_4-11-59fd75b48de9cbd23accc4c4414c6162 │ │ │ ├── smb_mapjoin_4-12-233250782bea3c7815e4c9949993d4f9 │ │ │ ├── smb_mapjoin_4-13-1ae07a8abc39f6a4195865ac583c1fb8 │ │ │ ├── smb_mapjoin_4-14-a6efb153fe9be91c7055a5642e0f642d │ │ │ ├── smb_mapjoin_4-15-18da9766adcfcd53820d747d4b573886 │ │ │ ├── smb_mapjoin_4-16-514034935af5348f67f1934cf5429d57 │ │ │ ├── smb_mapjoin_4-17-2a4723deed66d7aca3c272784dd11901 │ │ │ ├── smb_mapjoin_4-18-7f8bfb8ce6c1825708c37daa826fe5 │ │ │ ├── smb_mapjoin_4-19-afa62ebf8d41de52dfe732bdc470a995 │ │ │ ├── smb_mapjoin_4-2-31ed4593e624995154d0aedf94aa0f0f │ │ │ ├── smb_mapjoin_4-20-be9350a00a523e1758427a1c8e4bdf09 │ │ │ ├── smb_mapjoin_4-21-b4e83e2474975db8ed614e671af132f2 │ │ │ ├── smb_mapjoin_4-22-da023084bbab6727dc3823cfce500308 │ │ │ ├── smb_mapjoin_4-23-48c28e1909386c95f78cb448bb6272e8 │ │ │ ├── smb_mapjoin_4-24-7783ab33a26d29a2c0235f52f0e4ad86 │ │ │ ├── smb_mapjoin_4-25-c12edf424bd7b75fc06a21d6498b89d2 │ │ │ ├── smb_mapjoin_4-26-de14aa74d0da48dff6271410cc5dd98e │ │ │ ├── smb_mapjoin_4-27-2617dc7a064cbb545c3ea54fe82c45ef │ │ │ ├── smb_mapjoin_4-28-f71280b4b556515d068d074378c3a54 │ │ │ ├── smb_mapjoin_4-29-239bc4053a7791815b587afef03515fb │ │ │ ├── smb_mapjoin_4-3-bd7036a4c0b57349a588b974ffaa502 │ │ │ ├── smb_mapjoin_4-30-a0d3abda611809460bcea4101967f21f │ │ │ ├── smb_mapjoin_4-31-35fa9389f1249c6cd736786522e6d3c5 │ │ │ ├── smb_mapjoin_4-32-6477640b8a0a96f7a1c9290b8e71b5a8 │ │ │ ├── smb_mapjoin_4-33-bc66eac0bf67a5c88f75ca66f0722e07 │ │ │ ├── smb_mapjoin_4-34-48869ba51ea36864e720f94b09bf6b3 │ │ │ ├── smb_mapjoin_4-4-22ace1b9a0302d2b8a4aa57a2c2f6423 │ │ │ ├── smb_mapjoin_4-5-6d835f651b099615df163be284e833de │ │ │ ├── smb_mapjoin_4-6-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_4-7-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_4-8-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_4-9-137cd40f999272507f72f2faa2fbd7db │ │ │ ├── smb_mapjoin_5-0-91ac1a1471f9d6dd9059bdc6c18f594a │ │ │ ├── smb_mapjoin_5-1-ef8d866d66ac801be99efef73664cbec │ │ │ ├── smb_mapjoin_5-10-df63d18b19a05a728723ad01d4e526fc │ │ │ ├── smb_mapjoin_5-11-656085efab25db5dc019824b6b9a6bf5 │ │ │ ├── smb_mapjoin_5-12-a7a6dd05f89679cf3d621ca969a468e4 │ │ │ ├── smb_mapjoin_5-13-a1bada65e6df26b6e66681c565b41f2a │ │ │ ├── smb_mapjoin_5-14-e20bcd28cfd26259bcde9cffec8d2280 │ │ │ ├── smb_mapjoin_5-15-cff7ff4d03450148a945711bad28b34 │ │ │ ├── smb_mapjoin_5-16-8a8dc418de3716f5112b9868f472e4b9 │ │ │ ├── smb_mapjoin_5-17-6e755e2d2b23e9bd4073794eb4dbaa4f │ │ │ ├── smb_mapjoin_5-18-1f0dd26e6088c4f359fb691a8ef650bc │ │ │ ├── smb_mapjoin_5-19-dd3d36a83baa3ac6155ad9b2c987657a │ │ │ ├── smb_mapjoin_5-2-31ed4593e624995154d0aedf94aa0f0f │ │ │ ├── smb_mapjoin_5-20-18fe4e120d3c0d663c360b2504b4f88d │ │ │ ├── smb_mapjoin_5-21-7fd638ed676fe06a4970cc0c4a61b6c2 │ │ │ ├── smb_mapjoin_5-22-6ed2620fe017e454459a83061f25951a │ │ │ ├── smb_mapjoin_5-23-e68f9dc71bb8d5bcaf24d11e21da572a │ │ │ ├── smb_mapjoin_5-24-87f758a20c15fa3b97b4ba6703ae541b │ │ │ ├── smb_mapjoin_5-25-9f57e8a72a99c2e9a9d37bfb379af31 │ │ │ ├── smb_mapjoin_5-26-1c1a9519e207edc3c3a927c986a37177 │ │ │ ├── smb_mapjoin_5-27-d29148ce40aca2915f54788d3890b6e2 │ │ │ ├── smb_mapjoin_5-28-94440444fff7d2629a23a30fd778fcc7 │ │ │ ├── smb_mapjoin_5-29-8862326985836c72a2b21cb96a151579 │ │ │ ├── smb_mapjoin_5-3-bd7036a4c0b57349a588b974ffaa502 │ │ │ ├── smb_mapjoin_5-30-574d26a5179e5cebbbff5bbb425a9609 │ │ │ ├── smb_mapjoin_5-31-aa33e936a0d1a5ed534caef75647f0c3 │ │ │ ├── smb_mapjoin_5-32-17c99f827824994cfd21c40dbf4abfc │ │ │ ├── smb_mapjoin_5-33-487e89a8efb4dea08105f2fa79de5087 │ │ │ ├── smb_mapjoin_5-34-4db871582cf4f3038d43d0a2d5ae6895 │ │ │ ├── smb_mapjoin_5-4-22ace1b9a0302d2b8a4aa57a2c2f6423 │ │ │ ├── smb_mapjoin_5-5-6d835f651b099615df163be284e833de │ │ │ ├── smb_mapjoin_5-6-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_5-7-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_5-8-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_5-9-88a0d8b67f250913ba2be3cddffeb7df │ │ │ ├── smb_mapjoin_6-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── smb_mapjoin_6-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── smb_mapjoin_6-10-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_6-11-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_6-12-39e8889c37ee53d9a0ba48165b080b14 │ │ │ ├── smb_mapjoin_6-13-f9de7f57a4c89ccf84d35f47abb40d77 │ │ │ ├── smb_mapjoin_6-14-43123d2821871aa5b4d4a9e22e03d1ca │ │ │ ├── smb_mapjoin_6-15-c673bbec2ee476eea9609be3d3555438 │ │ │ ├── smb_mapjoin_6-16-449cb60e6537ba0810ea6879a7351a1e │ │ │ ├── smb_mapjoin_6-17-aa5f237005fb69b3f52808c80b4a276a │ │ │ ├── smb_mapjoin_6-18-a2ed8f3ca5f4a3c2d1377bc82463fe1a │ │ │ ├── smb_mapjoin_6-19-4fd621581c51ad55a7e8389a94c6a411 │ │ │ ├── smb_mapjoin_6-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_6-20-f9de7f57a4c89ccf84d35f47abb40d77 │ │ │ ├── smb_mapjoin_6-21-43123d2821871aa5b4d4a9e22e03d1ca │ │ │ ├── smb_mapjoin_6-22-c673bbec2ee476eea9609be3d3555438 │ │ │ ├── smb_mapjoin_6-23-449cb60e6537ba0810ea6879a7351a1e │ │ │ ├── smb_mapjoin_6-24-aa5f237005fb69b3f52808c80b4a276a │ │ │ ├── smb_mapjoin_6-25-e3552fabb4c9920d9bb964da5b907b46 │ │ │ ├── smb_mapjoin_6-26-5796487563f66866051a86f9c8cee822 │ │ │ ├── smb_mapjoin_6-27-efb64856d7a3cadd61eb1e2c61197c8 │ │ │ ├── smb_mapjoin_6-28-9715967e9a70084a4600ccac53dfac60 │ │ │ ├── smb_mapjoin_6-29-495784f95b09cffa052805c6b9af9216 │ │ │ ├── smb_mapjoin_6-3-2bfc6b33655f683fa9bd62ced5dab230 │ │ │ ├── smb_mapjoin_6-30-2cd20a399ce104eb7fb5881e59238196 │ │ │ ├── smb_mapjoin_6-4-6eb37be25535293ca377a47c3e08bffa │ │ │ ├── smb_mapjoin_6-5-ab8df8b65b35c17c45cac15468a4042c │ │ │ ├── smb_mapjoin_6-6-ae6abe879c8ee2b101c7d78da0770dd1 │ │ │ ├── smb_mapjoin_6-7-d7835ed6fd3add8aa8d65ef196798cc4 │ │ │ ├── smb_mapjoin_6-8-2e0e607c192151d31a6e6513fba79ef3 │ │ │ ├── smb_mapjoin_6-9-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_7-0-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── smb_mapjoin_7-1-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── smb_mapjoin_7-10-2e0e607c192151d31a6e6513fba79ef3 │ │ │ ├── smb_mapjoin_7-11-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_7-12-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_7-13-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_7-14-5e1546e0e05871eb1a6b8eb957252542 │ │ │ ├── smb_mapjoin_7-15-5e1546e0e05871eb1a6b8eb957252542 │ │ │ ├── smb_mapjoin_7-16-18d2a689883588ae3c24b2810663ab80 │ │ │ ├── smb_mapjoin_7-17-2ff32fe07d35a4d44b640f3ded5767fd │ │ │ ├── smb_mapjoin_7-18-1a4ee3f64c4a9bb1689234d30babb4a │ │ │ ├── smb_mapjoin_7-19-ab46164010b27950c293f32fb89f9f8a │ │ │ ├── smb_mapjoin_7-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_7-20-35dcb5bae00dc0cc7afa6663a5126fe6 │ │ │ ├── smb_mapjoin_7-21-449cb60e6537ba0810ea6879a7351a1e │ │ │ ├── smb_mapjoin_7-22-aa5f237005fb69b3f52808c80b4a276a │ │ │ ├── smb_mapjoin_7-23-1b6140f49d49eb1195c8551270b97ff │ │ │ ├── smb_mapjoin_7-3-e666afe7d9a532114a6133b7dc7df5aa │ │ │ ├── smb_mapjoin_7-4-85d6ffbe24f95df3128dee0e21a032de │ │ │ ├── smb_mapjoin_7-5-ab8df8b65b35c17c45cac15468a4042c │ │ │ ├── smb_mapjoin_7-6-8613f4d139c1ccdbb3be9b7af0e24ad4 │ │ │ ├── smb_mapjoin_7-7-ae6abe879c8ee2b101c7d78da0770dd1 │ │ │ ├── smb_mapjoin_7-8-f983875c44b290b0884a22b6be6adc8 │ │ │ ├── smb_mapjoin_7-9-84a394d962965e38593883742cc32c0d │ │ │ ├── smb_mapjoin_8-0-43d53504df013e6b35f81811138a167a │ │ │ ├── smb_mapjoin_8-1-e39f59c35ebbe686a18d45d9d8bf3ab0 │ │ │ ├── smb_mapjoin_8-10-401c6c31bc3ae2cbd493a3855b829893 │ │ │ ├── smb_mapjoin_8-11-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── smb_mapjoin_8-12-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── smb_mapjoin_8-13-b89ea2173180c8ae423d856f943e061f │ │ │ ├── smb_mapjoin_8-14-17529a2129bd485b814dde1ef894f06 │ │ │ ├── smb_mapjoin_8-15-343dfc1301b9f601ae03cb15f790102b │ │ │ ├── smb_mapjoin_8-16-e8f0853543694175095a8642e8f4fa03 │ │ │ ├── smb_mapjoin_8-17-5d2bab62264e462c007eb1a7a2c68866 │ │ │ ├── smb_mapjoin_8-18-17529a2129bd485b814dde1ef894f06 │ │ │ ├── smb_mapjoin_8-19-343dfc1301b9f601ae03cb15f790102b │ │ │ ├── smb_mapjoin_8-2-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── smb_mapjoin_8-20-3af6a47b927b966f80a8f4c973b5f1f7 │ │ │ ├── smb_mapjoin_8-21-77ac2e23e8a8bc22274952933cd8d252 │ │ │ ├── smb_mapjoin_8-22-17529a2129bd485b814dde1ef894f06 │ │ │ ├── smb_mapjoin_8-23-343dfc1301b9f601ae03cb15f790102b │ │ │ ├── smb_mapjoin_8-24-4e7e6b8eb897ed86e28d435c4f522e7c │ │ │ ├── smb_mapjoin_8-25-722aa3855f98f940fb34368c2789bcc3 │ │ │ ├── smb_mapjoin_8-26-17529a2129bd485b814dde1ef894f06 │ │ │ ├── smb_mapjoin_8-27-343dfc1301b9f601ae03cb15f790102b │ │ │ ├── smb_mapjoin_8-28-4e7e6b8eb897ed86e28d435c4f522e7c │ │ │ ├── smb_mapjoin_8-29-722aa3855f98f940fb34368c2789bcc3 │ │ │ ├── smb_mapjoin_8-3-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── smb_mapjoin_8-30-19b2b8c39155340929c605494826d30e │ │ │ ├── smb_mapjoin_8-31-3b6920dfb64f41b1b3c3c265275b1e4a │ │ │ ├── smb_mapjoin_8-32-4e7e6b8eb897ed86e28d435c4f522e7c │ │ │ ├── smb_mapjoin_8-33-722aa3855f98f940fb34368c2789bcc3 │ │ │ ├── smb_mapjoin_8-34-c8132556830d31a8803b07273aa1558f │ │ │ ├── smb_mapjoin_8-35-3b6920dfb64f41b1b3c3c265275b1e4a │ │ │ ├── smb_mapjoin_8-36-3af6a47b927b966f80a8f4c973b5f1f7 │ │ │ ├── smb_mapjoin_8-37-77ac2e23e8a8bc22274952933cd8d252 │ │ │ ├── smb_mapjoin_8-38-5ca28e78b53d14893518057c142f68a9 │ │ │ ├── smb_mapjoin_8-39-3b6920dfb64f41b1b3c3c265275b1e4a │ │ │ ├── smb_mapjoin_8-4-cd78ebbe3cc259ee6efb946f6b28f8d5 │ │ │ ├── smb_mapjoin_8-40-7aa01ceccf1bb45418145bdfc061206b │ │ │ ├── smb_mapjoin_8-41-8cf49829aada9587f04c9a5f334c433c │ │ │ ├── smb_mapjoin_8-42-d656a335f0f2f311717e2d72d0a9b6c6 │ │ │ ├── smb_mapjoin_8-43-3b6920dfb64f41b1b3c3c265275b1e4a │ │ │ ├── smb_mapjoin_8-44-559ecfd50bcc8c1bf63024c160bcad35 │ │ │ ├── smb_mapjoin_8-45-8cf49829aada9587f04c9a5f334c433c │ │ │ ├── smb_mapjoin_8-46-d656a335f0f2f311717e2d72d0a9b6c6 │ │ │ ├── smb_mapjoin_8-47-3b6920dfb64f41b1b3c3c265275b1e4a │ │ │ ├── smb_mapjoin_8-5-eee18fc4192a4aa92a066eb66513be93 │ │ │ ├── smb_mapjoin_8-6-f6541fbe0d06b7ce2479fc4da9d2905a │ │ │ ├── smb_mapjoin_8-7-35e90a6bc292cfd33b48c52460937858 │ │ │ ├── smb_mapjoin_8-8-81a6ffb61cbddc9900790d8b08e39e2a │ │ │ ├── smb_mapjoin_8-9-bd2b5b7d4eaec7854e3051455e601109 │ │ │ ├── sort-0-eee35bbc888a705ae527625447668032 │ │ │ ├── sort-1-10c8b0a592ed15eff488a71ec5909f45 │ │ │ ├── sort_merge_join_desc_1-0-6a35b44d4170109f641f8b68efef3719 │ │ │ ├── sort_merge_join_desc_1-1-a1c5a993c00586e79a161a5a11a6fe5c │ │ │ ├── sort_merge_join_desc_1-10-e4475ba09980280452542a0d595b8217 │ │ │ ├── sort_merge_join_desc_1-11-3599c6aa6da9420bdcec89c8516ffe89 │ │ │ ├── sort_merge_join_desc_1-2-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── sort_merge_join_desc_1-3-6cc3ecca54fb84949a89240c50d4bd19 │ │ │ ├── sort_merge_join_desc_1-4-a2e980fa0fbe8737cf256e21c784193e │ │ │ ├── sort_merge_join_desc_1-5-452fb932f6353effc9c458ec24dbeff9 │ │ │ ├── sort_merge_join_desc_1-6-7033dd1c3de2ad70a50a522d88533cf2 │ │ │ ├── sort_merge_join_desc_1-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── sort_merge_join_desc_1-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_1-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── sort_merge_join_desc_2-0-6a35b44d4170109f641f8b68efef3719 │ │ │ ├── sort_merge_join_desc_2-1-a1c5a993c00586e79a161a5a11a6fe5c │ │ │ ├── sort_merge_join_desc_2-10-c0cac985e4115bf4014274b21222cac9 │ │ │ ├── sort_merge_join_desc_2-11-47bc9cb5f049aaca33b394ea78578bdd │ │ │ ├── sort_merge_join_desc_2-2-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── sort_merge_join_desc_2-3-a38a9b74e94a1eb032a52d905d863d46 │ │ │ ├── sort_merge_join_desc_2-4-ac10c36f76f1dcf25783bb796d182f64 │ │ │ ├── sort_merge_join_desc_2-5-452fb932f6353effc9c458ec24dbeff9 │ │ │ ├── sort_merge_join_desc_2-6-7033dd1c3de2ad70a50a522d88533cf2 │ │ │ ├── sort_merge_join_desc_2-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── sort_merge_join_desc_2-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_2-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── sort_merge_join_desc_3-0-6a35b44d4170109f641f8b68efef3719 │ │ │ ├── sort_merge_join_desc_3-1-a1c5a993c00586e79a161a5a11a6fe5c │ │ │ ├── sort_merge_join_desc_3-10-8aa5c2ebf5cb82b372b17954dbdb5f28 │ │ │ ├── sort_merge_join_desc_3-11-47bc9cb5f049aaca33b394ea78578bdd │ │ │ ├── sort_merge_join_desc_3-2-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── sort_merge_join_desc_3-3-ce75a01507b158094bcf4441f3bfea95 │ │ │ ├── sort_merge_join_desc_3-4-ac1b8e89e9977e535e7e499992b6ccf2 │ │ │ ├── sort_merge_join_desc_3-5-452fb932f6353effc9c458ec24dbeff9 │ │ │ ├── sort_merge_join_desc_3-6-7033dd1c3de2ad70a50a522d88533cf2 │ │ │ ├── sort_merge_join_desc_3-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── sort_merge_join_desc_3-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_3-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── sort_merge_join_desc_4-0-6a35b44d4170109f641f8b68efef3719 │ │ │ ├── sort_merge_join_desc_4-1-a1c5a993c00586e79a161a5a11a6fe5c │ │ │ ├── sort_merge_join_desc_4-10-99adddf7dacf8042707a9b36062fe103 │ │ │ ├── sort_merge_join_desc_4-11-47bc9cb5f049aaca33b394ea78578bdd │ │ │ ├── sort_merge_join_desc_4-2-ffe97dc8c1df3195982e38263fbe8717 │ │ │ ├── sort_merge_join_desc_4-3-ce75a01507b158094bcf4441f3bfea95 │ │ │ ├── sort_merge_join_desc_4-4-ac10c36f76f1dcf25783bb796d182f64 │ │ │ ├── sort_merge_join_desc_4-5-452fb932f6353effc9c458ec24dbeff9 │ │ │ ├── sort_merge_join_desc_4-6-7033dd1c3de2ad70a50a522d88533cf2 │ │ │ ├── sort_merge_join_desc_4-7-3b0f76816be2c1b18a2058027a19bc9f │ │ │ ├── sort_merge_join_desc_4-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_4-9-b89ea2173180c8ae423d856f943e061f │ │ │ ├── sort_merge_join_desc_5-0-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── sort_merge_join_desc_5-1-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── sort_merge_join_desc_5-10-cd2f3c647c0821eb53e67d36b1556a4a │ │ │ ├── sort_merge_join_desc_5-2-1a2fc4c300be7c94681bebc14f7f7deb │ │ │ ├── sort_merge_join_desc_5-3-ac35b16d0e28472c6079f4ce2ee1438d │ │ │ ├── sort_merge_join_desc_5-4-f392824f42188aac282046394108ef48 │ │ │ ├── sort_merge_join_desc_5-5-85d19fc31c2031491560208803fe63bf │ │ │ ├── sort_merge_join_desc_5-6-eac4a4cf29e65d7bd394bbfc57fcbfa7 │ │ │ ├── sort_merge_join_desc_5-7-c23ea191ee4d60c0a6252ce763b1beed │ │ │ ├── sort_merge_join_desc_5-8-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_5-9-8b5783beaca02bba77d82adefe02c51 │ │ │ ├── sort_merge_join_desc_6-0-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── sort_merge_join_desc_6-1-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── sort_merge_join_desc_6-10-4c7a7ec8806a506693dcb7278c90cba8 │ │ │ ├── sort_merge_join_desc_6-11-cd2f3c647c0821eb53e67d36b1556a4a │ │ │ ├── sort_merge_join_desc_6-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── sort_merge_join_desc_6-3-d651a32232651880ad90428ada99358b │ │ │ ├── sort_merge_join_desc_6-4-ac35b16d0e28472c6079f4ce2ee1438d │ │ │ ├── sort_merge_join_desc_6-5-9d2278807f7eef56292afd44b347ff64 │ │ │ ├── sort_merge_join_desc_6-6-85d19fc31c2031491560208803fe63bf │ │ │ ├── sort_merge_join_desc_6-7-e12bb9bc44b0ed7e980ebe47517bc3e8 │ │ │ ├── sort_merge_join_desc_6-8-c23ea191ee4d60c0a6252ce763b1beed │ │ │ ├── sort_merge_join_desc_6-9-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_7-0-7b4ad215fc2e75c71c6614a2b6322e8e │ │ │ ├── sort_merge_join_desc_7-1-365488a703b0640acda73a7d7e6efa06 │ │ │ ├── sort_merge_join_desc_7-10-5918e837d2ae72cfaa753516c8652f24 │ │ │ ├── sort_merge_join_desc_7-11-e87a4aa598ea59bfbb7e61879a5b51c7 │ │ │ ├── sort_merge_join_desc_7-12-c23ea191ee4d60c0a6252ce763b1beed │ │ │ ├── sort_merge_join_desc_7-13-86473a0498e4361e4db0b4a22f2e8571 │ │ │ ├── sort_merge_join_desc_7-14-afdad72caa2e23071817fe124da07763 │ │ │ ├── sort_merge_join_desc_7-15-22330850dd2a9d18dedb504ea5879a07 │ │ │ ├── sort_merge_join_desc_7-2-7cccbdffc32975f8935eeba14a28147 │ │ │ ├── sort_merge_join_desc_7-3-546c076289ceaf1fbee969aeb30b402b │ │ │ ├── sort_merge_join_desc_7-4-ac35b16d0e28472c6079f4ce2ee1438d │ │ │ ├── sort_merge_join_desc_7-5-5f8d9bff48ffdbcc9a18553575bd0c83 │ │ │ ├── sort_merge_join_desc_7-6-7cf7a404374e41059f8c1db181a0e1f0 │ │ │ ├── sort_merge_join_desc_7-7-fecc7e5eef32fd38735e82d9d78a324f │ │ │ ├── sort_merge_join_desc_7-8-85d19fc31c2031491560208803fe63bf │ │ │ ├── sort_merge_join_desc_7-9-d1cfb738e07e78009bac4881c05853ec │ │ │ ├── stats0-0-418ec894d08c33fd712eb358f579b7a0 │ │ │ ├── stats0-1-e7bfbd9422685e9a3a6c9bd4965f828f │ │ │ ├── stats0-10-ee1bfc1f0047527d9bd745dcc747ab6c │ │ │ ├── stats0-11-82294461be4728b4b191414bf2fb3bd7 │ │ │ ├── stats0-12-31ebc4dcaa13c6dc5937c04f603e699 │ │ │ ├── stats0-13-ca0569fd4200d549843deadf84044649 │ │ │ ├── stats0-14-4f18f4b06db06844920b14e2d19471a9 │ │ │ ├── stats0-15-4a7ed5b7e3deb4106204f8f950357e1c │ │ │ ├── stats0-16-b12e5c70d6d29757471b900b6160fa8a │ │ │ ├── stats0-17-593999fae618b6b38322bc9ae4e0c027 │ │ │ ├── stats0-18-bb8d8522a40a50fb684fabffd2fa7d17 │ │ │ ├── stats0-19-eb5c7d6fd7433dfe9684e43e4a3419ed │ │ │ ├── stats0-2-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── stats0-20-5f7439f97275da70f633e135205f2095 │ │ │ ├── stats0-21-6bcc1360b3d777a8b51ae416ff43898a │ │ │ ├── stats0-22-85de3349a12a9fa0536f20ad0377fca1 │ │ │ ├── stats0-23-247568f4b3ce6b97979ca9d28c2ba05c │ │ │ ├── stats0-24-7f38972bcd18c477a027d881182d83f9 │ │ │ ├── stats0-25-98c925a2b2c4de06e270e1b52437a98b │ │ │ ├── stats0-26-ee1bfc1f0047527d9bd745dcc747ab6c │ │ │ ├── stats0-27-82294461be4728b4b191414bf2fb3bd7 │ │ │ ├── stats0-28-31ebc4dcaa13c6dc5937c04f603e699 │ │ │ ├── stats0-29-ca0569fd4200d549843deadf84044649 │ │ │ ├── stats0-3-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── stats0-30-4f18f4b06db06844920b14e2d19471a9 │ │ │ ├── stats0-31-4a7ed5b7e3deb4106204f8f950357e1c │ │ │ ├── stats0-4-5f7439f97275da70f633e135205f2095 │ │ │ ├── stats0-5-6bcc1360b3d777a8b51ae416ff43898a │ │ │ ├── stats0-6-85de3349a12a9fa0536f20ad0377fca1 │ │ │ ├── stats0-7-247568f4b3ce6b97979ca9d28c2ba05c │ │ │ ├── stats0-8-7f38972bcd18c477a027d881182d83f9 │ │ │ ├── stats0-9-98c925a2b2c4de06e270e1b52437a98b │ │ │ ├── stats_aggregator_error_1-0-6f3df708fa339df236ec9375d2ad37fa │ │ │ ├── stats_aggregator_error_1-1-36eee5cbac5c0c3228e499805b32f6 │ │ │ ├── stats_aggregator_error_1-10-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_aggregator_error_1-11-d58626190cded8d09f0457739a980eb │ │ │ ├── stats_aggregator_error_1-12-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_aggregator_error_1-13-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_aggregator_error_1-14-60a231b64a4a0e414d0ddce1c813c614 │ │ │ ├── stats_aggregator_error_1-15-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_aggregator_error_1-16-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_aggregator_error_1-2-2ca079278e0de95eecb5df315ce05c6 │ │ │ ├── stats_aggregator_error_1-3-66e3e0c942759f679c270698b49bfcf1 │ │ │ ├── stats_aggregator_error_1-4-d389db66cc7fd9b144445e364dac30e3 │ │ │ ├── stats_aggregator_error_1-5-63abf47101c5097e66a9c3ee92b128e3 │ │ │ ├── stats_aggregator_error_1-6-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_aggregator_error_1-7-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_aggregator_error_1-8-11f77597cc11fc71e95c0d0d7502c5c3 │ │ │ ├── stats_aggregator_error_1-9-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_empty_partition-0-42ae9007e347f7dedfc8974d21d84b41 │ │ │ ├── stats_empty_partition-1-418ec894d08c33fd712eb358f579b7a0 │ │ │ ├── stats_empty_partition-2-c14f09f88961dbad4d800317079a9105 │ │ │ ├── stats_empty_partition-3-868ba7a812c705caa29db49cdcb69c45 │ │ │ ├── stats_empty_partition-4-aed016ae4b528521874a719a5b129a55 │ │ │ ├── stats_publisher_error_1-0-836d3689af091fdebbdf31e6b29a423 │ │ │ ├── stats_publisher_error_1-1-36eee5cbac5c0c3228e499805b32f6 │ │ │ ├── stats_publisher_error_1-10-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_publisher_error_1-11-50519f196d320ee97be731907409fef9 │ │ │ ├── stats_publisher_error_1-12-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_publisher_error_1-13-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_publisher_error_1-14-f596f33c4a9271a406371baef799e52 │ │ │ ├── stats_publisher_error_1-15-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_publisher_error_1-16-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_publisher_error_1-2-2ca079278e0de95eecb5df315ce05c6 │ │ │ ├── stats_publisher_error_1-3-66e3e0c942759f679c270698b49bfcf1 │ │ │ ├── stats_publisher_error_1-4-d389db66cc7fd9b144445e364dac30e3 │ │ │ ├── stats_publisher_error_1-5-f39234f16f5819a2f51d3f200293332 │ │ │ ├── stats_publisher_error_1-6-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── stats_publisher_error_1-7-a31221a0c377c14e11b14484ddaa49a6 │ │ │ ├── stats_publisher_error_1-8-df9d7a7da57e4d207c0bcae2bfa4bf6b │ │ │ ├── stats_publisher_error_1-9-3b7c5bcb71c75e913caaea3acd48530c │ │ │ ├── string literal-0-ff43f1a7d06479b78622c8bb10e9f9a1 │ │ │ ├── subq2-0-279fb87476c70e9384874fa6bf77a380 │ │ │ ├── subq2-1-235919a7ddb574662158503b8052e7ca │ │ │ ├── subquery-alias.attr-0-fc8183d758151be72b3d75d9df124504 │ │ │ ├── subquery_exists-0-71049df380c600f02fb6c00d19999e8d │ │ │ ├── subquery_exists-1-57688cd1babd6a79bc3b2d2ec434b39 │ │ │ ├── subquery_exists-2-4c686f9b9cf51ae1b369acfa43d6c73f │ │ │ ├── subquery_exists-3-da5828589960a60826f5a08948850d78 │ │ │ ├── subquery_exists-4-2058d464561ef7b24d896ec8ecb21a00 │ │ │ ├── subquery_exists_having-0-927435f429722c2de003e376b9f0bbd2 │ │ │ ├── subquery_exists_having-1-b7ac11dbf892c229e180a2bc761117fe │ │ │ ├── subquery_exists_having-2-4f0b2dbae1324cdc5f3ead83b632e503 │ │ │ ├── subquery_exists_having-3-da5828589960a60826f5a08948850d78 │ │ │ ├── subquery_exists_having-4-fd5457ec549cc2265848f3c95a60693d │ │ │ ├── subquery_exists_having-5-aafe13388d5795b26035167edd90a69b │ │ │ ├── subquery_in-0-d3f50875bd5dff172cf813fdb7d738eb │ │ │ ├── subquery_in-1-dda16565b98926fc3587de937b9401c7 │ │ │ ├── subquery_in-10-3cd5ddc0f57e69745cbca1d5a8dd87c4 │ │ │ ├── subquery_in-11-21659892bff071ffb0dec9134dd465a8 │ │ │ ├── subquery_in-12-79fc971b8a399c25e1e2a1a30e08f336 │ │ │ ├── subquery_in-13-f17e8105a6efd193ef1065110d1145a6 │ │ │ ├── subquery_in-14-df6d4aad4f4c5d0675b1fbceac367fe2 │ │ │ ├── subquery_in-15-bacf85b0769b4030514a6f96c64d1ff7 │ │ │ ├── subquery_in-16-d51e0128520c31dbe041ffa4ae22dd4b │ │ │ ├── subquery_in-17-5f132cdb7fc12e6389d620472df5ba7f │ │ │ ├── subquery_in-18-f80281d529559f7f35ee5b42d53dd2ca │ │ │ ├── subquery_in-19-466013b596cc4160456daab670684af6 │ │ │ ├── subquery_in-2-374e39786feb745cd70f25be58bfa24 │ │ │ ├── subquery_in-3-42f922e862f882b9927abf566fe43050 │ │ │ ├── subquery_in-4-c76f8bd9221a571ffdbbaa248570d31d │ │ │ ├── subquery_in-5-3cec6e623c64903b3c6204d0548f543b │ │ │ ├── subquery_in-6-8b37b644ebdb9007c609043c6c855cb0 │ │ │ ├── subquery_in-7-208c9201161f60c2c7e521b0b33f0b19 │ │ │ ├── subquery_in-8-d7212bf1f2c9e019b7142314b823a979 │ │ │ ├── subquery_in-9-3d9f3ef5aa4fbb982a28109af8db9805 │ │ │ ├── subquery_in_having-0-dda16565b98926fc3587de937b9401c7 │ │ │ ├── subquery_in_having-1-374e39786feb745cd70f25be58bfa24 │ │ │ ├── subquery_in_having-10-b8ded52f10f8103684cda7bba20d2201 │ │ │ ├── subquery_in_having-11-ddeeedb49ded9eb733a4792fff83abe4 │ │ │ ├── subquery_in_having-2-877cbfc817ff3718f65073378a0c0829 │ │ │ ├── subquery_in_having-3-63a96439d273b9ad3304d3036bd79e35 │ │ │ ├── subquery_in_having-4-5d1259d48aa4b26931f1dbe686a0d2d7 │ │ │ ├── subquery_in_having-5-1beb605f3b9b0825c69dc5f52d085225 │ │ │ ├── subquery_in_having-6-9543704852a4d71a85b90b85a0c5c0a5 │ │ │ ├── subquery_in_having-7-6bba00f0273f13733fadbe10b43876f5 │ │ │ ├── subquery_in_having-8-662f1f7435da5d66fd4b09244387c06b │ │ │ ├── subquery_in_having-9-24ca942f094b14b92086305cc125e833 │ │ │ ├── subquery_notexists-0-75cd3855b33f05667ae76896f4b25d3d │ │ │ ├── subquery_notexists-1-4ae5bcc868eb27add076db2cb3ca9678 │ │ │ ├── subquery_notexists-2-73a67f6cae6d8e68efebdab4fbade162 │ │ │ ├── subquery_notexists-3-a8b49a691e12360c7c3fa5df113ba8cf │ │ │ ├── subquery_notexists_having-0-872612e3ae6ef1445982517a94200075 │ │ │ ├── subquery_notexists_having-1-8f6c09c8a89cc5939c1c309d660e7b3e │ │ │ ├── subquery_notexists_having-2-fb172ff54d6814f42360cb9f30f4882e │ │ │ ├── subquery_notexists_having-3-edd8e7bbc4bfde58cf744fc0901e2ac │ │ │ ├── subquery_notin_having-0-d3f50875bd5dff172cf813fdb7d738eb │ │ │ ├── subquery_notin_having-1-dda16565b98926fc3587de937b9401c7 │ │ │ ├── subquery_notin_having-2-374e39786feb745cd70f25be58bfa24 │ │ │ ├── subquery_notin_having-3-21a44539fd357dc260687003554fe02a │ │ │ ├── subquery_notin_having-4-dea2fabba75cc13e7fa8df072f6b557b │ │ │ ├── subquery_notin_having-5-341feddde788c15197d08d7969dafe19 │ │ │ ├── subquery_notin_having-6-7ed33e3bcdc0728a69995ef0b2fa54a5 │ │ │ ├── subquery_notin_having-7-44bdb73da0c1f4089b6edb43614e3e04 │ │ │ ├── table.attr-0-26c9d24eb6305ea2106c26bdca38012e │ │ │ ├── tablename_with_select-0-554898fe9d96fee7b652b8a771d66a25 │ │ │ ├── tablename_with_select-1-736d6a05e1fe3249a84eb58f7cd806d2 │ │ │ ├── tablename_with_select-2-58d48c815413287858e2cfa16e5c6a5d │ │ │ ├── tablename_with_select-3-35c08c648a66f09f2cf7cfa6019c2113 │ │ │ ├── test ambiguousReferences resolved as hive-0-c6d02549aec166e16bfc44d5905fa33a │ │ │ ├── test ambiguousReferences resolved as hive-1-a8987ff8c7b9ca95bf8b32314694ed1f │ │ │ ├── test ambiguousReferences resolved as hive-2-26f54240cf5b909086fc34a34d7fdb56 │ │ │ ├── test ambiguousReferences resolved as hive-3-d08d5280027adea681001ad82a5a6974 │ │ │ ├── test ambiguousReferences resolved as hive-4-22eb25b5be6daf72a6649adfe5041749 │ │ │ ├── timestamp cast #3-0-9f6fcc8c1a29c793c2238bad91453e9f │ │ │ ├── timestamp cast #4-0-e9286317470d42e9f8122bc98a2c1ce1 │ │ │ ├── timestamp_1-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── timestamp_1-1-d362501d0176855077e65f8faf067fa8 │ │ │ ├── timestamp_1-10-67f274bf16de625cf4e85af0c6185cac │ │ │ ├── timestamp_1-11-343c75daac6695917608c17db8bf473e │ │ │ ├── timestamp_1-12-cf19f7359a6d3456c4526b2c69f92d6a │ │ │ ├── timestamp_1-13-d242038c04dd4ee6075c7eebc0f75f17 │ │ │ ├── timestamp_1-14-90269c1e50c7ae8e75ca9cc297982135 │ │ │ ├── timestamp_1-15-e6bfca320c4ee3aff39cf2f179d57da6 │ │ │ ├── timestamp_1-16-d0291a9bd42054b2732cb4f54cf39ae7 │ │ │ ├── timestamp_1-17-e7b398d2a8107a42419c83771bda41e6 │ │ │ ├── timestamp_1-18-a3eeec08bccae78d0d94ad2cb923e1cf │ │ │ ├── timestamp_1-19-67f274bf16de625cf4e85af0c6185cac │ │ │ ├── timestamp_1-2-1d7cf3a2512fa1876b422b79bbe05426 │ │ │ ├── timestamp_1-20-343c75daac6695917608c17db8bf473e │ │ │ ├── timestamp_1-21-cf19f7359a6d3456c4526b2c69f92d6a │ │ │ ├── timestamp_1-22-cdb04b49b836e0244f6f0857aea7da8a │ │ │ ├── timestamp_1-23-90269c1e50c7ae8e75ca9cc297982135 │ │ │ ├── timestamp_1-24-e6bfca320c4ee3aff39cf2f179d57da6 │ │ │ ├── timestamp_1-25-d0291a9bd42054b2732cb4f54cf39ae7 │ │ │ ├── timestamp_1-26-e7b398d2a8107a42419c83771bda41e6 │ │ │ ├── timestamp_1-27-a3eeec08bccae78d0d94ad2cb923e1cf │ │ │ ├── timestamp_1-28-67f274bf16de625cf4e85af0c6185cac │ │ │ ├── timestamp_1-29-343c75daac6695917608c17db8bf473e │ │ │ ├── timestamp_1-3-74f477a8b726f5193dd42ef378a793c4 │ │ │ ├── timestamp_1-30-cf19f7359a6d3456c4526b2c69f92d6a │ │ │ ├── timestamp_1-31-9587976bd7e6caa5b667975c14e8dd53 │ │ │ ├── timestamp_1-32-90269c1e50c7ae8e75ca9cc297982135 │ │ │ ├── timestamp_1-33-e6bfca320c4ee3aff39cf2f179d57da6 │ │ │ ├── timestamp_1-34-d0291a9bd42054b2732cb4f54cf39ae7 │ │ │ ├── timestamp_1-35-e7b398d2a8107a42419c83771bda41e6 │ │ │ ├── timestamp_1-36-a3eeec08bccae78d0d94ad2cb923e1cf │ │ │ ├── timestamp_1-37-67f274bf16de625cf4e85af0c6185cac │ │ │ ├── timestamp_1-38-343c75daac6695917608c17db8bf473e │ │ │ ├── timestamp_1-39-cf19f7359a6d3456c4526b2c69f92d6a │ │ │ ├── timestamp_1-4-d833b177fac3162215468dde991f71d1 │ │ │ ├── timestamp_1-40-4ebcf4bcc059feba0fd9f76f26193f3b │ │ │ ├── timestamp_1-41-90269c1e50c7ae8e75ca9cc297982135 │ │ │ ├── timestamp_1-42-e6bfca320c4ee3aff39cf2f179d57da6 │ │ │ ├── timestamp_1-43-d0291a9bd42054b2732cb4f54cf39ae7 │ │ │ ├── timestamp_1-44-e7b398d2a8107a42419c83771bda41e6 │ │ │ ├── timestamp_1-45-a3eeec08bccae78d0d94ad2cb923e1cf │ │ │ ├── timestamp_1-46-67f274bf16de625cf4e85af0c6185cac │ │ │ ├── timestamp_1-47-343c75daac6695917608c17db8bf473e │ │ │ ├── timestamp_1-48-cf19f7359a6d3456c4526b2c69f92d6a │ │ │ ├── timestamp_1-49-7a59f9f939efc4b96f8159d00b39ed3 │ │ │ ├── timestamp_1-5-90269c1e50c7ae8e75ca9cc297982135 │ │ │ ├── timestamp_1-50-90269c1e50c7ae8e75ca9cc297982135 │ │ │ ├── timestamp_1-51-e6bfca320c4ee3aff39cf2f179d57da6 │ │ │ ├── timestamp_1-52-d0291a9bd42054b2732cb4f54cf39ae7 │ │ │ ├── timestamp_1-53-e7b398d2a8107a42419c83771bda41e6 │ │ │ ├── timestamp_1-54-a3eeec08bccae78d0d94ad2cb923e1cf │ │ │ ├── timestamp_1-55-67f274bf16de625cf4e85af0c6185cac │ │ │ ├── timestamp_1-56-343c75daac6695917608c17db8bf473e │ │ │ ├── timestamp_1-57-cf19f7359a6d3456c4526b2c69f92d6a │ │ │ ├── timestamp_1-58-d362501d0176855077e65f8faf067fa8 │ │ │ ├── timestamp_1-6-e6bfca320c4ee3aff39cf2f179d57da6 │ │ │ ├── timestamp_1-7-d0291a9bd42054b2732cb4f54cf39ae7 │ │ │ ├── timestamp_1-8-e7b398d2a8107a42419c83771bda41e6 │ │ │ ├── timestamp_1-9-a3eeec08bccae78d0d94ad2cb923e1cf │ │ │ ├── timestamp_2-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── timestamp_2-1-ea7192a4a5a985bcc8aab9aa79d9f028 │ │ │ ├── timestamp_2-10-252aebfe7882335d31bfc53a8705b7a │ │ │ ├── timestamp_2-11-5181279a0bf8939fe46ddacae015dad8 │ │ │ ├── timestamp_2-12-240fce5f58794fa051824e8732c00c03 │ │ │ ├── timestamp_2-13-5f450162886ccc79af149541527f5643 │ │ │ ├── timestamp_2-14-25f6ec69328af6cba76899194e0dd84e │ │ │ ├── timestamp_2-15-93c769be4cff93bea6e62bfe4e2a8742 │ │ │ ├── timestamp_2-16-5bdbf67419cc060b82d091d80ce59bf9 │ │ │ ├── timestamp_2-17-de3c42ab06c17ae895fd7deaf7bd9571 │ │ │ ├── timestamp_2-18-da3937d21b7c2cfe1e624e812ae1d3ef │ │ │ ├── timestamp_2-19-252aebfe7882335d31bfc53a8705b7a │ │ │ ├── timestamp_2-2-61dbdf6d26c2a3f1143f6fdae999b1b4 │ │ │ ├── timestamp_2-20-5181279a0bf8939fe46ddacae015dad8 │ │ │ ├── timestamp_2-21-240fce5f58794fa051824e8732c00c03 │ │ │ ├── timestamp_2-22-469fe94fb60f4b00809190c303434641 │ │ │ ├── timestamp_2-23-25f6ec69328af6cba76899194e0dd84e │ │ │ ├── timestamp_2-24-93c769be4cff93bea6e62bfe4e2a8742 │ │ │ ├── timestamp_2-25-5bdbf67419cc060b82d091d80ce59bf9 │ │ │ ├── timestamp_2-26-de3c42ab06c17ae895fd7deaf7bd9571 │ │ │ ├── timestamp_2-27-da3937d21b7c2cfe1e624e812ae1d3ef │ │ │ ├── timestamp_2-28-252aebfe7882335d31bfc53a8705b7a │ │ │ ├── timestamp_2-29-5181279a0bf8939fe46ddacae015dad8 │ │ │ ├── timestamp_2-3-a5092ff0f5a3d3b8f4171994932d4d19 │ │ │ ├── timestamp_2-30-240fce5f58794fa051824e8732c00c03 │ │ │ ├── timestamp_2-31-8f506498acf0c99c30960a00981ef460 │ │ │ ├── timestamp_2-32-25f6ec69328af6cba76899194e0dd84e │ │ │ ├── timestamp_2-33-93c769be4cff93bea6e62bfe4e2a8742 │ │ │ ├── timestamp_2-34-5bdbf67419cc060b82d091d80ce59bf9 │ │ │ ├── timestamp_2-35-de3c42ab06c17ae895fd7deaf7bd9571 │ │ │ ├── timestamp_2-36-da3937d21b7c2cfe1e624e812ae1d3ef │ │ │ ├── timestamp_2-37-252aebfe7882335d31bfc53a8705b7a │ │ │ ├── timestamp_2-38-5181279a0bf8939fe46ddacae015dad8 │ │ │ ├── timestamp_2-39-240fce5f58794fa051824e8732c00c03 │ │ │ ├── timestamp_2-4-81d6d29dcb3fd12a519426dff64411d2 │ │ │ ├── timestamp_2-40-972a007e54d1c09e9ac9549c19a32dbb │ │ │ ├── timestamp_2-41-25f6ec69328af6cba76899194e0dd84e │ │ │ ├── timestamp_2-42-93c769be4cff93bea6e62bfe4e2a8742 │ │ │ ├── timestamp_2-43-5bdbf67419cc060b82d091d80ce59bf9 │ │ │ ├── timestamp_2-44-de3c42ab06c17ae895fd7deaf7bd9571 │ │ │ ├── timestamp_2-45-da3937d21b7c2cfe1e624e812ae1d3ef │ │ │ ├── timestamp_2-46-252aebfe7882335d31bfc53a8705b7a │ │ │ ├── timestamp_2-47-5181279a0bf8939fe46ddacae015dad8 │ │ │ ├── timestamp_2-48-240fce5f58794fa051824e8732c00c03 │ │ │ ├── timestamp_2-49-650d2727b007638e0ed39b37c9498d66 │ │ │ ├── timestamp_2-5-25f6ec69328af6cba76899194e0dd84e │ │ │ ├── timestamp_2-50-25f6ec69328af6cba76899194e0dd84e │ │ │ ├── timestamp_2-51-93c769be4cff93bea6e62bfe4e2a8742 │ │ │ ├── timestamp_2-52-5bdbf67419cc060b82d091d80ce59bf9 │ │ │ ├── timestamp_2-53-de3c42ab06c17ae895fd7deaf7bd9571 │ │ │ ├── timestamp_2-54-da3937d21b7c2cfe1e624e812ae1d3ef │ │ │ ├── timestamp_2-55-252aebfe7882335d31bfc53a8705b7a │ │ │ ├── timestamp_2-56-5181279a0bf8939fe46ddacae015dad8 │ │ │ ├── timestamp_2-57-240fce5f58794fa051824e8732c00c03 │ │ │ ├── timestamp_2-58-ea7192a4a5a985bcc8aab9aa79d9f028 │ │ │ ├── timestamp_2-6-93c769be4cff93bea6e62bfe4e2a8742 │ │ │ ├── timestamp_2-7-5bdbf67419cc060b82d091d80ce59bf9 │ │ │ ├── timestamp_2-8-de3c42ab06c17ae895fd7deaf7bd9571 │ │ │ ├── timestamp_2-9-da3937d21b7c2cfe1e624e812ae1d3ef │ │ │ ├── timestamp_3-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── timestamp_3-1-165256158e3db1ce19c3c9db3c8011d2 │ │ │ ├── timestamp_3-10-ffc79abb874323e165963aa39f460a9b │ │ │ ├── timestamp_3-11-7b1ec929239ee305ea9da46ebb990c67 │ │ │ ├── timestamp_3-12-a63f40f6c4a022c16f8cf810e3b7ed2a │ │ │ ├── timestamp_3-13-7d225bcfa35f20da7dd63e7f8a413a77 │ │ │ ├── timestamp_3-14-165256158e3db1ce19c3c9db3c8011d2 │ │ │ ├── timestamp_3-2-81edf5107270547641586aa02b4e7d9b │ │ │ ├── timestamp_3-3-7a012a0d98729da25b5ac374855dcee4 │ │ │ ├── timestamp_3-4-86514381187b246a5685577c1968c559 │ │ │ ├── timestamp_3-5-935d0d2492beab99bbbba26ba62a1db4 │ │ │ ├── timestamp_3-6-8fe348d5d9b9903a26eda32d308b8e41 │ │ │ ├── timestamp_3-7-6be5fe01c502cd24db32a3781c97a703 │ │ │ ├── timestamp_3-8-6066ba0451cd0fcfac4bea6376e72add │ │ │ ├── timestamp_3-9-22e03daa775eab145d39ec0730953f7e │ │ │ ├── timestamp_comparison-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── timestamp_comparison-1-4b68f7ad0f8cf337e42bf16a45e15818 │ │ │ ├── timestamp_comparison-2-60557e7bd2822c89fa8b076a9d0520fc │ │ │ ├── timestamp_comparison-3-f96a9d88327951bd93f672dc2463ecd4 │ │ │ ├── timestamp_comparison-4-13e17ed811165196416f777cbc162592 │ │ │ ├── timestamp_comparison-5-4fa8a36edbefde4427c2ab2cf30e6399 │ │ │ ├── timestamp_comparison-6-7e4fb6e8ba01df422e4c67e06a0c8453 │ │ │ ├── timestamp_comparison-7-8c8e73673a950f6b3d960b08fcea076f │ │ │ ├── timestamp_comparison-8-510c0a2a57dc5df8588bd13c4152f8bc │ │ │ ├── timestamp_comparison-9-659d5b1ae8200f13f265270e52a3dd65 │ │ │ ├── timestamp_lazy-0-c0b1d928c9dea9b247ace0a056586594 │ │ │ ├── timestamp_lazy-1-d15685a0b8e8991b4f8d74568398bcdc │ │ │ ├── timestamp_lazy-2-bb5a4a13274290029bd07d95c2f92563 │ │ │ ├── timestamp_lazy-3-79e0c72c4fb3b259dfbffd245ccaa636 │ │ │ ├── timestamp_lazy-4-b4c4417ce9f08baeb82ffde6ef1baa25 │ │ │ ├── timestamp_null-0-3bd56783b637a47f6447d247024941a0 │ │ │ ├── timestamp_null-1-4b9c19c1f57557979d3483d548f762cb │ │ │ ├── timestamp_null-2-51762cf5079877abf7d81127738f4e5 │ │ │ ├── timestamp_null-3-222c5ea127c747c71738b5dc5b80459c │ │ │ ├── timestamp_null-4-ffc86f5c714eceabc36e92931b96beb0 │ │ │ ├── timestamp_udf-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── timestamp_udf-1-79914c5347620c6e62a8e0b9a95984af │ │ │ ├── timestamp_udf-10-287614364eaa3fb82aad08c6b62cc938 │ │ │ ├── timestamp_udf-11-dbc23736a61d9482d13cacada02a7a09 │ │ │ ├── timestamp_udf-12-442cf850a0cc1f1dcfdeaeffbffb2c35 │ │ │ ├── timestamp_udf-13-51959036fd4ac4f1e24f4e06eb9b0b6 │ │ │ ├── timestamp_udf-14-6ab3f356deaf807e8accc37e1f4849a │ │ │ ├── timestamp_udf-15-c745a1016461403526d44928a269c1de │ │ │ ├── timestamp_udf-16-7ab76c4458c7f78038c8b1df0fdeafbe │ │ │ ├── timestamp_udf-17-b36e87e17ca24d82072220bff559c718 │ │ │ ├── timestamp_udf-18-dad44d2d4a421286e9da080271bd2639 │ │ │ ├── timestamp_udf-19-cb033ecad964a2623bc633ac1d3f752a │ │ │ ├── timestamp_udf-2-59fc1842a23369235d42ed040d45fb3d │ │ │ ├── timestamp_udf-20-79914c5347620c6e62a8e0b9a95984af │ │ │ ├── timestamp_udf-21-59fc1842a23369235d42ed040d45fb3d │ │ │ ├── timestamp_udf-3-9039f474f9a96e9f15ace528faeed923 │ │ │ ├── timestamp_udf-4-b0fd4ca3b22eb732a32772399331352f │ │ │ ├── timestamp_udf-5-66868a2b075de978784011e9955483d │ │ │ ├── timestamp_udf-6-1124399033bcadf3874fb48f593392d │ │ │ ├── timestamp_udf-7-5810193ce35d38c23f4fc4b4979d60a4 │ │ │ ├── timestamp_udf-8-250e640a6a818f989f3f3280b00f64f9 │ │ │ ├── timestamp_udf-9-975df43df015d86422965af456f87a94 │ │ │ ├── touch-0-cd46bc635e3010cf1b990a652a584a09 │ │ │ ├── touch-1-27ad2962fed131f51ba802596ba37278 │ │ │ ├── touch-10-27ad2962fed131f51ba802596ba37278 │ │ │ ├── touch-2-3e95421993ab28d18245ec2340f580a3 │ │ │ ├── touch-3-c0c18ac884677231a41eea8d980d0451 │ │ │ ├── touch-4-c06da7f8c1e98dc22e3171018e357f6a │ │ │ ├── touch-5-af459a0264559a2aeaa1341ce779ab3c │ │ │ ├── touch-6-5c7b24abea435f2628fe618f3a82e115 │ │ │ ├── touch-7-3752320b12abae0d138148d56a27c5b1 │ │ │ ├── touch-8-3562ab40242756452595cd7eae79b0ce │ │ │ ├── touch-9-cd46bc635e3010cf1b990a652a584a09 │ │ │ ├── transform with SerDe-0-cdc393f3914c879787efe523f692b1e0 │ │ │ ├── transform with SerDe3-0-58a8b7eb07a949bc44dccb723222957f │ │ │ ├── transform with SerDe4-0-ba9ad2499a7408cb350c7abafaf9ea97 │ │ │ ├── transform with custom field delimiter-0-703cca3c02ced422feb11dc13b744484 │ │ │ ├── transform with custom field delimiter-0-82639dda9ba42df817466dffe2929174 │ │ │ ├── transform with custom field delimiter2-0-e8713b21483e1efb78ee90b61530479b │ │ │ ├── transform with custom field delimiter2-0-e8d2b2e60551f69bfb44e555f5cff064 │ │ │ ├── transform with custom field delimiter3-0-d4f4f471819345e9ce1964e281ea5289 │ │ │ ├── transform-0-d81d055660f6ef3d9cc60dd673a8c0fe │ │ │ ├── transform_ppr1-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── transform_ppr1-1-65fe307c21b350846b3c496890b0b619 │ │ │ ├── transform_ppr1-2-8de14457978564d5fe4ab9a1c2a87d47 │ │ │ ├── transform_ppr2-0-ae225e86c2ae20519ffdf23190454161 │ │ │ ├── transform_ppr2-1-6133f48deec4cdf525b8c1574e7247d1 │ │ │ ├── transform_ppr2-2-636c4938673a273299c8569295d27c99 │ │ │ ├── trivial join ON clause-0-3b6afcbd622aa111ee260bebc763613d │ │ │ ├── trivial join where clause-0-25ffeb9d5e570c8b62b6ae2829655fe3 │ │ │ ├── truncate_column-0-616cad77ad5e7ac74da0d7425a7869a │ │ │ ├── truncate_column-1-418ec894d08c33fd712eb358f579b7a0 │ │ │ ├── truncate_column_merge-0-46e8cc1556fa8586802a26267a906acf │ │ │ ├── truncate_table-0-d16efe9bac079f0c5fc6cc424a8fa3eb │ │ │ ├── truncate_table-1-7fc255c86d7c3a9ff088f9eb29a42565 │ │ │ ├── truncate_table-1-ec0e3744208003f18c33a1f2c4c1e2c6 │ │ │ ├── truncate_table-10-9ba46fdca3f0f4da8991cb5c7b01efdb │ │ │ ├── truncate_table-10-c32b771845f4d5a0330e2cfa09f89a7f │ │ │ ├── truncate_table-11-6e0b877ea24fa88c5461b02f7bda0746 │ │ │ ├── truncate_table-12-7dee32ebe9887833a9ae2ea6e5568028 │ │ │ ├── truncate_table-13-3230cfbe1871330193c3190c77582fe │ │ │ ├── truncate_table-14-ae23925663d7e9b7e97c42b66086d835 │ │ │ ├── truncate_table-15-7850dc059f9d00eb9439d477e92cb913 │ │ │ ├── truncate_table-16-623e41aa678d5abc8341a8cee0ac8f94 │ │ │ ├── truncate_table-17-8c71d29e7db6a8d1cb5746458c7741e6 │ │ │ ├── truncate_table-18-64d431f93d8a44fb143cb4b87d63a105 │ │ │ ├── truncate_table-19-1325d566d66f21a06543271c73a95a6f │ │ │ ├── truncate_table-2-fc4118284bf8301cf0d1056c388f963a │ │ │ ├── truncate_table-20-91f869cc79191b87d31cfd0eca2839f4 │ │ │ ├── truncate_table-21-f635675d59df31843e7be41af7b9e4fa │ │ │ ├── truncate_table-22-f121fdc101603a8220c0f18e867f581e │ │ │ ├── truncate_table-23-63988ac685a3bd645787116353f024d2 │ │ │ ├── truncate_table-3-ecca1d24f36175932911a6e7a78ece2d │ │ │ ├── truncate_table-4-88e636ed8bdf647a02ff269aa3ebfe62 │ │ │ ├── truncate_table-5-42aeecc67917d731e60fc46bde021d49 │ │ │ ├── truncate_table-6-5a6776344f711298f27a8f1d3b47d107 │ │ │ ├── truncate_table-7-1ad5d350714e3d4ea17201153772d58d │ │ │ ├── truncate_table-7-65e270fb0b61886aa85255d77eb65794 │ │ │ ├── truncate_table-8-76c754eac44c7254b45807255d4dbc3a │ │ │ ├── truncate_table-8-e7699db3640f3b9b1fe44d6b8c9b507e │ │ │ ├── truncate_table-9-eedfbb9479ac6c1b955b8e9b41994da4 │ │ │ ├── truncate_table-9-f4286b5657674a6a6b6bc6680f72f89a │ │ │ ├── type_cast_1-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── type_cast_1-1-60ea21e6e7d054a65f959fc89acf1b3d │ │ │ ├── type_cast_1-2-53a667981ad567b2ab977f67d65c5825 │ │ │ ├── type_widening-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── type_widening-1-630ac2c7e7dea4837384ccd572209229 │ │ │ ├── type_widening-2-cfbdf2b6fca84c6e23d4e691d2221bd6 │ │ │ ├── type_widening-3-a0ba6952d9bf830d1d1ea7aebd3784a2 │ │ │ ├── type_widening-4-65da8c67f6903286168acb39ac67fc04 │ │ │ ├── udaf_collect_set-0-38512a3299e2390dd813e61a0f63f35e │ │ │ ├── udaf_collect_set-1-78aa199d061d2ff9ba426849ea1eb449 │ │ │ ├── udaf_collect_set-10-c8bc33095e1a195bb7b5e579d8d78db │ │ │ ├── udaf_collect_set-11-5c3768074977ef68a1b9bb72eb9ef02 │ │ │ ├── udaf_collect_set-12-1d351f7e821fcaf66c6f7503e42fb291 │ │ │ ├── udaf_collect_set-13-a00d1791b7fa7ac5a0505d95c3d12257 │ │ │ ├── udaf_collect_set-14-c8bc33095e1a195bb7b5e579d8d78db │ │ │ ├── udaf_collect_set-15-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── udaf_collect_set-16-a00d1791b7fa7ac5a0505d95c3d12257 │ │ │ ├── udaf_collect_set-17-c8bc33095e1a195bb7b5e579d8d78db │ │ │ ├── udaf_collect_set-2-4747c35670a011344982573ba31a9bb │ │ │ ├── udaf_collect_set-3-9aa348a25ca17ab5b636d3ea2d6df986 │ │ │ ├── udaf_collect_set-4-1d351f7e821fcaf66c6f7503e42fb291 │ │ │ ├── udaf_collect_set-5-a7dc16cb82c595b18d4258a38a304b1e │ │ │ ├── udaf_collect_set-6-c8bc33095e1a195bb7b5e579d8d78db │ │ │ ├── udaf_collect_set-7-1fd4f3dcdac818ccc95c5033c6d01b56 │ │ │ ├── udaf_collect_set-8-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── udaf_collect_set-9-a7dc16cb82c595b18d4258a38a304b1e │ │ │ ├── udaf_corr-0-2f783a39471a7f1df9a824d741c443a9 │ │ │ ├── udaf_corr-1-930b47e12b5ea559387ec5c6e8d5d9b5 │ │ │ ├── udaf_corr-10-2f783a39471a7f1df9a824d741c443a9 │ │ │ ├── udaf_corr-2-e886f45c8f085596ffd420f89cdc2909 │ │ │ ├── udaf_corr-3-ddf417dbc3b551cc8df47d950cec03e │ │ │ ├── udaf_corr-4-8771b2d83d14b3b641e8a77fcdc5081a │ │ │ ├── udaf_corr-5-8abbd73784728b599f8c2a90f53da9fb │ │ │ ├── udaf_corr-6-4324e1f0a83a7491f3d4e3eef34f8727 │ │ │ ├── udaf_corr-7-70e701f50c3418ff91649b2bd8287da3 │ │ │ ├── udaf_corr-8-f2f0c7735f8b24266d5aaff96644e369 │ │ │ ├── udaf_corr-9-e2a0fa75c43279764ebca015f62bcf16 │ │ │ ├── udaf_covar_pop-0-2f783a39471a7f1df9a824d741c443a9 │ │ │ ├── udaf_covar_pop-1-930b47e12b5ea559387ec5c6e8d5d9b5 │ │ │ ├── udaf_covar_pop-10-2f783a39471a7f1df9a824d741c443a9 │ │ │ ├── udaf_covar_pop-2-e886f45c8f085596ffd420f89cdc2909 │ │ │ ├── udaf_covar_pop-3-fe27ea6dae14250e8835baef3c2e20f6 │ │ │ ├── udaf_covar_pop-4-7af9231ae293d0c4b84050176e1d73ad │ │ │ ├── udaf_covar_pop-5-22004d36f6f3770db284644317770fcd │ │ │ ├── udaf_covar_pop-6-bc03cfbf7ae382ce707bf83e7fb2fb8b │ │ │ ├── udaf_covar_pop-7-37e59e993e08216e6c69f88d6ac673ae │ │ │ ├── udaf_covar_pop-8-1e51388408dad651127edf940c11d91f │ │ │ ├── udaf_covar_pop-9-b3cc8c5b5b384622e212dbaaf3f09623 │ │ │ ├── udaf_covar_samp-0-2f783a39471a7f1df9a824d741c443a9 │ │ │ ├── udaf_covar_samp-1-930b47e12b5ea559387ec5c6e8d5d9b5 │ │ │ ├── udaf_covar_samp-10-2f783a39471a7f1df9a824d741c443a9 │ │ │ ├── udaf_covar_samp-2-e886f45c8f085596ffd420f89cdc2909 │ │ │ ├── udaf_covar_samp-3-7aa25da7ccb88ba67b100888b6227aaf │ │ │ ├── udaf_covar_samp-4-7e705a637950911e0a18059d8bf1fd2c │ │ │ ├── udaf_covar_samp-5-2cfd48c62fcfb58936ea1222ecf6a2b │ │ │ ├── udaf_covar_samp-6-8a701e7f4b9ce986f7923ae083bce0f1 │ │ │ ├── udaf_covar_samp-7-2702986700ff9a1c962f8b3762c1b5f3 │ │ │ ├── udaf_covar_samp-8-44861ae58cf0951eeda28a5f778f778a │ │ │ ├── udaf_covar_samp-9-234a5b02085d2228473d7ef15a6af683 │ │ │ ├── udaf_histogram_numeric-0-86b9fb8bef8a5c51077623f1db3a0251 │ │ │ ├── udaf_histogram_numeric-1-5303011455a61171f7eb7eb4bd0ca2a3 │ │ │ ├── udaf_histogram_numeric-2-b3b431c36154a1ae022bf01d55a6ecb1 │ │ │ ├── udaf_histogram_numeric-3-ff41f4450d6ae372633fde865ae187c6 │ │ │ ├── udf2-0-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── udf2-1-f60851dc36f579e83d6848d7d3c589e6 │ │ │ ├── udf2-2-31c8af064bac42541558a95fad3bca97 │ │ │ ├── udf2-3-c5938fcdd5675b58a4ed54269b5f5591 │ │ │ ├── udf5-0-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── udf5-1-f60851dc36f579e83d6848d7d3c589e6 │ │ │ ├── udf5-2-e08fad5ccbf165f44ecabb9356e58b24 │ │ │ ├── udf5-3-d23017942dc49be9f5a61430201371bf │ │ │ ├── udf5-4-1b35f4ee3febf99804db1f481af80b23 │ │ │ ├── udf5-5-2125da6f09799cf7f10b838fc8f24e71 │ │ │ ├── udf6-0-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── udf6-1-f60851dc36f579e83d6848d7d3c589e6 │ │ │ ├── udf6-2-4d2a0815afe8c050cabf7a2efbce8521 │ │ │ ├── udf6-3-e579646b969eef49b09656114da52a73 │ │ │ ├── udf6-4-29f45ffe530dd8c27dfb82268017dbb2 │ │ │ ├── udf6-5-fe336cd9850d6357980bd19139f76e │ │ │ ├── udf7-0-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── udf7-1-f60851dc36f579e83d6848d7d3c589e6 │ │ │ ├── udf7-2-645d8fe7ab47806e0427c3deeedb5ec6 │ │ │ ├── udf7-3-b3afef6eb68f8e29e31d6bb6a7903045 │ │ │ ├── udf8-0-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── udf8-1-63c38297946a2060c0cff4a426b0520c │ │ │ ├── udf8-2-700c31cc5099ea2c3bbb9fbf5c43a32 │ │ │ ├── udf8-3-72c1a1dd1627491550f6e19581a654cb │ │ │ ├── udf8-4-9f22d5a65353432826a526b1d76eb65b │ │ │ ├── udf9-0-a05de5714d8ccb2ac31dfe4f178fd358 │ │ │ ├── udf9-1-dd0981dc44ac24d445af5412e9f7fa8c │ │ │ ├── udf_10_trims-0-2a18d9570d9b676e240cda76df818c42 │ │ │ ├── udf_10_trims-1-4534b1b2e9101058e8d71756bcb416e │ │ │ ├── udf_10_trims-2-7624a192247c9c4c7be6a40d46f13597 │ │ │ ├── udf_E-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_E-1-cad0779d18f326c8e453bf2b5fe43596 │ │ │ ├── udf_E-2-d0fd9aa04fdeb948bdcf8559f7095c02 │ │ │ ├── udf_E-3-72bb4231ea2a877b4d93a53cd7b6b82a │ │ │ ├── udf_E-4-e8924af3bf99d2e01546a965303ffd09 │ │ │ ├── udf_E-5-9d54c12bf727e05e9f9d67c61402a1d4 │ │ │ ├── udf_E-6-d0fd9aa04fdeb948bdcf8559f7095c02 │ │ │ ├── udf_E-7-72bb4231ea2a877b4d93a53cd7b6b82a │ │ │ ├── udf_E-8-e8924af3bf99d2e01546a965303ffd09 │ │ │ ├── udf_PI-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_PI-1-13fd9345fd15b654d18b2707e5274b2b │ │ │ ├── udf_PI-2-97a12f6967726e425469ecfa70177ff0 │ │ │ ├── udf_PI-3-9c1476a2eab7455594e97b338ee3c188 │ │ │ ├── udf_PI-4-890f3c276eff2c459d8dc79d5a71c866 │ │ │ ├── udf_PI-5-cd1c31c39277a02bab8e44f8c29a6c2d │ │ │ ├── udf_PI-6-97a12f6967726e425469ecfa70177ff0 │ │ │ ├── udf_PI-7-9c1476a2eab7455594e97b338ee3c188 │ │ │ ├── udf_PI-8-890f3c276eff2c459d8dc79d5a71c866 │ │ │ ├── udf_abs-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_abs-1-6fe2e69c338fc823d3f61c9236eb2234 │ │ │ ├── udf_abs-2-eeb77ae8a0dcebbc0991923ca0932072 │ │ │ ├── udf_abs-3-50cb3c23902cd29e0dbff188c71062e5 │ │ │ ├── udf_abs-4-4ae7f62f8d996f0066037cecbf2e01c4 │ │ │ ├── udf_abs-5-5cd4c198e0de884ad436864b95fece6c │ │ │ ├── udf_abs-6-7aa32a019499c6464aded2e357c6843b │ │ │ ├── udf_acos-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_acos-1-4f49cb5a5c87efea534d63ed76435f06 │ │ │ ├── udf_acos-2-d330511cf4f626cd844b18f57f99a85f │ │ │ ├── udf_acos-3-661a0a85283df2a5c1567d60850e362b │ │ │ ├── udf_acos-4-23d588eece08fbea7431044524f1cecf │ │ │ ├── udf_acos-5-578612589fdb1ae21ee488924848fb4e │ │ │ ├── udf_acos-6-4d2bd33cee047e9a8bb740760c7cc3b4 │ │ │ ├── udf_add-0-5db764318a918a5f6d7c1d95d9e86045 │ │ │ ├── udf_add-1-400b238f4e6cdf7120be566b0ef079c5 │ │ │ ├── udf_array-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_array-1-2e9c2a7d9325bd9a53cf9f181b6333ee │ │ │ ├── udf_array-2-570741914bb78300b0233e5f38d7f08a │ │ │ ├── udf_array-3-47818d42e5e7667d8754c3f9a4b8053a │ │ │ ├── udf_array-4-51410e4d4d679fe5a8dd7a860f4efc47 │ │ │ ├── udf_array_contains-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_array_contains-1-d9a90108b052b111e8de4433e008b25a │ │ │ ├── udf_array_contains-2-eff16c7836252e01f3d8190cd833f79c │ │ │ ├── udf_array_contains-3-6b700cb69af298aef45b96bf5ac862d │ │ │ ├── udf_array_contains-4-bdb5a7e0ab81172a438145a1c406b1e8 │ │ │ ├── udf_ascii-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_ascii-1-72924c23459330cca6a54c70b12a542c │ │ │ ├── udf_ascii-2-dab8656d7f001e85615442d60df4b6b3 │ │ │ ├── udf_ascii-3-fc25cec86e0dafaf1633c2e3a6d2fc34 │ │ │ ├── udf_ascii-4-db9a06881a216f0252fa786d98c9bf │ │ │ ├── udf_asin-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_asin-1-99da197a53767060e3fa0250254d59cd │ │ │ ├── udf_asin-2-3d0c3fa6121f8f5158d221074f1d4129 │ │ │ ├── udf_asin-3-4b7ee6310a49ebf784a4a712748348ac │ │ │ ├── udf_asin-4-a3edf78ff8ccc629ee7d7518707b69ce │ │ │ ├── udf_asin-5-8dcbcf784496053e3b57c579aca809a6 │ │ │ ├── udf_asin-6-114c8141f1e831c70d70c570f0ae778f │ │ │ ├── udf_atan-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_atan-1-c79ed30c2444c8493d0db98c33c9132b │ │ │ ├── udf_atan-2-77e7ac1b89a4eac9102176cd73f67a62 │ │ │ ├── udf_atan-3-e6f97a834028a67e6c3033949f98fbf8 │ │ │ ├── udf_atan-4-eacd47571ba5c67f11e025d8d4de5811 │ │ │ ├── udf_atan-5-c79ed30c2444c8493d0db98c33c9132b │ │ │ ├── udf_atan-6-77e7ac1b89a4eac9102176cd73f67a62 │ │ │ ├── udf_atan-7-e6f97a834028a67e6c3033949f98fbf8 │ │ │ ├── udf_atan-8-eacd47571ba5c67f11e025d8d4de5811 │ │ │ ├── udf_avg-0-2d715528b290951fb9874f60d7e9b537 │ │ │ ├── udf_avg-1-c707c56871a903e4e022b3df5c92fc3f │ │ │ ├── udf_bigint-0-6c5b1e4b9d725caeb786bb18448a7927 │ │ │ ├── udf_bigint-1-4636e4f0083ea54814995a03b7c81202 │ │ │ ├── udf_bin-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_bin-1-ebbb090f6fa6b322a52bec3ba19dfe5b │ │ │ ├── udf_bin-2-843803a1b6ada107c11397af1a2f55d6 │ │ │ ├── udf_bin-3-6fda27c8567ac896538cba3f2b230ab │ │ │ ├── udf_bin-4-b9bac215e81c8d5c8324b1287542ced3 │ │ │ ├── udf_bitmap_and-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_bitmap_and-1-c9e0d8424ec5f433565397b113ae4f57 │ │ │ ├── udf_bitmap_and-2-5a60dfc80bef392fa390adddab0c0f87 │ │ │ ├── udf_bitmap_and-3-d550d017f9eb9176593719ea34eaae9b │ │ │ ├── udf_bitmap_and-4-a486db1f5a06f9623a0e5abd7737b0c6 │ │ │ ├── udf_bitmap_and-5-549dbeb1293c4c49ae08bf08acdbdf23 │ │ │ ├── udf_bitmap_and-6-ff2860a163cbe78d5affac8047199296 │ │ │ ├── udf_bitmap_and-7-d550d017f9eb9176593719ea34eaae9b │ │ │ ├── udf_bitmap_empty-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_bitmap_empty-1-a174269b5d1757398ab7f89cf1c97bfa │ │ │ ├── udf_bitmap_empty-2-f5d9880a3278b5632b356bbe6ecd90d3 │ │ │ ├── udf_bitmap_or-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_bitmap_or-1-cd510a5926df24d1ddbf8d0cce9d76ef │ │ │ ├── udf_bitmap_or-2-ab062e08acfd7e552a64ea967a0360c8 │ │ │ ├── udf_bitmap_or-3-d550d017f9eb9176593719ea34eaae9b │ │ │ ├── udf_bitmap_or-4-a486db1f5a06f9623a0e5abd7737b0c6 │ │ │ ├── udf_bitmap_or-5-549dbeb1293c4c49ae08bf08acdbdf23 │ │ │ ├── udf_bitmap_or-6-ea92fff4d814552b57535ed342a5dde0 │ │ │ ├── udf_bitmap_or-7-d550d017f9eb9176593719ea34eaae9b │ │ │ ├── udf_bitwise_and-0-e2374700cd32add926992d5539bd463a │ │ │ ├── udf_bitwise_and-1-2e63ac31262106160ab043027e356a4b │ │ │ ├── udf_bitwise_not-0-34abab2f47f90f0f194ef44aed1cdd7f │ │ │ ├── udf_bitwise_not-1-ccc0c59ea3e29b6d55e1edee7029155d │ │ │ ├── udf_bitwise_or-0-bf5bd0beebdd89b3fbbbbb8195a9bbe6 │ │ │ ├── udf_bitwise_or-1-272722c23fece2807c08191d3969c3bb │ │ │ ├── udf_bitwise_xor-0-6b05142d0b7e444a3e52a11b59d60a16 │ │ │ ├── udf_bitwise_xor-1-8fc9b9bf1aced42754419310784e0a9f │ │ │ ├── udf_boolean-0-a68fc036f5f5b7f9c85d71bb9627c749 │ │ │ ├── udf_boolean-1-23178b473a9d25d6be0abe378d44fb0e │ │ │ ├── udf_case-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_case-1-5bcbe4c0e0a75462160814a10b9449f4 │ │ │ ├── udf_case-2-54acf006155d8822a50e47729be24004 │ │ │ ├── udf_case-3-48789112d79aeb450d9f49184fc20e1c │ │ │ ├── udf_case-4-d39ed6ecd256fa99657f13709cb1c6e3 │ │ │ ├── udf_case-5-f53c9bb8a2d20ef7ff1fc7b3403270eb │ │ │ ├── udf_case-6-ff583116ba2edd78202349faf1e757dc │ │ │ ├── udf_ceil-0-4b40e67b8ca75729ab07df966d814e06 │ │ │ ├── udf_ceil-1-f410065d893a263f375fcf74072877bb │ │ │ ├── udf_ceiling-0-d5685e38400e68341e36a59671dcbdfd │ │ │ ├── udf_ceiling-1-69b4ba577d2f0f18befdaa1ee7a858df │ │ │ ├── udf_concat-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_concat-1-7bc53505a4e6587132870d8d0a704d2 │ │ │ ├── udf_concat-2-765c520f239cdff1ea3f8d22ba83e031 │ │ │ ├── udf_concat-3-a38183c2685e912befe6246f1b6f93b8 │ │ │ ├── udf_concat-4-a20ebbc181e5ee4a1c22ddafd212ddde │ │ │ ├── udf_concat_insert1-0-13ab74a58da514fe01dbeda0c3e79883 │ │ │ ├── udf_concat_insert1-1-ed0d453b9879faed8bf93913f7690545 │ │ │ ├── udf_concat_insert1-2-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── udf_concat_insert2-0-659e06570690cceeb3f37e10e855d2ea │ │ │ ├── udf_concat_insert2-1-39829ebc03d9e047f3eaac80b4428768 │ │ │ ├── udf_concat_insert2-2-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── udf_concat_ws-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_concat_ws-1-4c8bd7794a527e544c838408313eeaa8 │ │ │ ├── udf_concat_ws-2-b8b80f7e9bf4348367444c73020b3cab │ │ │ ├── udf_concat_ws-3-ce7c8205cdc107e1fb865d7d48b84a3c │ │ │ ├── udf_concat_ws-4-b13a1f7f63d2a54efa331c82bd635d63 │ │ │ ├── udf_concat_ws-5-a507af4996b13433b0ae100fcb32358f │ │ │ ├── udf_concat_ws-6-ca4f051369183cae36fc9a7bec6a9341 │ │ │ ├── udf_concat_ws-7-97071809ba7701b78e3729996f14b591 │ │ │ ├── udf_concat_ws-8-3bfc563ebf7e2cdb811766a54d84f224 │ │ │ ├── udf_concat_ws-9-8f60d81b410f4825809aa510806f2df2 │ │ │ ├── udf_conv-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_conv-1-d552befca345f3396464529cfde9f75a │ │ │ ├── udf_conv-10-f9ea15984e84250494e81e25d6a401c0 │ │ │ ├── udf_conv-11-2ce9111b47ed100bebc8d08de54efd1f │ │ │ ├── udf_conv-2-5e5904af10b5d23f20ae28dc4b9a49ab │ │ │ ├── udf_conv-3-5f43d0bec0421c86c49e2546c5ee923a │ │ │ ├── udf_conv-4-5df8d45902a3537e67545e629a96328a │ │ │ ├── udf_conv-5-8cdbb45b8c44fa97456da5bc4a43f459 │ │ │ ├── udf_conv-6-e5430adfa782ea9094e570d339626c0f │ │ │ ├── udf_conv-7-687f9b8a09f458d771d5641eec40031b │ │ │ ├── udf_conv-8-384902bf8d45b6b56b2bdc5db550c10 │ │ │ ├── udf_conv-9-28b833d0cd96f74c23aa7cf8c4f5a167 │ │ │ ├── udf_cos-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_cos-1-44f411146a7190b89f2bc8b4aa61cae3 │ │ │ ├── udf_cos-2-176030bdf43ff83ed8b3112d0c79f2f5 │ │ │ ├── udf_cos-3-166acc86afd6ececfe43800e38f106c9 │ │ │ ├── udf_cos-4-efda2f85872c6144280970eab84ef4d4 │ │ │ ├── udf_count-0-534a9b25b87d09e418645b1216949560 │ │ │ ├── udf_count-1-d566feb21bc894b97e6416b65fe5c02f │ │ │ ├── udf_count-10-455b30e7df33c5eebcaacabe0a578483 │ │ │ ├── udf_count-11-3b201ca546a8b0b5e5afaa1ff6aaee3e │ │ │ ├── udf_count-12-9f41ac3eb9a6e77b3d612afc2f2b8e0e │ │ │ ├── udf_count-13-9286bc5f08bf4db183719b1b49dc5b7 │ │ │ ├── udf_count-2-3344645abe535426307b9327b381fc85 │ │ │ ├── udf_count-3-e43165f41597d2a1c9e8cf780b99a4a8 │ │ │ ├── udf_count-4-93223bab63eada6ece8bc176e89c87a8 │ │ │ ├── udf_count-5-bdee61c35a27bfab974e2ba199d5dfa4 │ │ │ ├── udf_count-6-f8bcbbf6a5b8eb9b6d79c77264faa241 │ │ │ ├── udf_count-7-b975ad0d5f293508ce4832a7b19399b6 │ │ │ ├── udf_count-8-911e83c85155e1f811ba2c75aabbc6b7 │ │ │ ├── udf_count-9-75b3d8a0dac332ea00af5ef8971ca643 │ │ │ ├── udf_date_add-0-74d34471bfa0880230d8e3351eb0ab45 │ │ │ ├── udf_date_add-1-efb60fcbd6d78ad35257fb1ec39ace2 │ │ │ ├── udf_date_sub-0-f8fbf85026da1b0778fd325d9b5dae33 │ │ │ ├── udf_date_sub-1-7efeb74367835ade71e5e42b22f8ced4 │ │ │ ├── udf_datediff-0-3bd040a96a4568e7ea4922faa408ada5 │ │ │ ├── udf_datediff-1-34ae7a68b13c2bc9a89f61acf2edd4c5 │ │ │ ├── udf_day-0-c4c503756384ff1220222d84fd25e756 │ │ │ ├── udf_day-1-87168babe1110fe4c38269843414ca4 │ │ │ ├── udf_dayofmonth-0-7b2caf942528656555cf19c261a18502 │ │ │ ├── udf_dayofmonth-1-ca24d07102ad264d79ff30c64a73a7e8 │ │ │ ├── udf_degrees-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_degrees-1-f24ce67606944e23a4adc79f91cf0c17 │ │ │ ├── udf_degrees-2-aaee5dd4e87eaae3e65a585e07f1a3e4 │ │ │ ├── udf_degrees-3-2fd3a55901fe765f8f154531a7f5fd6b │ │ │ ├── udf_degrees-4-42f653c3c3cc3c94bb9ab9c5a4d1ca96 │ │ │ ├── udf_degrees-5-3a6468b02be2605c91b31987e76fb9a8 │ │ │ ├── udf_degrees-6-aaee5dd4e87eaae3e65a585e07f1a3e4 │ │ │ ├── udf_degrees-7-2fd3a55901fe765f8f154531a7f5fd6b │ │ │ ├── udf_degrees-8-42f653c3c3cc3c94bb9ab9c5a4d1ca96 │ │ │ ├── udf_div-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_div-1-31d31c7d5c544327dabfd874c88314db │ │ │ ├── udf_div-2-f23a07b1c6b1a98b303863188c10a8d8 │ │ │ ├── udf_div-3-5111340caad64e36370d9d4bc4db5f27 │ │ │ ├── udf_double-0-aa32d73a99587cae2f1efd9a2094d617 │ │ │ ├── udf_double-1-79380157cbd6624d760335f8291e6fb4 │ │ │ ├── udf_elt-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_elt-1-b46b060da76d1772db998c26a62a608f │ │ │ ├── udf_elt-2-e9f1bf17ad2a6f7bf3e40798ceebdbf4 │ │ │ ├── udf_elt-3-c2554fac72a2a51bb33faae16aec3507 │ │ │ ├── udf_elt-4-533ad9c703c320a6556c09dd5f9ac351 │ │ │ ├── udf_equal-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_equal-1-36b6cdf7c5f68c91155569b1622f5876 │ │ │ ├── udf_equal-2-2422b50b96502dde8b661acdfebd8892 │ │ │ ├── udf_equal-3-e0faab0f5e736c24bcc5503aeac55053 │ │ │ ├── udf_equal-4-39d8d6f197803de927f0af5409ec2f33 │ │ │ ├── udf_equal-5-ee018fc3267dbdd55b60ed4e6f56c9ca │ │ │ ├── udf_equal-6-878650cf21e9360a07d204c8ffb0cde7 │ │ │ ├── udf_equal-7-1635ef051fecdfc7891d9f5a9a3a545e │ │ │ ├── udf_equal-8-276101b04b10b7cd6d59061a8cbf42d2 │ │ │ ├── udf_exp-0-814f16e1acabe30740d7b815e4b5cc3a │ │ │ ├── udf_exp-1-d10d879c74951e9a1f1717cb1a2488c6 │ │ │ ├── udf_field-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_field-1-277b4a4dcb38cabb6df50147c77e0a33 │ │ │ ├── udf_field-10-ca9db7e6bb687606bc273d1f6c191035 │ │ │ ├── udf_field-11-7982ea72163dbc4cd45f53454edf66c8 │ │ │ ├── udf_field-2-379d8580693493f620a8f4084709324f │ │ │ ├── udf_field-3-5960d42257b272f6ba043406229bbf26 │ │ │ ├── udf_field-4-212d8b2297bf6a3311d24d68de67b5c6 │ │ │ ├── udf_field-5-949c2de113b214d83734c0c177f04b6b │ │ │ ├── udf_field-6-2d7c5cbe891c4a9dda34f9842f8e0828 │ │ │ ├── udf_field-7-3fd8b0c333acdf28c676315b03e2e10 │ │ │ ├── udf_field-8-6aa3518e9f55299754521e959e9376ef │ │ │ ├── udf_field-9-66dc6c81db0ac9b2075783b0d8976083 │ │ │ ├── udf_find_in_set-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_find_in_set-1-18d3e88b18c18a00598146a3307276f2 │ │ │ ├── udf_find_in_set-10-df21f44247d7275a292520c1605c4aab │ │ │ ├── udf_find_in_set-11-91f8c37820f31d0d1b16029a59a185ad │ │ │ ├── udf_find_in_set-12-692f41c998bbc6bec0f374eae4356739 │ │ │ ├── udf_find_in_set-13-45e5ae8f60de2c41f189db7922a04917 │ │ │ ├── udf_find_in_set-14-8e410ecfad2d408ad7d2554ccd3a6621 │ │ │ ├── udf_find_in_set-15-c50e6ff95c05bfa854b33b03db858cd9 │ │ │ ├── udf_find_in_set-16-8e17f41ae6e8b1075af4790a8fd88e13 │ │ │ ├── udf_find_in_set-17-fe61f992f2d971d006155bdec3143803 │ │ │ ├── udf_find_in_set-18-5b556a29e1685605bcc47bce60cf66c8 │ │ │ ├── udf_find_in_set-2-5fb7a7a1725749dc3853eb80fba19246 │ │ │ ├── udf_find_in_set-3-b3823bdc04a7f98951b55c3e30d2a772 │ │ │ ├── udf_find_in_set-4-132b7bc7812db7683eb3bff607275d0e │ │ │ ├── udf_find_in_set-5-6f25b5bba89e1fcae171f5d595acc4ee │ │ │ ├── udf_find_in_set-6-7bf387b94afb755faca4ad73bb7c42ba │ │ │ ├── udf_find_in_set-7-730d5e95ef748ad946eceefbcd633826 │ │ │ ├── udf_find_in_set-8-ea11724531f191940e455d13878a0e69 │ │ │ ├── udf_find_in_set-9-81f9999ed1b063ce7f17d89bd0162777 │ │ │ ├── udf_float-0-7987032f1c9dcad07001445f3ca1f7a7 │ │ │ ├── udf_float-1-2abdfb4c67fe3aec2bc9cc128f407e6b │ │ │ ├── udf_floor-0-e35abe1d5534243e96d71bd0c28761d6 │ │ │ ├── udf_floor-1-497a1ddbcf738aead319fde4f90f5248 │ │ │ ├── udf_format_number-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_format_number-1-e86d559aeb84a4cc017a103182c22bfb │ │ │ ├── udf_format_number-10-3bddca6913ea7e281e223b0603010b77 │ │ │ ├── udf_format_number-2-525f133cfff86d44afdeeda667c365a5 │ │ │ ├── udf_format_number-3-591f302d5c1cd24e153a598fa0b352fd │ │ │ ├── udf_format_number-4-7969ffc4e80f7214a8eead8e1084368a │ │ │ ├── udf_format_number-5-da5bf00d45d2bd758489f661caffd4dc │ │ │ ├── udf_format_number-6-6dfca21d142652fec9017ba828a226c8 │ │ │ ├── udf_format_number-7-31eda4b0f31406add3a61e2503590113 │ │ │ ├── udf_format_number-8-b297476c6348209933132202030eb8ea │ │ │ ├── udf_format_number-9-a21fbe58ff475634c8ed9829c6b8c187 │ │ │ ├── udf_from_unixtime-0-c3adaeede5c48d232473d78acf0eed7f │ │ │ ├── udf_from_unixtime-1-d1a511d2084c7c621b5f638908c8db65 │ │ │ ├── udf_greaterthan-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_greaterthan-1-99d268829a124103cb3429c53fdc4de4 │ │ │ ├── udf_greaterthan-2-8aab8e39726a986e10e1e572939fd63c │ │ │ ├── udf_greaterthan-3-75fcadcdc6c050f1c7e70c71dc89c800 │ │ │ ├── udf_greaterthanorequal-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_greaterthanorequal-1-a7214027a91abf6501881e2af313347a │ │ │ ├── udf_greaterthanorequal-2-3669f2008e7f428f365efadbcb5ae451 │ │ │ ├── udf_greaterthanorequal-3-631662997e0c8d24d80b5d64a17446d2 │ │ │ ├── udf_hash-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_hash-1-b9e3a3986320d275982797140edfccf4 │ │ │ ├── udf_hash-2-a18646b51501d0b1beb967dc79afbd1a │ │ │ ├── udf_hash-3-2646a87ce26c383a9dafea9b56281ab7 │ │ │ ├── udf_hash-4-d1368c2e3cd113e46202156b44811987 │ │ │ ├── udf_hex-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_hex-1-c8b923c23d5eb31446780f28acbd4e16 │ │ │ ├── udf_hex-2-d55348c0ccd133b7abb690f6949b520c │ │ │ ├── udf_hex-3-3a1de5be8ce350612ee6a93303107470 │ │ │ ├── udf_hex-4-a7f99c9ad67c837658b924c0a979cf01 │ │ │ ├── udf_hex-5-1a9b53bd38a3693e66f7c03092e15c8e │ │ │ ├── udf_if-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_if-0-b7ffa85b5785cccef2af1b285348cc2c │ │ │ ├── udf_if-1-30cf7f51f92b5684e556deff3032d49a │ │ │ ├── udf_if-1-b7ffa85b5785cccef2af1b285348cc2c │ │ │ ├── udf_if-2-30cf7f51f92b5684e556deff3032d49a │ │ │ ├── udf_if-2-f2b010128e922d0096a65ddd9ae1d0b4 │ │ │ ├── udf_if-3-20206f17367ff284d67044abd745ce9f │ │ │ ├── udf_if-3-59e90bb74481aaf35480076806daf365 │ │ │ ├── udf_if-4-174dae8a1eb4cad6ccf6f67203de71ca │ │ │ ├── udf_if-4-c4f4d2c83281f9c2380b5efac55fe6eb │ │ │ ├── udf_if-5-841a8068d35a42179d3654e1a2848c43 │ │ │ ├── udf_if-5-a7db13aec05c97792f9331d63709d8cc │ │ │ ├── udf_if-6-508f9140dd33931c7b9ad336dceb32cf │ │ │ ├── udf_index-0-e91e3e5a22029b9b979ccbbef97add66 │ │ │ ├── udf_index-1-a277ac394cae40cb55d1ef3aa5add260 │ │ │ ├── udf_index-2-1f5e109131b0c67ebea521fa4902a8f6 │ │ │ ├── udf_instr-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_instr-1-2e76f819563dbaba4beb51e3a130b922 │ │ │ ├── udf_instr-2-32da357fc754badd6e3898dcc8989182 │ │ │ ├── udf_instr-3-c40fbd09410b11388ce7a6e9bea5846f │ │ │ ├── udf_instr-4-7017a441a31abc235d9359440cefda49 │ │ │ ├── udf_int-0-c24c3d4e15b5cdf081fee0a8c8ea13ba │ │ │ ├── udf_int-1-3f0405ff93adfe8b3402b118567867d7 │ │ │ ├── udf_isnotnull-0-44584503014c378bb916b38e1879bfb6 │ │ │ ├── udf_isnotnull-1-6ca2ea7938c7dac331c603ad343c1a7 │ │ │ ├── udf_isnull-0-ac8e7827d760108923509f9ea1691d53 │ │ │ ├── udf_isnull-1-55d9d04204f30cde4aa2667db88db262 │ │ │ ├── udf_java_method-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_java_method-0-991b98a25032b21802bc2a1efde606c7 │ │ │ ├── udf_java_method-1-991b98a25032b21802bc2a1efde606c7 │ │ │ ├── udf_java_method-1-a3b94d9f2c2caf85a588b6686a64630a │ │ │ ├── udf_java_method-2-69e6b8725086a8fb8f55721705442112 │ │ │ ├── udf_java_method-2-a3b94d9f2c2caf85a588b6686a64630a │ │ │ ├── udf_java_method-3-9ae6daaf9783d3d6577231320727582a │ │ │ ├── udf_java_method-3-c526dfd4d9eac718ced9afb3cf9a62fd │ │ │ ├── udf_java_method-4-2fc4554258492a1d92c89a8dbad6c1c3 │ │ │ ├── udf_lcase-0-649df2b742e6a03d0e0e364f5bee76ad │ │ │ ├── udf_lcase-1-d947c47e03bedbfd4954853cc134c66e │ │ │ ├── udf_length-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_length-1-38364b60c3a2409f53c9aa2dae19903b │ │ │ ├── udf_length-10-de456a5765db4a06110d9483985aa4a6 │ │ │ ├── udf_length-11-f3a9bd30540345db0f69b6847014b333 │ │ │ ├── udf_length-2-f183e1f8ae516bb483132ed106289b67 │ │ │ ├── udf_length-3-af46cb6887618240836eaf5be8afbba6 │ │ │ ├── udf_length-4-dcd6404afce1103d5054527e6c216d6d │ │ │ ├── udf_length-5-ba49ba4e6505c74bc33b5003f3930c43 │ │ │ ├── udf_length-6-adc1ec67836b26b60d8547c4996bfd8f │ │ │ ├── udf_length-7-460dffb0f1ab0ac0ebc4fd545809aa9a │ │ │ ├── udf_length-8-8f28e6c488df47d89dca670f04a7563f │ │ │ ├── udf_length-9-e41b220da98996f997b26ba7ef457a84 │ │ │ ├── udf_lessthan-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_lessthan-1-a0d9e8b51e3d13685b3889db38f22427 │ │ │ ├── udf_lessthan-2-952c655a1092a410e5346f1205cb8142 │ │ │ ├── udf_lessthan-3-677a1383983c94ba8008535b5a193153 │ │ │ ├── udf_lessthanorequal-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_lessthanorequal-1-b3b021456c85da76d1879191886a425b │ │ │ ├── udf_lessthanorequal-2-869d983466744ad73b109211e1638869 │ │ │ ├── udf_lessthanorequal-3-947dd56091ae1ef399ab32ce58317667 │ │ │ ├── udf_like-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_like-1-e0ba9a953e50554bdcbc55585cffde09 │ │ │ ├── udf_like-2-9781f89d352c506e972ad2a1d58ec03a │ │ │ ├── udf_like-3-dbc46cb33f0dd356af03006d9492f8b7 │ │ │ ├── udf_like-4-bef03784eab9d5e8404fd24960dea4fc │ │ │ ├── udf_like-5-47bfd4d65090dab890b467ae06cf3bd5 │ │ │ ├── udf_ln-0-779eed5722a0efaa85efe24c559072b4 │ │ │ ├── udf_ln-1-60e3541b3c703d6413869d774df9b7e4 │ │ │ ├── udf_locate-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_locate-1-6e41693c9c6dceea4d7fab4c02884e4e │ │ │ ├── udf_locate-2-d9b5934457931447874d6bb7c13de478 │ │ │ ├── udf_locate-3-ce4a131f99dc9befa926027380b38dbb │ │ │ ├── udf_locate-4-104cbfb3b59ad563810ddd7304a58b1b │ │ │ ├── udf_log-0-ca773bc1afa66218f3c13dee676bd87a │ │ │ ├── udf_log-1-db9dd44bf8c6225f835819a8cdf20d70 │ │ │ ├── udf_log10-0-35028570b378a2c7ea25b6bf6a4fac1f │ │ │ ├── udf_log10-1-abf1173290ef905d24d422faf7801fe3 │ │ │ ├── udf_log2-0-6c9ae9d4deb1b42500ad2796a99e2bc6 │ │ │ ├── udf_log2-1-a79f0dce2cfc000b11a3b5299f02db56 │ │ │ ├── udf_lower-0-257a0065c0e0df1d0b35a0c6eb30a668 │ │ │ ├── udf_lower-1-550f0a6da388596a775d921b9da995c │ │ │ ├── udf_lower-2-467230d9c8442c726e5377b70257ff5e │ │ │ ├── udf_lower-3-61b2e3e72180c80d52cf9bed18125e08 │ │ │ ├── udf_lpad-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_lpad-1-995646acf1e23cea7825412915921bef │ │ │ ├── udf_lpad-2-f58bb0fd11cb70cf197c01555ac924a8 │ │ │ ├── udf_lpad-3-ea9a05f035dedfe15d3a7f3d7756a2d7 │ │ │ ├── udf_lpad-4-48234ef55a8ec06cd4b570b9b9edab73 │ │ │ ├── udf_ltrim-0-398a623504c47bcd64fe8d200c41402f │ │ │ ├── udf_ltrim-1-658d495908097792a0e33a77becac2 │ │ │ ├── udf_map-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_map-1-9feb9f29115f94b3bb4f6a36160bd17e │ │ │ ├── udf_map-2-1f8cd98df9bf7b2528506551fef87dcf │ │ │ ├── udf_map-3-be7b52baa973b8b59b7ca63fea19aa99 │ │ │ ├── udf_map-4-60cb9c30285f7a9f99377ccbd143eb06 │ │ │ ├── udf_minute-0-9a38997c1f41f4afe00faa0abc471aee │ │ │ ├── udf_minute-1-16995573ac4f4a1b047ad6ee88699e48 │ │ │ ├── udf_minute-2-2bf0b45e6608d66c7d7a5b320f662d75 │ │ │ ├── udf_minute-3-270055c684846e87444b037226cf554c │ │ │ ├── udf_modulo-0-4e06551d4aa9464492e0f53374a280d5 │ │ │ ├── udf_modulo-1-cc0579c83ca1b36fa8a3a1622d19e877 │ │ │ ├── udf_month-0-9a38997c1f41f4afe00faa0abc471aee │ │ │ ├── udf_month-1-16995573ac4f4a1b047ad6ee88699e48 │ │ │ ├── udf_named_struct-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_named_struct-0-8f0ea83364b78634fbb3752c5a5c725 │ │ │ ├── udf_named_struct-1-380c9638cc6ea8ea42f187bf0cedf350 │ │ │ ├── udf_named_struct-1-8f0ea83364b78634fbb3752c5a5c725 │ │ │ ├── udf_named_struct-2-22a79ac608b1249306f82f4bdc669b17 │ │ │ ├── udf_named_struct-2-380c9638cc6ea8ea42f187bf0cedf350 │ │ │ ├── udf_named_struct-3-c069e28293a12a813f8e881f776bae90 │ │ │ ├── udf_named_struct-3-d7e4a555934307155784904ff9df188b │ │ │ ├── udf_named_struct-4-b499d4120e009f222f2fab160a9006d7 │ │ │ ├── udf_negative-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_negative-1-1b770ec6fb07bb771af2231a9723ec8 │ │ │ ├── udf_negative-10-1cd28efecc0d26f463221195f5e39956 │ │ │ ├── udf_negative-2-5f64266721b1ed31cfe84ee2f2377bdf │ │ │ ├── udf_negative-3-a6863d2c5fc8c3131fe70080a011392c │ │ │ ├── udf_negative-4-b90eec030fee9cbd177f9615b782d722 │ │ │ ├── udf_negative-5-771e76b0acd8ddb128781da7819d0e47 │ │ │ ├── udf_negative-6-f62c4a097c592871d896a7dc47c42f61 │ │ │ ├── udf_negative-7-f838053f5ca5c8746dc299473dff0490 │ │ │ ├── udf_negative-8-f4f23aa6f634913d194a69261af8f3f6 │ │ │ ├── udf_negative-9-f6a78fa3ea0f519d0e4abc5be7a960e5 │ │ │ ├── udf_not-0-9ddee9ccebe4acbf903da1f42fe55dbc │ │ │ ├── udf_not-1-efefc8302b02224d20f4bb0f159a6911 │ │ │ ├── udf_not-2-7e63750d3027ced0e3452ad4eb0df117 │ │ │ ├── udf_not-3-aa0c674f9ce0feba86448448a211bd2a │ │ │ ├── udf_notequal-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_notequal-1-27c0d57f7c7c48ceb7bc671f7160254e │ │ │ ├── udf_notequal-2-a7f0d1064f8f398ef504008015fddf9a │ │ │ ├── udf_notequal-3-7d815b1218c85e4cf69d6780cab17520 │ │ │ ├── udf_notequal-4-b72baeb22fad61bb31ce2d2e69375f57 │ │ │ ├── udf_notequal-5-eb04e5ee00967799c913e8a5b424a332 │ │ │ ├── udf_notequal-6-e361b9cf294c4aa25018b081a2c05e07 │ │ │ ├── udf_notequal-7-46a6514f2d7e6a097035ec1559df0096 │ │ │ ├── udf_notequal-8-a71fea4e9514cda0da9542a7701613dd │ │ │ ├── udf_notop-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_notop-1-1ce21a9b4492969c1a97612b0ccc19f2 │ │ │ ├── udf_nvl-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_nvl-1-df7383141df0bb71ccb57f3eef9775b4 │ │ │ ├── udf_nvl-2-6ec6c4b23c742fc604c9937a25b0b092 │ │ │ ├── udf_nvl-3-47199a1c23cb1cc6827c601bb66513d3 │ │ │ ├── udf_nvl-4-656661e80deb75729fef313d5e2bd330 │ │ │ ├── udf_or-0-c404aa929eb0dd87269121f8f99ada70 │ │ │ ├── udf_or-1-e21a84ffd26beabb958518ca5e46d6e0 │ │ │ ├── udf_parse_url-0-7571c0423df7bf158ea9ca98142b26b8 │ │ │ ├── udf_parse_url-1-67adfb10d4a35c4d031f26adde9f61ab │ │ │ ├── udf_parse_url-2-ed7adf45f58ad014cf9f3d653b380a4d │ │ │ ├── udf_parse_url-3-3a43b1f94ffb8082419bd7cc0b371ce2 │ │ │ ├── udf_pmod-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_pmod-0-ed67184beaf84c0542117c26651938e1 │ │ │ ├── udf_pmod-1-90f75e01dcee85253a501d53b8562dae │ │ │ ├── udf_pmod-1-ed67184beaf84c0542117c26651938e1 │ │ │ ├── udf_pmod-10-b2c7b3ae343b0a21037fe089c1348bf2 │ │ │ ├── udf_pmod-10-cab94a0c6b36a489aab9f3f305b92772 │ │ │ ├── udf_pmod-11-7ca6baa647215c334419d1bb8a527449 │ │ │ ├── udf_pmod-2-8ac9813b27801704082c6e9ea4cdc312 │ │ │ ├── udf_pmod-2-90f75e01dcee85253a501d53b8562dae │ │ │ ├── udf_pmod-3-26d9546f030281a29a50a3e8e5858234 │ │ │ ├── udf_pmod-3-8d6dd8a5e7a519fdc5261e4193e3464f │ │ │ ├── udf_pmod-4-608e04ca8855780fb9e60486759b19b8 │ │ │ ├── udf_pmod-4-7695df16d24a821224676e6bad3d66d1 │ │ │ ├── udf_pmod-5-cf5311d51d44afb8d73f588e27d5e029 │ │ │ ├── udf_pmod-5-e3ca9fe032dd6f71e33ddf367ef5e2cf │ │ │ ├── udf_pmod-6-3c09a8da2f5645e732c22a45d055125 │ │ │ ├── udf_pmod-6-c5c810e71bed8e56c1bac59b7d9c16c5 │ │ │ ├── udf_pmod-7-3665a6414590bb2aff522dfe847dbc0e │ │ │ ├── udf_pmod-7-a5fcbb9c74f9ee98e65b74197b10f618 │ │ │ ├── udf_pmod-8-95f85c34076952af0640b596365b27ca │ │ │ ├── udf_pmod-8-f49d1f1fab1d9bc19be787efbe6036dd │ │ │ ├── udf_pmod-9-798ef5064b61d0ae403e3e11c8fd749b │ │ │ ├── udf_pmod-9-e7280393102077442aa1d10eb69a6d57 │ │ │ ├── udf_positive-0-50ee5b92ad14e9f49d7ce6df7847c9b2 │ │ │ ├── udf_positive-1-1b98434a841d2248ed985c5f6ba2cc3c │ │ │ ├── udf_positive-2-610d421e590f035c24e29694a68b0d23 │ │ │ ├── udf_positive-3-400b238f4e6cdf7120be566b0ef079c5 │ │ │ ├── udf_pow-0-c7f5178951dd45dc2a41c16729314d81 │ │ │ ├── udf_pow-1-3c22c000c35144135aedbc7052f10803 │ │ │ ├── udf_power-0-57001d802c281743322d28bbc520cd4 │ │ │ ├── udf_power-1-ebd0398b2cb03f382a16382ddac13426 │ │ │ ├── udf_radians-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_radians-1-58b73fc96927d447d1225f021eaa378 │ │ │ ├── udf_radians-10-9f1b8ddf9be2e5f9b9b7ff4f00cfb66 │ │ │ ├── udf_radians-2-cb8462f25c18b7405c41a50e52476d04 │ │ │ ├── udf_radians-3-bd00297cb26f599913b14a635e768be3 │ │ │ ├── udf_radians-4-65e16c7b13de48a5d36793d0c7d35e14 │ │ │ ├── udf_radians-5-9f1b8ddf9be2e5f9b9b7ff4f00cfb66 │ │ │ ├── udf_radians-6-70c9e7199b5898e2c3a4943ec58da113 │ │ │ ├── udf_radians-7-cb8462f25c18b7405c41a50e52476d04 │ │ │ ├── udf_radians-8-bd00297cb26f599913b14a635e768be3 │ │ │ ├── udf_radians-9-65e16c7b13de48a5d36793d0c7d35e14 │ │ │ ├── udf_rand-0-f6d991f4e0dfea517dfc3dcaf1ff6af2 │ │ │ ├── udf_rand-1-c6229b8f2ca3001663229cfb8ee4763e │ │ │ ├── udf_reflect2-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_reflect2-1-7bec330c7bc6f71cbaf9bf1883d1b184 │ │ │ ├── udf_reflect2-2-c5a05379f482215a5a484bed0299bf19 │ │ │ ├── udf_reflect2-3-effc057c78c00b0af26a4ac0f5f116ca │ │ │ ├── udf_reflect2-4-73d466e70e96e9e5f0cd373b37d4e1f4 │ │ │ ├── udf_regexp-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_regexp-1-19917611f74aedc0922560f7f2595948 │ │ │ ├── udf_regexp-2-f7f0527cd47612d7f256edd5f8963800 │ │ │ ├── udf_regexp-3-59aff54bae544ee620141e4e629f167a │ │ │ ├── udf_regexp_extract-0-e251e1a4b1e191814f26c54b14ab6cd9 │ │ │ ├── udf_regexp_extract-1-8add879ab5904bd805412ef8723276fb │ │ │ ├── udf_regexp_replace-0-3ef9cc6da51dd1f5c6b71cf8a464ca0e │ │ │ ├── udf_regexp_replace-1-e79b45aa220d3c4c3b4523ac9c897bc │ │ │ ├── udf_repeat-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_repeat-1-fdeae3e88f27ef148281d69ac8c4b23b │ │ │ ├── udf_repeat-2-836be47190989d8975a09a545ecbfe0b │ │ │ ├── udf_repeat-3-3a3180b4d7c59ee477ce4bebf8e6adec │ │ │ ├── udf_repeat-4-64c5fce0c5ad4c26680a842aa740dc57 │ │ │ ├── udf_rlike-0-6ec6ef55ac041208627454e16b501d38 │ │ │ ├── udf_rlike-1-829611a596e0c87431006f7247d25eca │ │ │ ├── udf_round-0-10b53ca1f15fd7879365926f86512d15 │ │ │ ├── udf_round-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_round-1-10b53ca1f15fd7879365926f86512d15 │ │ │ ├── udf_round-1-2367bcc43510dedc80bdb6707e434da8 │ │ │ ├── udf_round-2-2367bcc43510dedc80bdb6707e434da8 │ │ │ ├── udf_round-3-fa4d11da8e1eba258ed191ed5f1447de │ │ │ ├── udf_round-4-b87ccaa1e0a87c558b56d59a8a074396 │ │ │ ├── udf_round-5-441d0075081ae87579c959d714c4922d │ │ │ ├── udf_round-6-4658ec3bc034b43e0477bf2474939449 │ │ │ ├── udf_round-7-74ff5a4862c80bd8fd84bede1a0320d │ │ │ ├── udf_round_3-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_round_3-1-15a7f123f596e28e6f238063ba4e3d6d │ │ │ ├── udf_round_3-2-a03bf4e99027d4814a32c84d89d42cca │ │ │ ├── udf_round_3-3-e3c5b35d67ef3de2800a1836718e8ac9 │ │ │ ├── udf_round_3-4-8449fbdabbb4b1e6beab89be0af498f2 │ │ │ ├── udf_round_3-5-3844531c8cff115d6a33636db0a26ad │ │ │ ├── udf_rpad-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_rpad-1-56de896c5fe8b40b22a9ed55ed79889c │ │ │ ├── udf_rpad-2-48d17e5d5d6188300d048f987fab2ca0 │ │ │ ├── udf_rpad-3-66acb969c28a8e376782ccd0d442b450 │ │ │ ├── udf_rpad-4-299dee5a72aad2a2738d7841a89bb71b │ │ │ ├── udf_rtrim-0-7acca21c725995febdf2a9c1fdf0535a │ │ │ ├── udf_rtrim-1-66d61255134c09d37cbfedd757ae47fd │ │ │ ├── udf_second-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_second-1-e004a6f20da3fa6db868ec847b217ff2 │ │ │ ├── udf_second-2-3525f55f4f13253c42b3abaa53d77888 │ │ │ ├── udf_second-3-d678372e3837a16be245d2e33482f17f │ │ │ ├── udf_second-4-2496e4d3c64ca028184431c2930d82cf │ │ │ ├── udf_sign-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_sign-1-cddd6ec2a7dfc2f8f7e35bc39df541f9 │ │ │ ├── udf_sign-10-9a5326b0bf612fed4ce0b04770bebc16 │ │ │ ├── udf_sign-11-fc7341f89c3cd3c43e436242d8aa61fa │ │ │ ├── udf_sign-12-74237f5ecc497813cf9738b21647847a │ │ │ ├── udf_sign-2-fba3eb5c16eca01b0c0f5918dbbffbc7 │ │ │ ├── udf_sign-3-d3e4489fc6873b5dbc4fe3e99ef13900 │ │ │ ├── udf_sign-4-9a5326b0bf612fed4ce0b04770bebc16 │ │ │ ├── udf_sign-5-fc7341f89c3cd3c43e436242d8aa61fa │ │ │ ├── udf_sign-6-74237f5ecc497813cf9738b21647847a │ │ │ ├── udf_sign-7-ed2aaa1a416c0cccc04de970424e1860 │ │ │ ├── udf_sign-8-fba3eb5c16eca01b0c0f5918dbbffbc7 │ │ │ ├── udf_sign-9-d3e4489fc6873b5dbc4fe3e99ef13900 │ │ │ ├── udf_sin-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_sin-1-40b50393869eb0bcde66e36fe41078ee │ │ │ ├── udf_sin-2-2f867f432fb322e21dce353d7eb50c63 │ │ │ ├── udf_sin-3-1d3a615e3aa252a317daa601811820b1 │ │ │ ├── udf_sin-4-951fb8d311f52ab59d3bacd37d3e611a │ │ │ ├── udf_smallint-0-f28e857ef74c967303855c21dc60c042 │ │ │ ├── udf_smallint-1-37d8db74267ae370d6a076b3057c5ed6 │ │ │ ├── udf_sort_array-0-e86d559aeb84a4cc017a103182c22bfb │ │ │ ├── udf_sort_array-1-976cd8b6b50a2748bbc768aa5e11cf82 │ │ │ ├── udf_sort_array-10-9e047718e5fea6ea79124f1e899f1c13 │ │ │ ├── udf_sort_array-2-c429ec85a6da60ebd4bc6f0f266e8b93 │ │ │ ├── udf_sort_array-3-55c4cdaf8438b06675d60848d68f35de │ │ │ ├── udf_space-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_space-1-91e879c9f01d90eab7bf12fcef256010 │ │ │ ├── udf_space-2-e4eaf5e96807e122548cb43be9a26754 │ │ │ ├── udf_space-3-a1b9dad63547f7ba73a5230d650983b0 │ │ │ ├── udf_space-4-d9de5746edd753507c3f054e1bee7702 │ │ │ ├── udf_space-5-ce5288dcc60f9412109930bd56752a65 │ │ │ ├── udf_sqrt-0-d5e4a818c2b3255ef0e32876cd8ed240 │ │ │ ├── udf_sqrt-1-323cb8b7f5f2c93bdb1b5aed77c08e77 │ │ │ ├── udf_std-0-e3613484de2b3fa707995720ec3f8a5b │ │ │ ├── udf_std-1-6759bde0e50a3607b7c3fd5a93cbd027 │ │ │ ├── udf_stddev-0-ad7627185d89a60b83ce19966eddbc92 │ │ │ ├── udf_stddev-1-18e1d598820013453fad45852e1a303d │ │ │ ├── udf_stddev_pop-0-96788538f1f20eb879a1add4bb5f9d12 │ │ │ ├── udf_stddev_pop-1-6286ef94de26050617bf69c17a3b4a10 │ │ │ ├── udf_stddev_samp-0-29e22949ef00f5ece1b5fd6bb1923a4 │ │ │ ├── udf_stddev_samp-1-ac7c0f92fe3b72287df2c7a719280bc4 │ │ │ ├── udf_stddev_samp-2-29e22949ef00f5ece1b5fd6bb1923a4 │ │ │ ├── udf_stddev_samp-3-ac7c0f92fe3b72287df2c7a719280bc4 │ │ │ ├── udf_string-0-17412ad1c1a827411caa7b5e891b6ac3 │ │ │ ├── udf_string-1-53b00551846b7f8bb27874b3a466e68d │ │ │ ├── udf_struct-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_struct-0-f41043b7d9f14fa5e998c90454c7bdb1 │ │ │ ├── udf_struct-1-8ccdb20153debdab789ea8ad0228e2eb │ │ │ ├── udf_struct-1-f41043b7d9f14fa5e998c90454c7bdb1 │ │ │ ├── udf_struct-2-4a62774a6de7571c8d2bcb77da63f8f3 │ │ │ ├── udf_struct-2-8ccdb20153debdab789ea8ad0228e2eb │ │ │ ├── udf_struct-3-71361a92b74c4d026ac7ae6e1e6746f1 │ │ │ ├── udf_struct-3-abffdaacb0c7076ab538fbeec072daa2 │ │ │ ├── udf_struct-4-b196b5d8849d52bbe5e2ee683f29e051 │ │ │ ├── udf_substring-0-8297700b238f417dea2bd60ba72a6ece │ │ │ ├── udf_substring-1-e5df65419ecd9e837dadfcdd7f9074f8 │ │ │ ├── udf_subtract-0-8f69db6aad14e23c9c32bf21bd0b3bf3 │ │ │ ├── udf_subtract-1-b90eec030fee9cbd177f9615b782d722 │ │ │ ├── udf_sum-0-d5b30a6a291025b1f9334ce8944dab31 │ │ │ ├── udf_sum-1-ddae1a511d3371122ab79918be5b495b │ │ │ ├── udf_sum-2-d5b30a6a291025b1f9334ce8944dab31 │ │ │ ├── udf_sum-3-ddae1a511d3371122ab79918be5b495b │ │ │ ├── udf_tan-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_tan-1-c21aa640b4edabf6613dd705d029c878 │ │ │ ├── udf_tan-2-a8c8eaa832aa9a4345b2fb9cd5e1d505 │ │ │ ├── udf_tan-3-8b46b68ff11c5fb05fb4fd7605895f0b │ │ │ ├── udf_tan-4-769fde617744ccfaa29cefec81b8704c │ │ │ ├── udf_tan-5-c21aa640b4edabf6613dd705d029c878 │ │ │ ├── udf_tan-6-a8c8eaa832aa9a4345b2fb9cd5e1d505 │ │ │ ├── udf_tan-7-8b46b68ff11c5fb05fb4fd7605895f0b │ │ │ ├── udf_tan-8-769fde617744ccfaa29cefec81b8704c │ │ │ ├── udf_tinyint-0-4a2b3d48ca445776d4a2d8c445f9633d │ │ │ ├── udf_tinyint-1-417de1aeb44510aa9746729f9ff3b426 │ │ │ ├── udf_to_byte-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_to_byte-1-94eb069fb446b7758f7e06386486bec9 │ │ │ ├── udf_to_byte-2-233102b562824cf38010868478e91e1 │ │ │ ├── udf_to_byte-3-5dc0e4c21764683d98700860d2c8ab31 │ │ │ ├── udf_to_byte-4-dafb27507b4d30fd2231680f9ea80c82 │ │ │ ├── udf_to_byte-5-eb6600cd2260e8e75253e7844c0d7dc2 │ │ │ ├── udf_to_byte-6-489cd2d26b9efde2cdbff19254289371 │ │ │ ├── udf_to_byte-7-1eaba393f93af1763dd761172fb78d52 │ │ │ ├── udf_to_byte-8-8fe36cf8fba87514744a89fe50414f79 │ │ │ ├── udf_to_byte-9-322163c32973ccc3a5168463db7a8589 │ │ │ ├── udf_to_date-0-ab5c4edc1825010642bd24f4cfc26166 │ │ │ ├── udf_to_date-1-da3c817bc5f4458078c6199390ac915e │ │ │ ├── udf_to_double-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_to_double-0-cbe030be095a93a9ae810ce7e66bdca7 │ │ │ ├── udf_to_double-1-98d2ce732277c3a7fb4827d8b221a43a │ │ │ ├── udf_to_double-1-9d7f149dc28bd312425392c3f2abea72 │ │ │ ├── udf_to_double-2-69bf8a5a4cb378bbd54c20cb8aa97abe │ │ │ ├── udf_to_double-2-e5df309104b260ff9145229d119a774d │ │ │ ├── udf_to_double-3-ab23099412d24154ff369d8bd6bde89f │ │ │ ├── udf_to_double-3-abd1a8fc84fcd692891c1ac242492e45 │ │ │ ├── udf_to_double-4-293a639a2b61a11da6ca798c04624f68 │ │ │ ├── udf_to_double-4-3651962b1a5fac4f1dc02f0403e68471 │ │ │ ├── udf_to_double-5-39bd92a64ad9d5f57d477bf668e08da5 │ │ │ ├── udf_to_double-5-42d1e80bb3324030c62a23c6d1b786a8 │ │ │ ├── udf_to_double-6-5bac1a7db00d788fd7d82e3a78e60be6 │ │ │ ├── udf_to_double-6-b65b3f3b72ce068c2b954850fe5fc2a6 │ │ │ ├── udf_to_double-7-97080ab9cd416f8acd8803291e9dc9e5 │ │ │ ├── udf_to_double-7-ab78e74674e92847fd44db0d21c2a145 │ │ │ ├── udf_to_double-8-22e97175b71ca7fd8668130f5a757aee │ │ │ ├── udf_to_double-8-df51146f6ef960c77cd1722191e4b982 │ │ │ ├── udf_to_double-9-53d0629f93ae811965bb4658e1aa3cb9 │ │ │ ├── udf_to_float-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_to_float-0-7646eca02448547eedf84a81bf42be89 │ │ │ ├── udf_to_float-1-6f0f1660c78aa1318ae1da4a2afdd9dd │ │ │ ├── udf_to_float-1-eac0237ee0294d635c2b538f6e2f0a5c │ │ │ ├── udf_to_float-2-39a67183b6d2a4da005baed849c5e971 │ │ │ ├── udf_to_float-2-ef6719eced842e7efe970665b41f8c0 │ │ │ ├── udf_to_float-3-5c1ae08cfd9ffd4d3e57b7a6ec4e39ce │ │ │ ├── udf_to_float-3-bfb661d2179679c317a7b088837258d3 │ │ │ ├── udf_to_float-4-477519ea558ef60feb754d442c1b13cc │ │ │ ├── udf_to_float-4-f3e0ab8ed691a386e6be4ce6993be507 │ │ │ ├── udf_to_float-5-3ea0b65c600c2a6c0a2f20b36bc02c0a │ │ │ ├── udf_to_float-5-75f364708c01b5e31f988f19e52b2201 │ │ │ ├── udf_to_float-6-1d9b690354f7b04df660a9e3c448a002 │ │ │ ├── udf_to_float-6-6bf596b8ac0a57d7df844cca1c94a0c7 │ │ │ ├── udf_to_float-7-cdfefa5173854b647a76383300f8b9d1 │ │ │ ├── udf_to_float-7-e4b449ba415538aac9c9ec421d8bcce8 │ │ │ ├── udf_to_float-8-5b0a785185bcaa98b581c5b3dbb3e12c │ │ │ ├── udf_to_float-8-c46d1c40e52bef886e56ae1e07892bb7 │ │ │ ├── udf_to_float-9-c5545924be7d13b1f4a13cb2bd0c17cc │ │ │ ├── udf_to_long-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_to_long-1-8aeb3ba62d4a0cecfff363741e8042f6 │ │ │ ├── udf_to_long-2-7e8fa1ae8d00a121ec14941a48d24947 │ │ │ ├── udf_to_long-3-6e5936fba8e7486beb9ab998548bbe9b │ │ │ ├── udf_to_long-4-8c284b082a256abf0426d4f6f1971703 │ │ │ ├── udf_to_long-5-6bb29b93f6b0f1427ba93efb4e78810a │ │ │ ├── udf_to_long-6-290b5a4ce01563482e81b3b532ebf9db │ │ │ ├── udf_to_long-7-da20f84586dac3e50ee9d5b9078f44db │ │ │ ├── udf_to_long-8-90f068b4b6275bdd1c4c431fb7fa90e2 │ │ │ ├── udf_to_long-9-cc8b79539085fe0e00f672b562c51cd0 │ │ │ ├── udf_to_short-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_to_short-1-94f15fe043839493107058a06a210cf7 │ │ │ ├── udf_to_short-2-981e4cb6654fde7eb4634c7ad72f8570 │ │ │ ├── udf_to_short-3-b259ee30ecf279bb4ad12d1515ca2767 │ │ │ ├── udf_to_short-4-40ffb132d5641645e2b8043dc056fb0 │ │ │ ├── udf_to_short-5-5d6c46b0154d1073c035a79dbf612479 │ │ │ ├── udf_to_short-6-6561b41835a21f973cbbc2dd80eef87f │ │ │ ├── udf_to_short-7-9f83813005b639a23901ca6ff87ff473 │ │ │ ├── udf_to_short-8-885656e165feb3a674cf636dbf08716c │ │ │ ├── udf_to_short-9-750382fa1a1b3ed5dca0d549d3a68996 │ │ │ ├── udf_translate-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_translate-1-7fe940a2b26fa19a3cfee39e56fb1241 │ │ │ ├── udf_translate-10-ca7c17e78c6a3d4e19dbd66622a87eae │ │ │ ├── udf_translate-11-40c4e7adff4dde739d7797d212892c5a │ │ │ ├── udf_translate-12-d81fd3267ec96cff31079142bf5d49bf │ │ │ ├── udf_translate-13-26085a3eba1a1b34684ec4e6c1723527 │ │ │ ├── udf_translate-2-f7aa38a33ca0df73b7a1e6b6da4b7fe8 │ │ │ ├── udf_translate-3-42aba80bf1913dd7c64545831f476c58 │ │ │ ├── udf_translate-4-20904c8be8fed5cbd2d66ead6248a60a │ │ │ ├── udf_translate-5-5d4abaf86254bacaa545c769bd7e50ba │ │ │ ├── udf_translate-6-f2637240d227f9732d3db76f2e9d3a59 │ │ │ ├── udf_translate-7-f8de3ab54db5d6a44fddb542b3d99704 │ │ │ ├── udf_translate-8-1747ed8fbb4ef889df3db937ee51e2b0 │ │ │ ├── udf_translate-9-f1bd0dd5226ee632db3c72c5fc2aaeb0 │ │ │ ├── udf_trim-0-18aa2b7ff8d263124ea47c9e27fc672f │ │ │ ├── udf_trim-1-e23715e112959e6840b6feed2ecf38a7 │ │ │ ├── udf_ucase-0-8f8c18102eb02df524106be5ea49f23d │ │ │ ├── udf_ucase-1-640713eb89dbb09dbb6e5b472fc0ec8f │ │ │ ├── udf_unhex-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_unhex-1-11eb3cc5216d5446f4165007203acc47 │ │ │ ├── udf_unhex-2-a660886085b8651852b9b77934848ae4 │ │ │ ├── udf_unhex-3-4b2cf4050af229fde91ab53fd9f3af3e │ │ │ ├── udf_unhex-4-7d3e094f139892ecef17de3fd63ca3c3 │ │ │ ├── udf_unix_timestamp-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_unix_timestamp-1-d555c8cd733572bfa8cd3362da9480cb │ │ │ ├── udf_unix_timestamp-2-8a9dbadae706047715cf5f903ff4a724 │ │ │ ├── udf_unix_timestamp-3-28c40e51e55bed62693e626efda5d9c5 │ │ │ ├── udf_unix_timestamp-4-6059ff48788d0fb8317fd331172ecea9 │ │ │ ├── udf_unix_timestamp-5-b2e42ebb75cecf09961d36587797f6d0 │ │ │ ├── udf_unix_timestamp-6-31243f5cb64356425b9f95ba011ac9d6 │ │ │ ├── udf_unix_timestamp-7-9b0f20bde1aaf9102b67a5498b167f31 │ │ │ ├── udf_unix_timestamp-8-47f433ff6ccce4c666440cc1a228a96d │ │ │ ├── udf_upper-0-47dc226b0435f668df20fe0e84293ead │ │ │ ├── udf_upper-1-f81f11c3563dbc9ff80496c4b10bcd1d │ │ │ ├── udf_var_pop-0-3187e740690ccc1988a19fea4202a6de │ │ │ ├── udf_var_pop-1-fd25e5226312bf54d918858511814766 │ │ │ ├── udf_var_samp-0-b918928871d1b7f944315558c230c229 │ │ │ ├── udf_var_samp-1-59032ed5856fd4aa17c3e8e6721eec2b │ │ │ ├── udf_var_samp-2-b918928871d1b7f944315558c230c229 │ │ │ ├── udf_var_samp-3-59032ed5856fd4aa17c3e8e6721eec2b │ │ │ ├── udf_variance-0-fd23be1baa8b5ffa0d4519560d3fca87 │ │ │ ├── udf_variance-1-c1856abae908b05bfd6183189b4fd06a │ │ │ ├── udf_variance-2-3187e740690ccc1988a19fea4202a6de │ │ │ ├── udf_variance-3-fd25e5226312bf54d918858511814766 │ │ │ ├── udf_variance-4-fd23be1baa8b5ffa0d4519560d3fca87 │ │ │ ├── udf_variance-5-c1856abae908b05bfd6183189b4fd06a │ │ │ ├── udf_variance-6-3187e740690ccc1988a19fea4202a6de │ │ │ ├── udf_variance-7-fd25e5226312bf54d918858511814766 │ │ │ ├── udf_weekofyear-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_weekofyear-1-d6b4490b549a358be375511e39627dc2 │ │ │ ├── udf_weekofyear-2-b7bbdfabe6054a66701250fd70065ddd │ │ │ ├── udf_weekofyear-3-d5dd3abb6c8c7046a85dd05f51126285 │ │ │ ├── udf_when-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_when-1-88b97c6722176393e9b3d089559d2d11 │ │ │ ├── udf_when-2-7365d5fe39dc7a025c942dad8fb9f0d4 │ │ │ ├── udf_when-3-734890c41528b9d918db66b0582228a4 │ │ │ ├── udf_when-4-c57d6eb11efc29ce3a9c450488f3d750 │ │ │ ├── udf_when-5-6ed21e998c0fc32c39f6375136f55de6 │ │ │ ├── udf_xpath-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath-1-622670bd1cbf4bf0cf04a553006e3c8 │ │ │ ├── udf_xpath-2-5a6f10392053a4eabe62f5cabb073a71 │ │ │ ├── udf_xpath-3-f0b9adf99c68290c86d0f40f45111e18 │ │ │ ├── udf_xpath-4-6d5e7ed902ac051f0cdba43d7a30434e │ │ │ ├── udf_xpath-5-b66a64f91dd812fda2859863855988b5 │ │ │ ├── udf_xpath-6-d4f95ebc0057639138900722c74ee17a │ │ │ ├── udf_xpath-7-6b8fceac3bd654662f067da60670e1d9 │ │ │ ├── udf_xpath_boolean-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_boolean-1-8b2f3f8132bfc8344e243cdaf45eb371 │ │ │ ├── udf_xpath_boolean-2-9e935539c9a3f3a118145096e7f978c4 │ │ │ ├── udf_xpath_boolean-3-9b97a08303a7a89e7575687f6d7ba435 │ │ │ ├── udf_xpath_boolean-4-284ce7d6fc6850ca853111145784286b │ │ │ ├── udf_xpath_boolean-5-95a0dfa897ba9050ad751a78aeb72f3d │ │ │ ├── udf_xpath_boolean-6-796c717c9d52d3efa374d12fe65259e6 │ │ │ ├── udf_xpath_boolean-7-cc3ae9a7505e04a2e9b950442a81a559 │ │ │ ├── udf_xpath_boolean-8-62a1af222d4e12c59cef71b979c6e58 │ │ │ ├── udf_xpath_double-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_double-1-39199612969071d58b24034a2d17ca67 │ │ │ ├── udf_xpath_double-10-ad0f9117f6f52590d38e619e998a6648 │ │ │ ├── udf_xpath_double-11-bf1f96ce71879c17d91ac9df44c36d29 │ │ │ ├── udf_xpath_double-12-9621353ce5c583ca34216d357c5bb0eb │ │ │ ├── udf_xpath_double-2-2d5ceab0a14d6e837ed153e1a2235bb2 │ │ │ ├── udf_xpath_double-3-a4d22cea9dffaf26b485b3eb08963789 │ │ │ ├── udf_xpath_double-4-ea050c5b9e74d4b87b037236ef9e4fc2 │ │ │ ├── udf_xpath_double-5-1e0514d71f99da09e01a414a4e01d046 │ │ │ ├── udf_xpath_double-6-6a3985167fedd579f7bd5745133a3524 │ │ │ ├── udf_xpath_double-7-d97e93fb4b69522300f505e04b6674c8 │ │ │ ├── udf_xpath_double-8-fce6cafa07b75c9843c1c1964e84fc10 │ │ │ ├── udf_xpath_double-9-f27361521c35bf4f6581dba4c185d550 │ │ │ ├── udf_xpath_float-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_float-1-7483dafee0dc7334eecabba31977e791 │ │ │ ├── udf_xpath_float-10-89ae28cf8e6b6f422d307a0085774cab │ │ │ ├── udf_xpath_float-2-f6ddff2daba006787aeb861ca6f9d37a │ │ │ ├── udf_xpath_float-3-b743a9cb9f8688220e0a6346856f18ce │ │ │ ├── udf_xpath_float-4-6720ee0163b0f0ddd2ab72fa9ab935e3 │ │ │ ├── udf_xpath_float-5-f5e1100f6e8de31081042413b4039fb2 │ │ │ ├── udf_xpath_float-6-5e8457209d15467af7f14c09dfadb894 │ │ │ ├── udf_xpath_float-7-580ffe4dabef758c4fcb52050b315615 │ │ │ ├── udf_xpath_float-8-73cfa6fe399ca3e240b84b47ee4f8bc8 │ │ │ ├── udf_xpath_float-9-bf66b884da717d46f0b12c3b8cf8313a │ │ │ ├── udf_xpath_int-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_int-1-a9ed102a70e7e9d505be1555f0c7eb12 │ │ │ ├── udf_xpath_int-10-ea25feb474c40c6985152093d4dbb13a │ │ │ ├── udf_xpath_int-2-26ddf7e46a66065909e9e547f0459910 │ │ │ ├── udf_xpath_int-3-a04ed6832ab542d6ee5903039511a826 │ │ │ ├── udf_xpath_int-4-bf5a4dbb7a98abc91111a3798b56809f │ │ │ ├── udf_xpath_int-5-f49db0ecb889722ec68d1753c084b0e1 │ │ │ ├── udf_xpath_int-6-ac509f06f01c02924adef220404fc515 │ │ │ ├── udf_xpath_int-7-87ff12d650afb8f511d906778450fae7 │ │ │ ├── udf_xpath_int-8-a175811eca252aa77c16a44fbb0ee7b2 │ │ │ ├── udf_xpath_int-9-7da88f589199f5ca873780fb22614573 │ │ │ ├── udf_xpath_long-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_long-1-d274b272251e95ec2e8139bfa471bd0b │ │ │ ├── udf_xpath_long-10-caeac94758a40493a5227fcdb8ec2f87 │ │ │ ├── udf_xpath_long-2-43fbf4d944cf7eaf57b4d6166b803fb6 │ │ │ ├── udf_xpath_long-3-9df8d27e31d96e0b35b9b40910d4bd98 │ │ │ ├── udf_xpath_long-4-3211913c56521887d30e3d1a50762b3f │ │ │ ├── udf_xpath_long-5-d580a8f01a546baddd939b95722e6354 │ │ │ ├── udf_xpath_long-6-b695348ed3faec63be2c07d0d4afaaf3 │ │ │ ├── udf_xpath_long-7-ed5af6d7451107a753b2c7ff130ac73b │ │ │ ├── udf_xpath_long-8-2f952b56682969bb203fa3d9102f7015 │ │ │ ├── udf_xpath_long-9-947b6e08ba9c7defd75d00412f9bc4fd │ │ │ ├── udf_xpath_short-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_short-1-7d5231aed9cbbf68cd740791f9e5be17 │ │ │ ├── udf_xpath_short-10-b537709676634250e13914e76cd9a530 │ │ │ ├── udf_xpath_short-2-5d45932563b78e0b435b8cfebfe3cc2 │ │ │ ├── udf_xpath_short-3-c09b4ae6886fa58dcdd728bef45e7efa │ │ │ ├── udf_xpath_short-4-84f5f6bb2fdc0987d281d52a53a4b24e │ │ │ ├── udf_xpath_short-5-c09fd0565ed041c773fee9bd0436e861 │ │ │ ├── udf_xpath_short-6-16ced3de15d4ec87a4e7001376551758 │ │ │ ├── udf_xpath_short-7-8ffdf20c15f3ed81bb5a92c61d200ae2 │ │ │ ├── udf_xpath_short-8-102ad2dea8d94528b402d980a45d53d4 │ │ │ ├── udf_xpath_short-9-d571e18b7d8ad44fef2e0b2424f34a0d │ │ │ ├── udf_xpath_string-0-50131c0ba7b7a6b65c789a5a8497bada │ │ │ ├── udf_xpath_string-1-e315d11e9feb29177b5cb1e221c7cfa4 │ │ │ ├── udf_xpath_string-10-d87fb71039c9d2419d750a0721c5696f │ │ │ ├── udf_xpath_string-2-110b583cde6cd23c486d8223c444cbe9 │ │ │ ├── udf_xpath_string-3-17e4d8122b93a1ebdba6c1d2cf9ce0c4 │ │ │ ├── udf_xpath_string-4-302630fe7dac2cc61fe7d36ead0f41ab │ │ │ ├── udf_xpath_string-5-19357ba9cb87d3a5717543d2afdc96e2 │ │ │ ├── udf_xpath_string-6-4837e470f745487fae4f498b3a2946bc │ │ │ ├── udf_xpath_string-7-8e42951d002e3c4034b4a51928442706 │ │ │ ├── udf_xpath_string-8-fdfa4e17d70608dcc634c9e1e8a8f288 │ │ │ ├── udf_xpath_string-9-84109613320bd05abccd1058044d62c3 │ │ │ ├── unicode_notation-0-8ee564d593fc64e0ad8a52b5d659f286 │ │ │ ├── unicode_notation-1-3de206f543c9e1525c54547f076b99c3 │ │ │ ├── unicode_notation-2-9a9c2395773e362f0db32d5603673291 │ │ │ ├── unicode_notation-3-4ac0de021c370cc6b8e753e00f96682e │ │ │ ├── unicode_notation-4-3de206f543c9e1525c54547f076b99c3 │ │ │ ├── unicode_notation-5-9a9c2395773e362f0db32d5603673291 │ │ │ ├── unicode_notation-6-b52052b427ea699f7bc7bee7e32d1de9 │ │ │ ├── unicode_notation-7-3de206f543c9e1525c54547f076b99c3 │ │ │ ├── unicode_notation-8-9a9c2395773e362f0db32d5603673291 │ │ │ ├── union10-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union10-1-c5b4e04f745a28463e64aeeec6d4b2af │ │ │ ├── union10-2-60ee9eae687170317ff91dafe6b799bf │ │ │ ├── union10-3-6b4ed91859c7ab8d3548d4c7eeb65182 │ │ │ ├── union10-4-7f83822f19aa9b973198fe4c42c66856 │ │ │ ├── union11-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union11-1-a6f37db310de2edce6696c25a4fe96e3 │ │ │ ├── union11-2-cd756f39e22e121bdbd51400662aa47f │ │ │ ├── union13-0-6970d1e2405f3769a28a8804887ac657 │ │ │ ├── union13-1-534d0853c5fc094404f65ca4631c1c20 │ │ │ ├── union14-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union14-1-11603fb6225423979af6c062cfa9389b │ │ │ ├── union14-2-8e01b2f4a18ad41a622e0aadbe680398 │ │ │ ├── union15-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union15-1-caf8a4bf47a5f5dfd27388fe00686c56 │ │ │ ├── union15-2-a89acfb4bbc044c483b94e28152a41e0 │ │ │ ├── union16-0-7d7f87e388835405f8c7baba969e04f5 │ │ │ ├── union16-1-9f76074598f9b55d8afbb5659737a382 │ │ │ ├── union17-0-383b0c63b3fe31509d23612cb6ae88a │ │ │ ├── union17-1-9491c271b7e2c351ddcf126f73679892 │ │ │ ├── union17-2-e6fb104913b9da8193167ee263993dd1 │ │ │ ├── union17-3-eef8248caa65e21a7c2956aa488297a0 │ │ │ ├── union17-4-a6b1560ec2eb0bd64c9dd2c8daae99c5 │ │ │ ├── union17-5-404392d6faff5db5f36b4aa87ac8e8c9 │ │ │ ├── union18-0-383b0c63b3fe31509d23612cb6ae88a │ │ │ ├── union18-1-9491c271b7e2c351ddcf126f73679892 │ │ │ ├── union18-2-584e61e1599fe449cc998a3332dcb7e5 │ │ │ ├── union18-3-b86b4936bb620a8f5d929943f4aa75f2 │ │ │ ├── union18-4-1799ebb147238db6032fd6fe2fd36878 │ │ │ ├── union18-5-b12dcddfa4f02a14318f6564947c98a0 │ │ │ ├── union19-0-383b0c63b3fe31509d23612cb6ae88a │ │ │ ├── union19-1-9491c271b7e2c351ddcf126f73679892 │ │ │ ├── union19-2-b6161b64e57a2502c79662866782cbdf │ │ │ ├── union19-3-4e2ace50cdaad15bbe48cb793f72cbd2 │ │ │ ├── union19-4-1799ebb147238db6032fd6fe2fd36878 │ │ │ ├── union19-5-b12dcddfa4f02a14318f6564947c98a0 │ │ │ ├── union2-0-58813daf3d1af57b17518b606f8345b2 │ │ │ ├── union2-1-90d739774cb96e7d0d96513c1c9968b4 │ │ │ ├── union20-0-a7f64187712936e741d5c33b2f5dfa6d │ │ │ ├── union20-1-968e353589f1fddb914242beb25be94c │ │ │ ├── union22-0-4bd6583b3635f1db95765565518bda8d │ │ │ ├── union22-1-9037e5e0cb2d64e4efe6280dc03396f7 │ │ │ ├── union22-10-90e9c4388340428a1f68868e9322c400 │ │ │ ├── union22-2-a4c7c7ba0177c0a8fe415e2bd3e93002 │ │ │ ├── union22-3-291783e57ccb7c6cad6b5e8d2dae89a0 │ │ │ ├── union22-4-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── union22-5-24ca942f094b14b92086305cc125e833 │ │ │ ├── union22-6-44d382ce6848d3f0b900b0808747d8e9 │ │ │ ├── union22-7-25fc734982956a164adde6bb1d4d8751 │ │ │ ├── union22-8-c78e8af8e8e327c58a74f7cb34a1c912 │ │ │ ├── union22-9-f4414e4636a16596d04fcc433d1119b6 │ │ │ ├── union23-0-c86f3e120d66f1b06a8b916a4a67e4b4 │ │ │ ├── union23-1-7830963417e3535034962e2597970ddd │ │ │ ├── union24-0-5659f2e36b79fa312aaf6e233dc575c9 │ │ │ ├── union24-1-92aaed1a225be0e1b3d4556680a77b8c │ │ │ ├── union24-10-ae53b6e1d433f000da3fbe130222b89 │ │ │ ├── union24-11-a41e75063b4cac0dbaf99b4aabc3201a │ │ │ ├── union24-2-4afc74338258d50ae6ecdb0589bd2a38 │ │ │ ├── union24-3-d3370b90a3ace4b4d1cefd1ffc79906f │ │ │ ├── union24-4-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── union24-5-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── union24-6-83d9274a535ebebe0170ce8f16062ef4 │ │ │ ├── union24-7-afb3649d2de5113691a37d0c77b28b31 │ │ │ ├── union24-8-b6d9a41e2b537869e977cfb969b51edb │ │ │ ├── union24-9-db8ce0526e33b73f5589e3e34aca0198 │ │ │ ├── union25-0-f4e883ee4edf8fbb95efed8ae41cff1c │ │ │ ├── union25-1-8f4a32f3c1551b4e4f22c3b776a92043 │ │ │ ├── union25-2-f61103bb2045761ba95828898e63b92b │ │ │ ├── union26-0-a0d1a7f8eb3fba9455ab517aab14552d │ │ │ ├── union26-1-4702087f160230463e6114d6534d47e4 │ │ │ ├── union26-2-5c88f10d25ae39c1e2df8f4beaa8d562 │ │ │ ├── union26-3-4702087f160230463e6114d6534d47e4 │ │ │ ├── union27-0-7f319eff3c0237b6c06cb704dcde9195 │ │ │ ├── union27-1-fb2ddef0c7d9b05d7fb26442599d354f │ │ │ ├── union27-2-10d1593b6663231ff7de938024ce6bb6 │ │ │ ├── union27-3-ab84df3813ff23be99f148449610e530 │ │ │ ├── union28-0-6bccc08f175712c17aa66cebbf5b7e36 │ │ │ ├── union28-1-f1bd585c115dbabf655d8dc38cd4e026 │ │ │ ├── union28-2-9985bbc70b8dd624fac261eafb10a78f │ │ │ ├── union28-3-b1d75ba0d33a452619e41f70e69616e9 │ │ │ ├── union29-0-6bccc08f175712c17aa66cebbf5b7e36 │ │ │ ├── union29-1-a40036f756a306f4226634b6ab67c72c │ │ │ ├── union29-2-c7fab64fc276c13149e1e68c0deb6594 │ │ │ ├── union29-3-b1d75ba0d33a452619e41f70e69616e9 │ │ │ ├── union3-0-99620f72f0282904846a596ca5b3e46c │ │ │ ├── union3-1-ae80732ae5db530cc4e355d5d4724457 │ │ │ ├── union3-2-90ca96ea59fd45cf0af8c020ae77c908 │ │ │ ├── union3-3-72b149ccaef751bcfe55d5ca37cb5fd7 │ │ │ ├── union30-0-6bccc08f175712c17aa66cebbf5b7e36 │ │ │ ├── union30-1-1aff6fba829bae7d20266cf91383ef78 │ │ │ ├── union30-2-252f12f7532ca67132bfc62063c58430 │ │ │ ├── union30-3-b1d75ba0d33a452619e41f70e69616e9 │ │ │ ├── union31-0-ca16024e6f5399b1d035f5b9fd665163 │ │ │ ├── union31-1-b12aa87aaf64b573ce0be7013117651b │ │ │ ├── union31-10-ca695e6973bc98b7f06c998b964ae339 │ │ │ ├── union31-11-70dda95c1b749e4104cc2c767cd7fec0 │ │ │ ├── union31-12-de2477a134ab37bb22d879028becf2e5 │ │ │ ├── union31-13-22b1078764cb1c9b2fb95358c968e987 │ │ │ ├── union31-14-c36a1d8de2713f722ec42bc4686d6125 │ │ │ ├── union31-15-5df6435aed6e0a6a6853480a027b911e │ │ │ ├── union31-16-ca16024e6f5399b1d035f5b9fd665163 │ │ │ ├── union31-17-b12aa87aaf64b573ce0be7013117651b │ │ │ ├── union31-18-1522ec86f2e6735cf809a52c1f6f7883 │ │ │ ├── union31-19-1e9320795b3e4acd7e6d89a8c9ba897e │ │ │ ├── union31-2-1522ec86f2e6735cf809a52c1f6f7883 │ │ │ ├── union31-20-dceb6d9a03096d68d090557692ed6899 │ │ │ ├── union31-21-bda2e62d0ecd30200b2359df420da574 │ │ │ ├── union31-22-fa1c85506afbfa956251cd1253f5d79a │ │ │ ├── union31-23-c9d9d45a7d1a0c69efb8d8babc4a50df │ │ │ ├── union31-24-df38c8164af7cc164c728b8178da72c5 │ │ │ ├── union31-25-1485e295a99908e1862eae397b814045 │ │ │ ├── union31-3-35d1dd67e8c3d76c77baaeae0760ddfc │ │ │ ├── union31-4-77653483e5ce18437c9f85d3b297335d │ │ │ ├── union31-5-4651987fca60c1c1a59b8b28713ea737 │ │ │ ├── union31-6-69c2b75a25f884a72d89e43e0186f5a6 │ │ │ ├── union31-7-7b021f95774705e4d7ff7049ee0e0b74 │ │ │ ├── union31-8-ba92b89786ffaecd74a740705e0fa0cb │ │ │ ├── union31-9-56dfdb30edd8a687f9aa9cad29b42760 │ │ │ ├── union33-0-c67a488530dc7e20a9e7acf02c14380f │ │ │ ├── union33-1-1df7c476abb48234c839878414720873 │ │ │ ├── union33-2-3987150ad66482f5186826efcfb117f7 │ │ │ ├── union33-3-bfe75625806b414a5098af487b91046a │ │ │ ├── union33-4-1d22c1e85a4bfa338aff713d45440877 │ │ │ ├── union33-5-13c01085e0a2c46e745985fa11bedf34 │ │ │ ├── union33-6-796e4fce2bfb63c09bc04ac6eca7c9d8 │ │ │ ├── union33-7-1d22c1e85a4bfa338aff713d45440877 │ │ │ ├── union34-0-a9a6e5b0059d8f66a79ee702f2bec0a4 │ │ │ ├── union34-1-320c2fe802fab386957039aaff6399f1 │ │ │ ├── union34-10-da2b79118c21ac45ce85001fa61b0043 │ │ │ ├── union34-2-5707c9fd2cfd049426383e5e5dc80d7 │ │ │ ├── union34-3-c179e14d840249d6953cb552279822f1 │ │ │ ├── union34-4-70479e10c016e5ac448394dbadb32794 │ │ │ ├── union34-5-24ca942f094b14b92086305cc125e833 │ │ │ ├── union34-6-ff0312eeb487fc393a06880ef5bb286f │ │ │ ├── union34-7-da2b79118c21ac45ce85001fa61b0043 │ │ │ ├── union34-8-b1e2ade89ae898650f0be4f796d8947b │ │ │ ├── union34-9-d82ffe361a119651bbf41a149b6eba91 │ │ │ ├── union4-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union4-1-88deb3987655dc41989f39c0827cec74 │ │ │ ├── union4-2-41739c4bd273f0cfa94b347c36a71f38 │ │ │ ├── union4-3-2fb47e6ec0a780da5bda97752e573c0b │ │ │ ├── union4-4-7f83822f19aa9b973198fe4c42c66856 │ │ │ ├── union5-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union5-1-54c6369ded20ba12138e6c53a157dae8 │ │ │ ├── union5-2-2c19c8d564b010eeb42deee63d66a292 │ │ │ ├── union6-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union6-1-7d631b7dbfe39ccaf995e16186b3e94d │ │ │ ├── union6-2-31cbd867e4b88605d230c542af64b7c4 │ │ │ ├── union6-3-c39f37580f6b3cecbcf3192ee0cd2aa9 │ │ │ ├── union6-4-a03959cc5aaa8f6521a73e6dae04cd15 │ │ │ ├── union7-0-863233ccd616401efb4bf83c4b9e3a52 │ │ │ ├── union7-1-f449f20f6bfc4f038c79c3b7e8f48c37 │ │ │ ├── union7-2-55d6e503a281acf3289a7874c0fba3f5 │ │ │ ├── union8-0-d0a83a1cedcbd1d2158acf7eb938d18e │ │ │ ├── union8-1-1b422e4c1c8b97775518f760b995c771 │ │ │ ├── union9-0-fad6a053ab42c3cad89052e88d819e83 │ │ │ ├── union9-1-a77ee9f723b3b17a3a02164c5d0000c1 │ │ │ ├── union_date-0-a0bade1c77338d4f72962389a1f5bea2 │ │ │ ├── union_date-1-21306adbd8be8ad75174ad9d3e42b73c │ │ │ ├── union_date-2-b386e4435da29e7e240893639c6dd9c4 │ │ │ ├── union_date-3-f0f678c9032603ca0ae729a31c8c9d38 │ │ │ ├── union_date-4-d85fe746334b430941c5db3665e744d4 │ │ │ ├── union_date-5-82eebfded24cef08e0a881d1bcca02b1 │ │ │ ├── union_date-6-f4d5c71145a9b7464685aa7d09cd4dfd │ │ │ ├── union_date-7-a0bade1c77338d4f72962389a1f5bea2 │ │ │ ├── union_date-8-21306adbd8be8ad75174ad9d3e42b73c │ │ │ ├── union_lateralview-0-fbcc72d0cd912977292df8a9e55a4e98 │ │ │ ├── union_lateralview-1-55dc0ec224133e4714291cc13a7a8ce0 │ │ │ ├── union_lateralview-2-2252a6cc9b8af3e9c6eb12d470072339 │ │ │ ├── union_lateralview-3-97ea99689397f6e0c8b07d598dd9c042 │ │ │ ├── union_ppr-0-eadce09bf5dfa4849ed4536e04c0c32b │ │ │ ├── union_ppr-1-4d073ff9d6978f3c3be447920ab8daed │ │ │ ├── union_remove_11-0-3c29684bfd2df7439ee0551eb42cfa0 │ │ │ ├── union_remove_11-1-16a6a293f1d2ce481b1d2482b1d5787c │ │ │ ├── union_remove_11-10-9788525d32af3dccdefb459669f886c1 │ │ │ ├── union_remove_11-11-42ecec4117d372551310ad1d85a9c09a │ │ │ ├── union_remove_11-12-ea111d286c70e4a0c6a68a7420dc7b7 │ │ │ ├── union_remove_11-13-43d53504df013e6b35f81811138a167a │ │ │ ├── union_remove_11-14-e409e7032445097ace016b1876d95b3e │ │ │ ├── union_remove_11-2-cafed8ca348b243372b9114910be1557 │ │ │ ├── union_remove_11-3-b12e5c70d6d29757471b900b6160fa8a │ │ │ ├── union_remove_11-4-593999fae618b6b38322bc9ae4e0c027 │ │ │ ├── union_remove_11-5-6f53d5613262d393d82d159ec5dc16dc │ │ │ ├── union_remove_11-6-a2a411ad6620aa1ab24550ade336e785 │ │ │ ├── union_remove_11-7-ba03d14418197f8ad6496d30c0c29a59 │ │ │ ├── union_remove_11-8-68f30e8e5c05bbedbda95d88ab6f3ee2 │ │ │ ├── union_remove_11-9-94da21f150ed2c56046b80e46da8884d │ │ │ ├── union_remove_3-0-3c29684bfd2df7439ee0551eb42cfa0 │ │ │ ├── union_remove_3-1-16a6a293f1d2ce481b1d2482b1d5787c │ │ │ ├── union_remove_3-10-cfc49418c6621c665dfb671ed5656fc9 │ │ │ ├── union_remove_3-11-ea111d286c70e4a0c6a68a7420dc7b7 │ │ │ ├── union_remove_3-12-43d53504df013e6b35f81811138a167a │ │ │ ├── union_remove_3-13-e409e7032445097ace016b1876d95b3e │ │ │ ├── union_remove_3-2-cafed8ca348b243372b9114910be1557 │ │ │ ├── union_remove_3-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── union_remove_3-4-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── union_remove_3-5-a2a411ad6620aa1ab24550ade336e785 │ │ │ ├── union_remove_3-6-c36130e41df18093eee24b45fc0846f0 │ │ │ ├── union_remove_3-7-48f70528347f5201f387d28dae37a14a │ │ │ ├── union_remove_3-8-94da21f150ed2c56046b80e46da8884d │ │ │ ├── union_remove_3-9-7da122d7b42dc7ef504ccc442d6545f1 │ │ │ ├── union_remove_6-0-3c29684bfd2df7439ee0551eb42cfa0 │ │ │ ├── union_remove_6-1-16a6a293f1d2ce481b1d2482b1d5787c │ │ │ ├── union_remove_6-10-52171e0094ea92aaea8a485aedc88e88 │ │ │ ├── union_remove_6-11-60361645974d38829674ec6bb5502a62 │ │ │ ├── union_remove_6-12-43d53504df013e6b35f81811138a167a │ │ │ ├── union_remove_6-13-e409e7032445097ace016b1876d95b3e │ │ │ ├── union_remove_6-14-f74b28904e86047150396bc42680ca38 │ │ │ ├── union_remove_6-2-cafed8ca348b243372b9114910be1557 │ │ │ ├── union_remove_6-3-dc129f70e75cd575ce8c0de288884523 │ │ │ ├── union_remove_6-4-a572a07cd60fd4607ddd7613db8a64ab │ │ │ ├── union_remove_6-5-a2a411ad6620aa1ab24550ade336e785 │ │ │ ├── union_remove_6-6-22f22c916f3bc3bf0a28259c7b232b7 │ │ │ ├── union_remove_6-7-48f70528347f5201f387d28dae37a14a │ │ │ ├── union_remove_6-8-19e054c1050e5dbf703e91a48253ecdf │ │ │ ├── union_remove_6-9-94da21f150ed2c56046b80e46da8884d │ │ │ ├── union_script-0-ca195b08d98d7f21fe93208499bf0ff6 │ │ │ ├── union_script-1-982cc6d7b98f8fb1055a10ef021e2769 │ │ │ ├── varchar_2-0-fbced67562c536a7e9b6d3928bd9d0af │ │ │ ├── varchar_2-1-bee4e3a9ded7276960e619e6185bf329 │ │ │ ├── varchar_2-2-779a555944479991520be53f7f247626 │ │ │ ├── varchar_2-3-a8c072e5b13997e9c79484b4af9d78da │ │ │ ├── varchar_2-4-c7ac6a1b3e9416e42d2d1b56f017fe6f │ │ │ ├── varchar_2-5-96353c24b5f2b361f72e5c26b4135519 │ │ │ ├── varchar_2-6-2b62789d07b4044bc32190261bf3490f │ │ │ ├── varchar_2-7-fbced67562c536a7e9b6d3928bd9d0af │ │ │ ├── varchar_join1-0-f170a8c3d5db4cbf4e7c10aee1ef652e │ │ │ ├── varchar_join1-1-8318072ee410cae36186c9880989a1a5 │ │ │ ├── varchar_join1-10-1958143ee083437e87662cadb48c37ce │ │ │ ├── varchar_join1-11-a55f750032663f77066e4979dedea1c │ │ │ ├── varchar_join1-12-f170a8c3d5db4cbf4e7c10aee1ef652e │ │ │ ├── varchar_join1-13-8318072ee410cae36186c9880989a1a5 │ │ │ ├── varchar_join1-14-8bbaae82c89553165b975c5b8ca3aee4 │ │ │ ├── varchar_join1-2-8bbaae82c89553165b975c5b8ca3aee4 │ │ │ ├── varchar_join1-3-735f68c77eae74623c8bdbebc995a3c7 │ │ │ ├── varchar_join1-4-d5105d36e4d077e0929597124526c532 │ │ │ ├── varchar_join1-5-93624b74270b7ebd40bbb8c0a7e93e28 │ │ │ ├── varchar_join1-6-ab4392aa5ff499ec43229425ff23e22f │ │ │ ├── varchar_join1-7-a01639290aaceb4b85aa6e44319f6386 │ │ │ ├── varchar_join1-8-c05d7b534b51cecdc2ba2de4ce57ba37 │ │ │ ├── varchar_join1-9-c152d3dc6495ef75e4872dea4b7e0f82 │ │ │ ├── varchar_union1-0-433f0ff2f1c8dc92fba226759326067e │ │ │ ├── varchar_union1-1-2d1b9ffae67b8cff19b5c0c9ada38cec │ │ │ ├── varchar_union1-10-6ec48d5fea3e4a35275956b9b4467715 │ │ │ ├── varchar_union1-11-78f6e219b974e1fdf3663e46f57892a9 │ │ │ ├── varchar_union1-12-433f0ff2f1c8dc92fba226759326067e │ │ │ ├── varchar_union1-13-2d1b9ffae67b8cff19b5c0c9ada38cec │ │ │ ├── varchar_union1-14-217ba1b02c693576b652d719970a0048 │ │ │ ├── varchar_union1-2-217ba1b02c693576b652d719970a0048 │ │ │ ├── varchar_union1-3-ce2fdb2b3ec26c9a6b351d10ac8283ca │ │ │ ├── varchar_union1-4-86e7275fc6c5ce64da5031aa7c79821b │ │ │ ├── varchar_union1-5-bf77db56df2b2a077d668e47211be708 │ │ │ ├── varchar_union1-6-f338f341c5f86d0a44cabfb4f7bddc3b │ │ │ ├── varchar_union1-7-ea0d1fbae997b50dc34f7610480bbe29 │ │ │ ├── varchar_union1-8-f3be9a2498927d692356c2cf871d25bf │ │ │ ├── varchar_union1-9-b9455ffec62df97cfec63204ce02a110 │ │ │ ├── view-0-5528e36b3b0f5b14313898cc45f9c23a │ │ │ ├── view-1-7650b86c86dd6b1a99c86ddc5a31bd63 │ │ │ ├── view-10-7aae4448a05e8a8a3bace7522e952cd0 │ │ │ ├── view-11-dc95343d3e57846485dd543476391376 │ │ │ ├── view-12-371764e1cae31ea0518c03060528d239 │ │ │ ├── view-13-2abce88008f8a19164758ee821aaa8a6 │ │ │ ├── view-14-deb504f4f70fd7db975950c3c47959ee │ │ │ ├── view-15-6f2797b6f81943d3b53b8d247ae8512b │ │ │ ├── view-16-3077fd708f97a03d4151a1a30e4308d8 │ │ │ ├── view-17-544b822e12afa24d2c64d6149e19c12c │ │ │ ├── view-18-cd6a123a71769b082000669292e57add │ │ │ ├── view-19-4a8f62f10a8a7b1f6e0d1c15481590a6 │ │ │ ├── view-2-9c529f486fa81a032bfe1253808fca8 │ │ │ ├── view-20-92aa822cb9dc29a1d3ad37d3ebaa344a │ │ │ ├── view-21-4fa118ed540dfe42748bbed1e7fb513d │ │ │ ├── view-22-f83b15c828d4ec599d7827af8b25f578 │ │ │ ├── view-23-f6a52dd2ff5b11ea3bba2feb867f00c2 │ │ │ ├── view-3-e7dd3b24daa60d8955b22f0441f01a6a │ │ │ ├── view-4-4a64d1a623ca71e515796787dbd0f904 │ │ │ ├── view-5-7abee38ed087f13f03ac216ef0decf4c │ │ │ ├── view-6-47b5043f03a84695b6784682b4402ac8 │ │ │ ├── view-7-8b1bbdadfd1e11af1b56064196164e58 │ │ │ ├── view-8-60d2f3ee552ae7021f9fa72f0dcf2867 │ │ │ ├── view-9-66c68babac10ae0f645fe8334c5a42d4 │ │ │ ├── view_cast-0-89bd46ad04f967f1f5ee17c6f201aacf │ │ │ ├── view_cast-1-85685a26971fb51ab6e28f9c5e8421bb │ │ │ ├── view_cast-10-a7c865e5180df8d73dba90ede8be0d45 │ │ │ ├── view_cast-11-b809f5d793b072146ccf577abf286003 │ │ │ ├── view_cast-2-635031c0752d5b30c44dfb3dec759a6c │ │ │ ├── view_cast-3-9f675e7edd64a33713e91282dc201867 │ │ │ ├── view_cast-4-d9edb83f4cf847e141d97012314917d4 │ │ │ ├── view_cast-5-6db508ccd85562a9ca7841fb0a08981a │ │ │ ├── view_cast-6-b18da53e46b62d6d91efac88ba62f308 │ │ │ ├── view_cast-7-78ac3800b22682b31708b6a09b402bfb │ │ │ ├── view_cast-8-2cc0c576f0a008abf5bdf3308d500869 │ │ │ ├── view_cast-9-f306bf3ad1c2a99f6f1843db44d7dfb4 │ │ │ ├── view_inputs-0-9e67dfd1d595ab8b1935b789645f76c0 │ │ │ ├── view_inputs-1-5af97e73bc3841793440105aae766bbe │ │ │ ├── view_inputs-2-626fa3664754125edc44b7ca7f8630db │ │ │ ├── windowing.q -- 1. testWindowing-0-327a8cd39fe30255ff492ee86f660522 │ │ │ ├── windowing.q -- 10. testHavingWithWindowingCondRankNoGBY-0-fef4bf638d52a9a601845347010602fd │ │ │ ├── windowing.q -- 11. testFirstLast-0-86bb9c97d92fdcd941bcb5143513e2e6 │ │ │ ├── windowing.q -- 12. testFirstLastWithWhere-0-84345a9f685ba63b87caa4bb16b122b5 │ │ │ ├── windowing.q -- 13. testSumWindow-0-6cfc8840d3a4469b0fe11d63182cb59f │ │ │ ├── windowing.q -- 14. testNoSortClause-0-88d96a526d3cae6ed8168c5b228974d1 │ │ │ ├── windowing.q -- 15. testExpressions-0-11f6c13cf2710ce7054654cca136e73e │ │ │ ├── windowing.q -- 16. testMultipleWindows-0-efd1476255eeb1b1961149144f574b7a │ │ │ ├── windowing.q -- 17. testCountStar-0-1b1fc185c8fddf68e58e92f29052ab2d │ │ │ ├── windowing.q -- 18. testUDAFs-0-6974e5959e41a661e09db18547fef58a │ │ │ ├── windowing.q -- 19. testUDAFsWithGBY-0-67d15ee5915ac64a738fd4b60d75eb35 │ │ │ ├── windowing.q -- 2. testGroupByWithPartitioning-0-cb5618b1e626f3a9d4a030b508b5d251 │ │ │ ├── windowing.q -- 20. testSTATs-0-6dfcd7925fb267699c4bf82737d4609 │ │ │ ├── windowing.q -- 21. testDISTs-0-d9065e533430691d70b3370174fbbd50 │ │ │ ├── windowing.q -- 24. testLateralViews-0-dea06072f0a64fe4537fae854944ed5a │ │ │ ├── windowing.q -- 26. testGroupByHavingWithSWQAndAlias-0-b996a664b06e5741c08079d5c38241bc │ │ │ ├── windowing.q -- 27. testMultipleRangeWindows-0-227e080e337d734dd88ff814b3b412e4 │ │ │ ├── windowing.q -- 28. testPartOrderInUDAFInvoke-0-25912ae7d18c91cc09e17e57968fb5db │ │ │ ├── windowing.q -- 29. testPartOrderInWdwDef-0-88945892370ccbc1125a927a3d55342a │ │ │ ├── windowing.q -- 3. testGroupByHavingWithSWQ-0-a5a5339330a6a6660d32ccb0cc5d7100 │ │ │ ├── windowing.q -- 30. testDefaultPartitioningSpecRules-0-fa80b09c99e3c1487de48ea71a88dada │ │ │ ├── windowing.q -- 36. testRankWithPartitioning-0-45ccbaf0ee083858f7661c66b11d4768 │ │ │ ├── windowing.q -- 37. testPartitioningVariousForms-0-3436e50214f9afdec84334e10faa931a │ │ │ ├── windowing.q -- 38. testPartitioningVariousForms2-0-cba9d84a6b1bb5e36595338d4602377e │ │ │ ├── windowing.q -- 39. testUDFOnOrderCols-0-7647562850dd367ef1e6c63117805423 │ │ │ ├── windowing.q -- 4. testCount-0-e6e97e884327df86f16b870527ec026c │ │ │ ├── windowing.q -- 40. testNoBetweenForRows-0-99007f45b6406869e048b0e4eb9213f1 │ │ │ ├── windowing.q -- 41. testNoBetweenForRange-0-d81a591e90950de291d2f133793e9283 │ │ │ ├── windowing.q -- 42. testUnboundedFollowingForRows-0-fb8648e82e4dd56d6bdcfd739dd1edf0 │ │ │ ├── windowing.q -- 43. testUnboundedFollowingForRange-0-3cd04e5f2398853c4850f4f86142bb39 │ │ │ ├── windowing.q -- 44. testOverNoPartitionSingleAggregate-0-cb3d2f8c1296044dc2658876bb6103ae │ │ │ ├── windowing.q -- 5. testCountWithWindowingUDAF-0-3bde93728761b780a745c2ce0398aa0f │ │ │ ├── windowing.q -- 6. testCountInSubQ-0-73d5274a21d4f4fd51d2a0f1d98516ce │ │ │ ├── windowing.q -- 8. testMixedCaseAlias-0-4b1ad2515fb079012467e987f484a722 │ │ │ ├── windowing.q -- 9. testHavingWithWindowingNoGBY-0-70cdc0555a61ef08534a9ebebb95ebbf │ │ │ ├── windowing_adjust_rowcontainer_sz-0-d3f50875bd5dff172cf813fdb7d738eb │ │ │ ├── windowing_adjust_rowcontainer_sz-1-dda16565b98926fc3587de937b9401c7 │ │ │ ├── windowing_adjust_rowcontainer_sz-2-374e39786feb745cd70f25be58bfa24 │ │ │ ├── windowing_adjust_rowcontainer_sz-3-d2b5e23edec42a62e61750b110ecbaac │ │ │ ├── windowing_adjust_rowcontainer_sz-4-50d0c630159068b5b8ccdeb76493f1f7 │ │ │ ├── windowing_adjust_rowcontainer_sz-5-3f95cd6f4add7a2d0101fe3dd97e5082 │ │ │ ├── windowing_columnPruning-0-d3f50875bd5dff172cf813fdb7d738eb │ │ │ ├── windowing_columnPruning-1-dda16565b98926fc3587de937b9401c7 │ │ │ ├── windowing_columnPruning-2-374e39786feb745cd70f25be58bfa24 │ │ │ ├── windowing_columnPruning-3-9294b4a22bc396ff2accabd53c5da98b │ │ │ ├── windowing_columnPruning-4-445cab062581c449ceffcb368cdf133 │ │ │ ├── windowing_columnPruning-5-89110070c761eafb992eb9315128b53f │ │ │ ├── windowing_multipartitioning.q (deterministic) 1-0-12a92d8800e0da8b515ba3eaf6a7fd0f │ │ │ ├── windowing_multipartitioning.q (deterministic) 3-0-455e41d9949a2d22bab634fd8e42f2b1 │ │ │ ├── windowing_multipartitioning.q (deterministic) 4-0-cfad06ae8eba6b047d32a6a61dd59392 │ │ │ ├── windowing_multipartitioning.q (deterministic) 5-0-d7ca7a61377cef3a9f721a28afdae012 │ │ │ ├── windowing_multipartitioning.q (deterministic) 6-0-287bcc7679822bc7b684532b267bf11f │ │ │ ├── windowing_navfn.q (deterministic)-0-36217f6074daaacddb9fcb50a3f4fb5b │ │ │ ├── windowing_navfn.q (deterministic)-1-9ee79e711248dd6e0a6ce27e439e55f4 │ │ │ ├── windowing_navfn.q (deterministic)-2-1e88e0ba414a00195f7ebf6b8600ac04 │ │ │ ├── windowing_navfn.q (deterministic)-3-34d9ee4120f21d0d0ae914fba0acc60c │ │ │ ├── windowing_navfn.q (deterministic)-4-dfd39236756a3951bc1ec354799d69e4 │ │ │ ├── windowing_navfn.q (deterministic)-5-8d0ee3e1605f38214bfad28a5ce897cc │ │ │ ├── windowing_ntile.q (deterministic)-0-b7cb25303831392a51cd996e758ac79a │ │ │ ├── windowing_ntile.q (deterministic)-1-a3d352560ac835993001665db6954965 │ │ │ ├── windowing_ntile.q (deterministic)-2-fafa16c0f7697ca28aeb6f2698799562 │ │ │ ├── windowing_ntile.q (deterministic)-3-bda0e7c77d6f4712a03389cb5032bc6d │ │ │ ├── windowing_rank.q (deterministic) 1-0-2e0cbc2d7c5f16657edacd9e7209e6e7 │ │ │ ├── windowing_rank.q (deterministic) 1-1-5c5f373e325115d710a7a23fcb1626f1 │ │ │ ├── windowing_rank.q (deterministic) 1-2-ac487cc1b94130bf9ce00e07c7075f65 │ │ │ ├── windowing_rank.q (deterministic) 1-3-b82dfa24123047be4b4e3c27c3997d34 │ │ │ ├── windowing_rank.q (deterministic) 2-0-81bb7f49a55385878637c8aac4d08e5 │ │ │ ├── windowing_rank.q (deterministic) 3-0-58a982694ba2b1e34de82b1de54936a0 │ │ │ ├── windowing_rank.q (deterministic) 4-0-12cc78f3953c3e6b5411ddc729541bf0 │ │ │ ├── windowing_udaf.q (deterministic)-0-6642a21d87e0401ba1a668ea8b244f0c │ │ │ ├── windowing_udaf.q (deterministic)-1-2bf20f39e6ffef258858f7943a974e7e │ │ │ ├── windowing_udaf.q (deterministic)-2-16239d2b069789ba99fbac50c4f0724f │ │ │ ├── windowing_udaf.q (deterministic)-3-d90b27fca067b0b3c48d873b3ef32af7 │ │ │ ├── windowing_udaf.q (deterministic)-4-f2e4d659b65a833e9281b6786d3d55c1 │ │ │ ├── windowing_udaf2-0-96659fde37d7a38ea15b367b47f59ce2 │ │ │ ├── windowing_udaf2-1-b4bdee4908b1cb8e240c549ae5cfe4c0 │ │ │ ├── windowing_windowspec.q (deterministic)-0-f498cccf82480be03022d2a36f87651e │ │ │ ├── windowing_windowspec.q (deterministic)-1-6378faf36ffd3f61e61cee6c0cb70e6 │ │ │ ├── windowing_windowspec.q (deterministic)-2-5f0eab306ea3c22b11ace9b542a7ee56 │ │ │ ├── windowing_windowspec.q (deterministic)-3-6f104992e0050576085064815de43194 │ │ │ ├── windowing_windowspec.q (deterministic)-4-cd2e3d2344810cb3ba843d4c01c81d7e │ │ │ ├── windowing_windowspec.q (deterministic)-5-ee44c5cdc80e1c832b702f9fb76d8145 │ │ │ ├── windowing_windowspec.q (deterministic)-6-4d78f7b1d172d20c91f5867bc13a42a0 │ │ │ ├── windowing_windowspec.q (deterministic)-7-20fdc99aa046b2c41d9b85ab338c749c │ │ │ └── windowing_windowspec.q (deterministic)-8-45a1d7c2aba45d761e19ff4dfdf5463e │ │ ├── hive-site.xml │ │ ├── hive-test-path-helper.txt │ │ ├── log4j2.properties │ │ ├── ql │ │ │ └── src │ │ │ │ └── test │ │ │ │ └── queries │ │ │ │ └── clientpositive │ │ │ │ ├── add_part_exist.q │ │ │ │ ├── add_part_multiple.q │ │ │ │ ├── add_partition_no_includelist.q │ │ │ │ ├── add_partition_with_includelist.q │ │ │ │ ├── alias_casted_column.q │ │ │ │ ├── allcolref_in_udf.q │ │ │ │ ├── alter1.q │ │ │ │ ├── alter2.q │ │ │ │ ├── alter3.q │ │ │ │ ├── alter4.q │ │ │ │ ├── alter5.q │ │ │ │ ├── alter_char1.q │ │ │ │ ├── alter_char2.q │ │ │ │ ├── alter_concatenate_indexed_table.q │ │ │ │ ├── alter_db_owner.q │ │ │ │ ├── alter_index.q │ │ │ │ ├── alter_merge.q │ │ │ │ ├── alter_merge_2.q │ │ │ │ ├── alter_merge_stats.q │ │ │ │ ├── alter_numbuckets_partitioned_table.q │ │ │ │ ├── alter_numbuckets_partitioned_table2.q │ │ │ │ ├── alter_numbuckets_partitioned_table2_h23.q │ │ │ │ ├── alter_numbuckets_partitioned_table_h23.q │ │ │ │ ├── alter_partition_clusterby_sortby.q │ │ │ │ ├── alter_partition_coltype.q │ │ │ │ ├── alter_partition_format_loc.q │ │ │ │ ├── alter_partition_protect_mode.q │ │ │ │ ├── alter_partition_with_includelist.q │ │ │ │ ├── alter_rename_partition.q │ │ │ │ ├── alter_rename_partition_authorization.q │ │ │ │ ├── alter_skewed_table.q │ │ │ │ ├── alter_table_not_sorted.q │ │ │ │ ├── alter_table_serde.q │ │ │ │ ├── alter_table_serde2.q │ │ │ │ ├── alter_varchar1.q │ │ │ │ ├── alter_varchar2.q │ │ │ │ ├── alter_view_as_select.q │ │ │ │ ├── alter_view_rename.q │ │ │ │ ├── ambiguous_col.q │ │ │ │ ├── annotate_stats_filter.q │ │ │ │ ├── annotate_stats_groupby.q │ │ │ │ ├── annotate_stats_join.q │ │ │ │ ├── annotate_stats_limit.q │ │ │ │ ├── annotate_stats_part.q │ │ │ │ ├── annotate_stats_select.q │ │ │ │ ├── annotate_stats_table.q │ │ │ │ ├── annotate_stats_union.q │ │ │ │ ├── ansi_sql_arithmetic.q │ │ │ │ ├── archive.q │ │ │ │ ├── archive_corrupt.q │ │ │ │ ├── archive_excludeHadoop20.q │ │ │ │ ├── archive_multi.q │ │ │ │ ├── authorization_1.q │ │ │ │ ├── authorization_1_sql_std.q │ │ │ │ ├── authorization_2.q │ │ │ │ ├── authorization_3.q │ │ │ │ ├── authorization_4.q │ │ │ │ ├── authorization_5.q │ │ │ │ ├── authorization_6.q │ │ │ │ ├── authorization_7.q │ │ │ │ ├── authorization_8.q │ │ │ │ ├── authorization_9.q │ │ │ │ ├── authorization_admin_almighty1.q │ │ │ │ ├── authorization_create_func1.q │ │ │ │ ├── authorization_create_macro1.q │ │ │ │ ├── authorization_create_table_owner_privs.q │ │ │ │ ├── authorization_grant_public_role.q │ │ │ │ ├── authorization_grant_table_priv.q │ │ │ │ ├── authorization_index.q │ │ │ │ ├── authorization_owner_actions.q │ │ │ │ ├── authorization_owner_actions_db.q │ │ │ │ ├── authorization_parts.q │ │ │ │ ├── authorization_revoke_table_priv.q │ │ │ │ ├── authorization_role_grant1.q │ │ │ │ ├── authorization_role_grant2.q │ │ │ │ ├── authorization_set_show_current_role.q │ │ │ │ ├── authorization_view_sqlstd.q │ │ │ │ ├── auto_join0.q │ │ │ │ ├── auto_join1.q │ │ │ │ ├── auto_join10.q │ │ │ │ ├── auto_join11.q │ │ │ │ ├── auto_join12.q │ │ │ │ ├── auto_join13.q │ │ │ │ ├── auto_join14.q │ │ │ │ ├── auto_join14_hadoop20.q │ │ │ │ ├── auto_join15.q │ │ │ │ ├── auto_join16.q │ │ │ │ ├── auto_join17.q │ │ │ │ ├── auto_join18.q │ │ │ │ ├── auto_join18_multi_distinct.q │ │ │ │ ├── auto_join19.q │ │ │ │ ├── auto_join2.q │ │ │ │ ├── auto_join20.q │ │ │ │ ├── auto_join21.q │ │ │ │ ├── auto_join22.q │ │ │ │ ├── auto_join23.q │ │ │ │ ├── auto_join24.q │ │ │ │ ├── auto_join25.q │ │ │ │ ├── auto_join26.q │ │ │ │ ├── auto_join27.q │ │ │ │ ├── auto_join28.q │ │ │ │ ├── auto_join29.q │ │ │ │ ├── auto_join3.q │ │ │ │ ├── auto_join30.q │ │ │ │ ├── auto_join31.q │ │ │ │ ├── auto_join32.q │ │ │ │ ├── auto_join4.q │ │ │ │ ├── auto_join5.q │ │ │ │ ├── auto_join6.q │ │ │ │ ├── auto_join7.q │ │ │ │ ├── auto_join8.q │ │ │ │ ├── auto_join9.q │ │ │ │ ├── auto_join_filters.q │ │ │ │ ├── auto_join_nulls.q │ │ │ │ ├── auto_join_reordering_values.q │ │ │ │ ├── auto_join_without_localtask.q │ │ │ │ ├── auto_smb_mapjoin_14.q │ │ │ │ ├── auto_sortmerge_join_1.q │ │ │ │ ├── auto_sortmerge_join_10.q │ │ │ │ ├── auto_sortmerge_join_11.q │ │ │ │ ├── auto_sortmerge_join_12.q │ │ │ │ ├── auto_sortmerge_join_13.q │ │ │ │ ├── auto_sortmerge_join_14.q │ │ │ │ ├── auto_sortmerge_join_15.q │ │ │ │ ├── auto_sortmerge_join_16.q │ │ │ │ ├── auto_sortmerge_join_2.q │ │ │ │ ├── auto_sortmerge_join_3.q │ │ │ │ ├── auto_sortmerge_join_4.q │ │ │ │ ├── auto_sortmerge_join_5.q │ │ │ │ ├── auto_sortmerge_join_6.q │ │ │ │ ├── auto_sortmerge_join_7.q │ │ │ │ ├── auto_sortmerge_join_8.q │ │ │ │ ├── auto_sortmerge_join_9.q │ │ │ │ ├── autogen_colalias.q │ │ │ │ ├── avro_change_schema.q │ │ │ │ ├── avro_compression_enabled.q │ │ │ │ ├── avro_evolved_schemas.q │ │ │ │ ├── avro_joins.q │ │ │ │ ├── avro_nullable_fields.q │ │ │ │ ├── avro_partitioned.q │ │ │ │ ├── avro_sanity_test.q │ │ │ │ ├── avro_schema_error_message.q │ │ │ │ ├── avro_schema_literal.q │ │ │ │ ├── ba_table1.q │ │ │ │ ├── ba_table2.q │ │ │ │ ├── ba_table3.q │ │ │ │ ├── ba_table_udfs.q │ │ │ │ ├── ba_table_union.q │ │ │ │ ├── binary_constant.q │ │ │ │ ├── binary_output_format.q │ │ │ │ ├── binary_table_bincolserde.q │ │ │ │ ├── binary_table_colserde.q │ │ │ │ ├── binarysortable_1.q │ │ │ │ ├── bucket1.q │ │ │ │ ├── bucket2.q │ │ │ │ ├── bucket3.q │ │ │ │ ├── bucket4.q │ │ │ │ ├── bucket5.q │ │ │ │ ├── bucket_groupby.q │ │ │ │ ├── bucket_if_with_path_filter.q │ │ │ │ ├── bucket_map_join_1.q │ │ │ │ ├── bucket_map_join_2.q │ │ │ │ ├── bucket_map_join_tez1.q │ │ │ │ ├── bucket_map_join_tez2.q │ │ │ │ ├── bucket_num_reducers.q │ │ │ │ ├── bucket_num_reducers2.q │ │ │ │ ├── bucketcontext_1.q │ │ │ │ ├── bucketcontext_2.q │ │ │ │ ├── bucketcontext_3.q │ │ │ │ ├── bucketcontext_4.q │ │ │ │ ├── bucketcontext_5.q │ │ │ │ ├── bucketcontext_6.q │ │ │ │ ├── bucketcontext_7.q │ │ │ │ ├── bucketcontext_8.q │ │ │ │ ├── bucketizedhiveinputformat.q │ │ │ │ ├── bucketizedhiveinputformat_auto.q │ │ │ │ ├── bucketmapjoin1.q │ │ │ │ ├── bucketmapjoin10.q │ │ │ │ ├── bucketmapjoin11.q │ │ │ │ ├── bucketmapjoin12.q │ │ │ │ ├── bucketmapjoin13.q │ │ │ │ ├── bucketmapjoin2.q │ │ │ │ ├── bucketmapjoin3.q │ │ │ │ ├── bucketmapjoin4.q │ │ │ │ ├── bucketmapjoin5.q │ │ │ │ ├── bucketmapjoin6.q │ │ │ │ ├── bucketmapjoin7.q │ │ │ │ ├── bucketmapjoin8.q │ │ │ │ ├── bucketmapjoin9.q │ │ │ │ ├── bucketmapjoin_negative.q │ │ │ │ ├── bucketmapjoin_negative2.q │ │ │ │ ├── bucketmapjoin_negative3.q │ │ │ │ ├── bucketsortoptimize_insert_1.q │ │ │ │ ├── bucketsortoptimize_insert_2.q │ │ │ │ ├── bucketsortoptimize_insert_3.q │ │ │ │ ├── bucketsortoptimize_insert_4.q │ │ │ │ ├── bucketsortoptimize_insert_5.q │ │ │ │ ├── bucketsortoptimize_insert_6.q │ │ │ │ ├── bucketsortoptimize_insert_7.q │ │ │ │ ├── bucketsortoptimize_insert_8.q │ │ │ │ ├── case_sensitivity.q │ │ │ │ ├── cast1.q │ │ │ │ ├── cast_to_int.q │ │ │ │ ├── char_1.q │ │ │ │ ├── char_2.q │ │ │ │ ├── char_cast.q │ │ │ │ ├── char_comparison.q │ │ │ │ ├── char_join1.q │ │ │ │ ├── char_nested_types.q │ │ │ │ ├── char_serde.q │ │ │ │ ├── char_udf1.q │ │ │ │ ├── char_union1.q │ │ │ │ ├── char_varchar_udf.q │ │ │ │ ├── cluster.q │ │ │ │ ├── column_access_stats.q │ │ │ │ ├── columnarserde_create_shortcut.q │ │ │ │ ├── columnstats_partlvl.q │ │ │ │ ├── columnstats_tbllvl.q │ │ │ │ ├── combine1.q │ │ │ │ ├── combine2.q │ │ │ │ ├── combine2_hadoop20.q │ │ │ │ ├── combine2_win.q │ │ │ │ ├── combine3.q │ │ │ │ ├── compile_processor.q │ │ │ │ ├── compute_stats_binary.q │ │ │ │ ├── compute_stats_boolean.q │ │ │ │ ├── compute_stats_decimal.q │ │ │ │ ├── compute_stats_double.q │ │ │ │ ├── compute_stats_empty_table.q │ │ │ │ ├── compute_stats_long.q │ │ │ │ ├── compute_stats_string.q │ │ │ │ ├── concatenate_inherit_table_location.q │ │ │ │ ├── constant_prop.q │ │ │ │ ├── convert_enum_to_string.q │ │ │ │ ├── correlationoptimizer1.q │ │ │ │ ├── correlationoptimizer10.q │ │ │ │ ├── correlationoptimizer11.q │ │ │ │ ├── correlationoptimizer12.q │ │ │ │ ├── correlationoptimizer13.q │ │ │ │ ├── correlationoptimizer14.q │ │ │ │ ├── correlationoptimizer15.q │ │ │ │ ├── correlationoptimizer2.q │ │ │ │ ├── correlationoptimizer3.q │ │ │ │ ├── correlationoptimizer4.q │ │ │ │ ├── correlationoptimizer5.q │ │ │ │ ├── correlationoptimizer6.q │ │ │ │ ├── correlationoptimizer7.q │ │ │ │ ├── correlationoptimizer8.q │ │ │ │ ├── correlationoptimizer9.q │ │ │ │ ├── count.q │ │ │ │ ├── cp_mj_rc.q │ │ │ │ ├── create_1.q │ │ │ │ ├── create_alter_list_bucketing_table1.q │ │ │ │ ├── create_big_view.q │ │ │ │ ├── create_default_prop.q │ │ │ │ ├── create_escape.q │ │ │ │ ├── create_func1.q │ │ │ │ ├── create_genericudaf.q │ │ │ │ ├── create_genericudf.q │ │ │ │ ├── create_insert_outputformat.q │ │ │ │ ├── create_like.q │ │ │ │ ├── create_like2.q │ │ │ │ ├── create_like_tbl_props.q │ │ │ │ ├── create_like_view.q │ │ │ │ ├── create_merge_compressed.q │ │ │ │ ├── create_nested_type.q │ │ │ │ ├── create_or_replace_view.q │ │ │ │ ├── create_skewed_table1.q │ │ │ │ ├── create_struct_table.q │ │ │ │ ├── create_udaf.q │ │ │ │ ├── create_union_table.q │ │ │ │ ├── create_view.q │ │ │ │ ├── create_view_partitioned.q │ │ │ │ ├── create_view_translate.q │ │ │ │ ├── cross_join.q │ │ │ │ ├── cross_product_check_1.q │ │ │ │ ├── cross_product_check_2.q │ │ │ │ ├── ct_case_insensitive.q │ │ │ │ ├── ctas.q │ │ │ │ ├── ctas_char.q │ │ │ │ ├── ctas_colname.q │ │ │ │ ├── ctas_date.q │ │ │ │ ├── ctas_hadoop20.q │ │ │ │ ├── ctas_uses_database_location.q │ │ │ │ ├── ctas_varchar.q │ │ │ │ ├── cte_1.q │ │ │ │ ├── cte_2.q │ │ │ │ ├── custom_input_output_format.q │ │ │ │ ├── database.q │ │ │ │ ├── database_drop.q │ │ │ │ ├── database_location.q │ │ │ │ ├── database_properties.q │ │ │ │ ├── date_1.q │ │ │ │ ├── date_2.q │ │ │ │ ├── date_3.q │ │ │ │ ├── date_4.q │ │ │ │ ├── date_comparison.q │ │ │ │ ├── date_join1.q │ │ │ │ ├── date_serde.q │ │ │ │ ├── date_udf.q │ │ │ │ ├── dbtxnmgr_compact1.q │ │ │ │ ├── dbtxnmgr_compact2.q │ │ │ │ ├── dbtxnmgr_compact3.q │ │ │ │ ├── dbtxnmgr_ddl1.q │ │ │ │ ├── dbtxnmgr_query1.q │ │ │ │ ├── dbtxnmgr_query2.q │ │ │ │ ├── dbtxnmgr_query3.q │ │ │ │ ├── dbtxnmgr_query4.q │ │ │ │ ├── dbtxnmgr_query5.q │ │ │ │ ├── dbtxnmgr_showlocks.q │ │ │ │ ├── ddltime.q │ │ │ │ ├── decimal_1.q │ │ │ │ ├── decimal_1_1.q │ │ │ │ ├── decimal_2.q │ │ │ │ ├── decimal_3.q │ │ │ │ ├── decimal_4.q │ │ │ │ ├── decimal_5.q │ │ │ │ ├── decimal_6.q │ │ │ │ ├── decimal_join.q │ │ │ │ ├── decimal_precision.q │ │ │ │ ├── decimal_serde.q │ │ │ │ ├── decimal_udf.q │ │ │ │ ├── default_partition_name.q │ │ │ │ ├── delimiter.q │ │ │ │ ├── desc_non_existent_tbl.q │ │ │ │ ├── desc_tbl_part_cols.q │ │ │ │ ├── describe_comment_indent.q │ │ │ │ ├── describe_comment_nonascii.q │ │ │ │ ├── describe_database_json.q │ │ │ │ ├── describe_formatted_view_partitioned.q │ │ │ │ ├── describe_formatted_view_partitioned_json.q │ │ │ │ ├── describe_pretty.q │ │ │ │ ├── describe_syntax.q │ │ │ │ ├── describe_table.q │ │ │ │ ├── describe_table_json.q │ │ │ │ ├── describe_xpath.q │ │ │ │ ├── diff_part_input_formats.q │ │ │ │ ├── disable_file_format_check.q │ │ │ │ ├── disable_merge_for_bucketing.q │ │ │ │ ├── disallow_incompatible_type_change_off.q │ │ │ │ ├── distinct_stats.q │ │ │ │ ├── driverhook.q │ │ │ │ ├── drop_database_removes_partition_dirs.q │ │ │ │ ├── drop_function.q │ │ │ │ ├── drop_index.q │ │ │ │ ├── drop_index_removes_partition_dirs.q │ │ │ │ ├── drop_multi_partitions.q │ │ │ │ ├── drop_partitions_filter.q │ │ │ │ ├── drop_partitions_filter2.q │ │ │ │ ├── drop_partitions_filter3.q │ │ │ │ ├── drop_partitions_ignore_protection.q │ │ │ │ ├── drop_table.q │ │ │ │ ├── drop_table2.q │ │ │ │ ├── drop_table_removes_partition_dirs.q │ │ │ │ ├── drop_udf.q │ │ │ │ ├── drop_view.q │ │ │ │ ├── drop_with_concurrency.q │ │ │ │ ├── dynamic_partition_skip_default.q │ │ │ │ ├── dynpart_sort_opt_vectorization.q │ │ │ │ ├── dynpart_sort_optimization.q │ │ │ │ ├── enforce_order.q │ │ │ │ ├── escape1.q │ │ │ │ ├── escape2.q │ │ │ │ ├── escape_clusterby1.q │ │ │ │ ├── escape_distributeby1.q │ │ │ │ ├── escape_orderby1.q │ │ │ │ ├── escape_sortby1.q │ │ │ │ ├── exchange_partition.q │ │ │ │ ├── exchange_partition2.q │ │ │ │ ├── exchange_partition3.q │ │ │ │ ├── exim_00_nonpart_empty.q │ │ │ │ ├── exim_01_nonpart.q │ │ │ │ ├── exim_02_00_part_empty.q │ │ │ │ ├── exim_02_part.q │ │ │ │ ├── exim_03_nonpart_over_compat.q │ │ │ │ ├── exim_04_all_part.q │ │ │ │ ├── exim_04_evolved_parts.q │ │ │ │ ├── exim_05_some_part.q │ │ │ │ ├── exim_06_one_part.q │ │ │ │ ├── exim_07_all_part_over_nonoverlap.q │ │ │ │ ├── exim_08_nonpart_rename.q │ │ │ │ ├── exim_09_part_spec_nonoverlap.q │ │ │ │ ├── exim_10_external_managed.q │ │ │ │ ├── exim_11_managed_external.q │ │ │ │ ├── exim_12_external_location.q │ │ │ │ ├── exim_13_managed_location.q │ │ │ │ ├── exim_14_managed_location_over_existing.q │ │ │ │ ├── exim_15_external_part.q │ │ │ │ ├── exim_16_part_external.q │ │ │ │ ├── exim_17_part_managed.q │ │ │ │ ├── exim_18_part_external.q │ │ │ │ ├── exim_19_00_part_external_location.q │ │ │ │ ├── exim_19_part_external_location.q │ │ │ │ ├── exim_20_part_managed_location.q │ │ │ │ ├── exim_21_export_authsuccess.q │ │ │ │ ├── exim_22_import_exist_authsuccess.q │ │ │ │ ├── exim_23_import_part_authsuccess.q │ │ │ │ ├── exim_24_import_nonexist_authsuccess.q │ │ │ │ ├── exim_hidden_files.q │ │ │ │ ├── explain_dependency.q │ │ │ │ ├── explain_dependency2.q │ │ │ │ ├── explain_logical.q │ │ │ │ ├── explain_rearrange.q │ │ │ │ ├── explode_null.q │ │ │ │ ├── external_table_with_space_in_location_path.q │ │ │ │ ├── fetch_aggregation.q │ │ │ │ ├── file_with_header_footer.q │ │ │ │ ├── fileformat_mix.q │ │ │ │ ├── fileformat_sequencefile.q │ │ │ │ ├── fileformat_text.q │ │ │ │ ├── filter_join_breaktask.q │ │ │ │ ├── filter_join_breaktask2.q │ │ │ │ ├── filter_numeric.q │ │ │ │ ├── global_limit.q │ │ │ │ ├── groupby1.q │ │ │ │ ├── groupby10.q │ │ │ │ ├── groupby11.q │ │ │ │ ├── groupby12.q │ │ │ │ ├── groupby1_limit.q │ │ │ │ ├── groupby1_map.q │ │ │ │ ├── groupby1_map_nomap.q │ │ │ │ ├── groupby1_map_skew.q │ │ │ │ ├── groupby1_noskew.q │ │ │ │ ├── groupby2.q │ │ │ │ ├── groupby2_limit.q │ │ │ │ ├── groupby2_map.q │ │ │ │ ├── groupby2_map_multi_distinct.q │ │ │ │ ├── groupby2_map_skew.q │ │ │ │ ├── groupby2_noskew.q │ │ │ │ ├── groupby2_noskew_multi_distinct.q │ │ │ │ ├── groupby3.q │ │ │ │ ├── groupby3_map.q │ │ │ │ ├── groupby3_map_multi_distinct.q │ │ │ │ ├── groupby3_map_skew.q │ │ │ │ ├── groupby3_noskew.q │ │ │ │ ├── groupby3_noskew_multi_distinct.q │ │ │ │ ├── groupby4.q │ │ │ │ ├── groupby4_map.q │ │ │ │ ├── groupby4_map_skew.q │ │ │ │ ├── groupby4_noskew.q │ │ │ │ ├── groupby5.q │ │ │ │ ├── groupby5_map.q │ │ │ │ ├── groupby5_map_skew.q │ │ │ │ ├── groupby5_noskew.q │ │ │ │ ├── groupby6.q │ │ │ │ ├── groupby6_map.q │ │ │ │ ├── groupby6_map_skew.q │ │ │ │ ├── groupby6_noskew.q │ │ │ │ ├── groupby7.q │ │ │ │ ├── groupby7_map.q │ │ │ │ ├── groupby7_map_multi_single_reducer.q │ │ │ │ ├── groupby7_map_skew.q │ │ │ │ ├── groupby7_noskew.q │ │ │ │ ├── groupby7_noskew_multi_single_reducer.q │ │ │ │ ├── groupby8.q │ │ │ │ ├── groupby8_map.q │ │ │ │ ├── groupby8_map_skew.q │ │ │ │ ├── groupby8_noskew.q │ │ │ │ ├── groupby9.q │ │ │ │ ├── groupby_bigdata.q │ │ │ │ ├── groupby_complex_types.q │ │ │ │ ├── groupby_complex_types_multi_single_reducer.q │ │ │ │ ├── groupby_cube1.q │ │ │ │ ├── groupby_distinct_samekey.q │ │ │ │ ├── groupby_grouping_id1.q │ │ │ │ ├── groupby_grouping_id2.q │ │ │ │ ├── groupby_grouping_sets1.q │ │ │ │ ├── groupby_grouping_sets2.q │ │ │ │ ├── groupby_grouping_sets3.q │ │ │ │ ├── groupby_grouping_sets4.q │ │ │ │ ├── groupby_grouping_sets5.q │ │ │ │ ├── groupby_map_ppr.q │ │ │ │ ├── groupby_map_ppr_multi_distinct.q │ │ │ │ ├── groupby_multi_insert_common_distinct.q │ │ │ │ ├── groupby_multi_single_reducer.q │ │ │ │ ├── groupby_multi_single_reducer2.q │ │ │ │ ├── groupby_multi_single_reducer3.q │ │ │ │ ├── groupby_mutli_insert_common_distinct.q │ │ │ │ ├── groupby_neg_float.q │ │ │ │ ├── groupby_position.q │ │ │ │ ├── groupby_ppd.q │ │ │ │ ├── groupby_ppr.q │ │ │ │ ├── groupby_ppr_multi_distinct.q │ │ │ │ ├── groupby_resolution.q │ │ │ │ ├── groupby_rollup1.q │ │ │ │ ├── groupby_sort_1.q │ │ │ │ ├── groupby_sort_10.q │ │ │ │ ├── groupby_sort_11.q │ │ │ │ ├── groupby_sort_2.q │ │ │ │ ├── groupby_sort_3.q │ │ │ │ ├── groupby_sort_4.q │ │ │ │ ├── groupby_sort_5.q │ │ │ │ ├── groupby_sort_6.q │ │ │ │ ├── groupby_sort_7.q │ │ │ │ ├── groupby_sort_8.q │ │ │ │ ├── groupby_sort_9.q │ │ │ │ ├── groupby_sort_skew_1.q │ │ │ │ ├── groupby_sort_test_1.q │ │ │ │ ├── having.q │ │ │ │ ├── hook_context_cs.q │ │ │ │ ├── hook_order.q │ │ │ │ ├── implicit_cast1.q │ │ │ │ ├── import_exported_table.q │ │ │ │ ├── index_auth.q │ │ │ │ ├── index_auto.q │ │ │ │ ├── index_auto_empty.q │ │ │ │ ├── index_auto_file_format.q │ │ │ │ ├── index_auto_mult_tables.q │ │ │ │ ├── index_auto_mult_tables_compact.q │ │ │ │ ├── index_auto_multiple.q │ │ │ │ ├── index_auto_partitioned.q │ │ │ │ ├── index_auto_self_join.q │ │ │ │ ├── index_auto_unused.q │ │ │ │ ├── index_auto_update.q │ │ │ │ ├── index_bitmap.q │ │ │ │ ├── index_bitmap1.q │ │ │ │ ├── index_bitmap2.q │ │ │ │ ├── index_bitmap3.q │ │ │ │ ├── index_bitmap_auto.q │ │ │ │ ├── index_bitmap_auto_partitioned.q │ │ │ │ ├── index_bitmap_compression.q │ │ │ │ ├── index_bitmap_rc.q │ │ │ │ ├── index_compact.q │ │ │ │ ├── index_compact_1.q │ │ │ │ ├── index_compact_2.q │ │ │ │ ├── index_compact_3.q │ │ │ │ ├── index_compact_binary_search.q │ │ │ │ ├── index_compression.q │ │ │ │ ├── index_creation.q │ │ │ │ ├── index_serde.q │ │ │ │ ├── index_stale.q │ │ │ │ ├── index_stale_partitioned.q │ │ │ │ ├── infer_bucket_sort.q │ │ │ │ ├── infer_bucket_sort_bucketed_table.q │ │ │ │ ├── infer_bucket_sort_convert_join.q │ │ │ │ ├── infer_bucket_sort_dyn_part.q │ │ │ │ ├── infer_bucket_sort_grouping_operators.q │ │ │ │ ├── infer_bucket_sort_list_bucket.q │ │ │ │ ├── infer_bucket_sort_map_operators.q │ │ │ │ ├── infer_bucket_sort_merge.q │ │ │ │ ├── infer_bucket_sort_multi_insert.q │ │ │ │ ├── infer_bucket_sort_num_buckets.q │ │ │ │ ├── infer_bucket_sort_reducers_power_two.q │ │ │ │ ├── infer_const_type.q │ │ │ │ ├── init_file.q │ │ │ │ ├── innerjoin.q │ │ │ │ ├── inoutdriver.q │ │ │ │ ├── input.q │ │ │ │ ├── input0.q │ │ │ │ ├── input1.q │ │ │ │ ├── input10.q │ │ │ │ ├── input11.q │ │ │ │ ├── input11_limit.q │ │ │ │ ├── input12.q │ │ │ │ ├── input12_hadoop20.q │ │ │ │ ├── input13.q │ │ │ │ ├── input14.q │ │ │ │ ├── input14_limit.q │ │ │ │ ├── input15.q │ │ │ │ ├── input16.q │ │ │ │ ├── input16_cc.q │ │ │ │ ├── input17.q │ │ │ │ ├── input18.q │ │ │ │ ├── input19.q │ │ │ │ ├── input1_limit.q │ │ │ │ ├── input2.q │ │ │ │ ├── input20.q │ │ │ │ ├── input21.q │ │ │ │ ├── input22.q │ │ │ │ ├── input23.q │ │ │ │ ├── input24.q │ │ │ │ ├── input25.q │ │ │ │ ├── input26.q │ │ │ │ ├── input28.q │ │ │ │ ├── input2_limit.q │ │ │ │ ├── input3.q │ │ │ │ ├── input30.q │ │ │ │ ├── input31.q │ │ │ │ ├── input32.q │ │ │ │ ├── input33.q │ │ │ │ ├── input34.q │ │ │ │ ├── input35.q │ │ │ │ ├── input36.q │ │ │ │ ├── input37.q │ │ │ │ ├── input38.q │ │ │ │ ├── input39.q │ │ │ │ ├── input39_hadoop20.q │ │ │ │ ├── input3_limit.q │ │ │ │ ├── input4.q │ │ │ │ ├── input40.q │ │ │ │ ├── input41.q │ │ │ │ ├── input42.q │ │ │ │ ├── input43.q │ │ │ │ ├── input44.q │ │ │ │ ├── input45.q │ │ │ │ ├── input46.q │ │ │ │ ├── input49.q │ │ │ │ ├── input4_cb_delim.q │ │ │ │ ├── input4_limit.q │ │ │ │ ├── input5.q │ │ │ │ ├── input6.q │ │ │ │ ├── input7.q │ │ │ │ ├── input8.q │ │ │ │ ├── input9.q │ │ │ │ ├── input_columnarserde.q │ │ │ │ ├── input_dfs.q │ │ │ │ ├── input_dynamicserde.q │ │ │ │ ├── input_lazyserde.q │ │ │ │ ├── input_limit.q │ │ │ │ ├── input_part0.q │ │ │ │ ├── input_part1.q │ │ │ │ ├── input_part10.q │ │ │ │ ├── input_part10_win.q │ │ │ │ ├── input_part2.q │ │ │ │ ├── input_part3.q │ │ │ │ ├── input_part4.q │ │ │ │ ├── input_part5.q │ │ │ │ ├── input_part6.q │ │ │ │ ├── input_part7.q │ │ │ │ ├── input_part8.q │ │ │ │ ├── input_part9.q │ │ │ │ ├── input_testsequencefile.q │ │ │ │ ├── input_testxpath.q │ │ │ │ ├── input_testxpath2.q │ │ │ │ ├── input_testxpath3.q │ │ │ │ ├── input_testxpath4.q │ │ │ │ ├── inputddl1.q │ │ │ │ ├── inputddl2.q │ │ │ │ ├── inputddl3.q │ │ │ │ ├── inputddl4.q │ │ │ │ ├── inputddl5.q │ │ │ │ ├── inputddl6.q │ │ │ │ ├── inputddl7.q │ │ │ │ ├── inputddl8.q │ │ │ │ ├── insert1.q │ │ │ │ ├── insert1_overwrite_partitions.q │ │ │ │ ├── insert2_overwrite_partitions.q │ │ │ │ ├── insert_compressed.q │ │ │ │ ├── insert_into1.q │ │ │ │ ├── insert_into2.q │ │ │ │ ├── insert_into3.q │ │ │ │ ├── insert_into4.q │ │ │ │ ├── insert_into5.q │ │ │ │ ├── insert_into6.q │ │ │ │ ├── insert_overwrite_local_directory_1.q │ │ │ │ ├── insertexternal1.q │ │ │ │ ├── join0.q │ │ │ │ ├── join1.q │ │ │ │ ├── join10.q │ │ │ │ ├── join11.q │ │ │ │ ├── join12.q │ │ │ │ ├── join13.q │ │ │ │ ├── join14.q │ │ │ │ ├── join14_hadoop20.q │ │ │ │ ├── join15.q │ │ │ │ ├── join16.q │ │ │ │ ├── join17.q │ │ │ │ ├── join18.q │ │ │ │ ├── join18_multi_distinct.q │ │ │ │ ├── join19.q │ │ │ │ ├── join2.q │ │ │ │ ├── join20.q │ │ │ │ ├── join21.q │ │ │ │ ├── join22.q │ │ │ │ ├── join23.q │ │ │ │ ├── join24.q │ │ │ │ ├── join25.q │ │ │ │ ├── join26.q │ │ │ │ ├── join27.q │ │ │ │ ├── join28.q │ │ │ │ ├── join29.q │ │ │ │ ├── join3.q │ │ │ │ ├── join30.q │ │ │ │ ├── join31.q │ │ │ │ ├── join32.q │ │ │ │ ├── join32_lessSize.q │ │ │ │ ├── join33.q │ │ │ │ ├── join34.q │ │ │ │ ├── join35.q │ │ │ │ ├── join36.q │ │ │ │ ├── join37.q │ │ │ │ ├── join38.q │ │ │ │ ├── join39.q │ │ │ │ ├── join4.q │ │ │ │ ├── join40.q │ │ │ │ ├── join41.q │ │ │ │ ├── join5.q │ │ │ │ ├── join6.q │ │ │ │ ├── join7.q │ │ │ │ ├── join8.q │ │ │ │ ├── join9.q │ │ │ │ ├── join_1to1.q │ │ │ │ ├── join_alt_syntax.q │ │ │ │ ├── join_array.q │ │ │ │ ├── join_casesensitive.q │ │ │ │ ├── join_cond_pushdown_1.q │ │ │ │ ├── join_cond_pushdown_2.q │ │ │ │ ├── join_cond_pushdown_3.q │ │ │ │ ├── join_cond_pushdown_4.q │ │ │ │ ├── join_cond_pushdown_unqual1.q │ │ │ │ ├── join_cond_pushdown_unqual2.q │ │ │ │ ├── join_cond_pushdown_unqual3.q │ │ │ │ ├── join_cond_pushdown_unqual4.q │ │ │ │ ├── join_empty.q │ │ │ │ ├── join_filters.q │ │ │ │ ├── join_filters_overlap.q │ │ │ │ ├── join_hive_626.q │ │ │ │ ├── join_literals.q │ │ │ │ ├── join_map_ppr.q │ │ │ │ ├── join_merging.q │ │ │ │ ├── join_nulls.q │ │ │ │ ├── join_nullsafe.q │ │ │ │ ├── join_rc.q │ │ │ │ ├── join_reorder.q │ │ │ │ ├── join_reorder2.q │ │ │ │ ├── join_reorder3.q │ │ │ │ ├── join_reorder4.q │ │ │ │ ├── join_star.q │ │ │ │ ├── join_thrift.q │ │ │ │ ├── join_vc.q │ │ │ │ ├── join_view.q │ │ │ │ ├── keyword_1.q │ │ │ │ ├── lateral_view.q │ │ │ │ ├── lateral_view_cp.q │ │ │ │ ├── lateral_view_noalias.q │ │ │ │ ├── lateral_view_outer.q │ │ │ │ ├── lateral_view_ppd.q │ │ │ │ ├── lb_fs_stats.q │ │ │ │ ├── leadlag.q │ │ │ │ ├── leadlag_queries.q │ │ │ │ ├── leftsemijoin.q │ │ │ │ ├── leftsemijoin_mr.q │ │ │ │ ├── limit_partition_metadataonly.q │ │ │ │ ├── limit_pushdown.q │ │ │ │ ├── limit_pushdown_negative.q │ │ │ │ ├── lineage1.q │ │ │ │ ├── list_bucket_dml_1.q │ │ │ │ ├── list_bucket_dml_10.q │ │ │ │ ├── list_bucket_dml_11.q │ │ │ │ ├── list_bucket_dml_12.q │ │ │ │ ├── list_bucket_dml_13.q │ │ │ │ ├── list_bucket_dml_2.q │ │ │ │ ├── list_bucket_dml_3.q │ │ │ │ ├── list_bucket_dml_4.q │ │ │ │ ├── list_bucket_dml_5.q │ │ │ │ ├── list_bucket_dml_6.q │ │ │ │ ├── list_bucket_dml_7.q │ │ │ │ ├── list_bucket_dml_8.q │ │ │ │ ├── list_bucket_dml_9.q │ │ │ │ ├── list_bucket_query_multiskew_1.q │ │ │ │ ├── list_bucket_query_multiskew_2.q │ │ │ │ ├── list_bucket_query_multiskew_3.q │ │ │ │ ├── list_bucket_query_oneskew_1.q │ │ │ │ ├── list_bucket_query_oneskew_2.q │ │ │ │ ├── list_bucket_query_oneskew_3.q │ │ │ │ ├── literal_decimal.q │ │ │ │ ├── literal_double.q │ │ │ │ ├── literal_ints.q │ │ │ │ ├── literal_string.q │ │ │ │ ├── load_binary_data.q │ │ │ │ ├── load_dyn_part1.q │ │ │ │ ├── load_dyn_part10.q │ │ │ │ ├── load_dyn_part11.q │ │ │ │ ├── load_dyn_part12.q │ │ │ │ ├── load_dyn_part13.q │ │ │ │ ├── load_dyn_part14.q │ │ │ │ ├── load_dyn_part14_win.q │ │ │ │ ├── load_dyn_part15.q │ │ │ │ ├── load_dyn_part2.q │ │ │ │ ├── load_dyn_part3.q │ │ │ │ ├── load_dyn_part4.q │ │ │ │ ├── load_dyn_part5.q │ │ │ │ ├── load_dyn_part6.q │ │ │ │ ├── load_dyn_part7.q │ │ │ │ ├── load_dyn_part8.q │ │ │ │ ├── load_dyn_part9.q │ │ │ │ ├── load_exist_part_authsuccess.q │ │ │ │ ├── load_file_with_space_in_the_name.q │ │ │ │ ├── load_fs.q │ │ │ │ ├── load_fs2.q │ │ │ │ ├── load_fs_overwrite.q │ │ │ │ ├── load_hdfs_file_with_space_in_the_name.q │ │ │ │ ├── load_nonpart_authsuccess.q │ │ │ │ ├── load_overwrite.q │ │ │ │ ├── load_part_authsuccess.q │ │ │ │ ├── loadpart1.q │ │ │ │ ├── loadpart2.q │ │ │ │ ├── loadpart_err.q │ │ │ │ ├── lock1.q │ │ │ │ ├── lock2.q │ │ │ │ ├── lock3.q │ │ │ │ ├── lock4.q │ │ │ │ ├── louter_join_ppr.q │ │ │ │ ├── macro.q │ │ │ │ ├── mapjoin1.q │ │ │ │ ├── mapjoin_addjar.q │ │ │ │ ├── mapjoin_decimal.q │ │ │ │ ├── mapjoin_distinct.q │ │ │ │ ├── mapjoin_filter_on_outerjoin.q │ │ │ │ ├── mapjoin_hook.q │ │ │ │ ├── mapjoin_mapjoin.q │ │ │ │ ├── mapjoin_memcheck.q │ │ │ │ ├── mapjoin_subquery.q │ │ │ │ ├── mapjoin_subquery2.q │ │ │ │ ├── mapjoin_test_outer.q │ │ │ │ ├── mapreduce1.q │ │ │ │ ├── mapreduce2.q │ │ │ │ ├── mapreduce3.q │ │ │ │ ├── mapreduce4.q │ │ │ │ ├── mapreduce5.q │ │ │ │ ├── mapreduce6.q │ │ │ │ ├── mapreduce7.q │ │ │ │ ├── mapreduce8.q │ │ │ │ ├── merge1.q │ │ │ │ ├── merge2.q │ │ │ │ ├── merge3.q │ │ │ │ ├── merge4.q │ │ │ │ ├── merge_dynamic_partition.q │ │ │ │ ├── merge_dynamic_partition2.q │ │ │ │ ├── merge_dynamic_partition3.q │ │ │ │ ├── merge_dynamic_partition4.q │ │ │ │ ├── merge_dynamic_partition5.q │ │ │ │ ├── mergejoins.q │ │ │ │ ├── mergejoins_mixed.q │ │ │ │ ├── metadata_export_drop.q │ │ │ │ ├── metadata_only_queries.q │ │ │ │ ├── metadata_only_queries_with_filters.q │ │ │ │ ├── metadataonly1.q │ │ │ │ ├── mi.q │ │ │ │ ├── misc_json.q │ │ │ │ ├── mrr.q │ │ │ │ ├── multiMapJoin1.q │ │ │ │ ├── multiMapJoin2.q │ │ │ │ ├── multi_insert.q │ │ │ │ ├── multi_insert_gby.q │ │ │ │ ├── multi_insert_gby2.q │ │ │ │ ├── multi_insert_gby3.q │ │ │ │ ├── multi_insert_lateral_view.q │ │ │ │ ├── multi_insert_move_tasks_share_dependencies.q │ │ │ │ ├── multi_join_union.q │ │ │ │ ├── multi_sahooks.q │ │ │ │ ├── multigroupby_singlemr.q │ │ │ │ ├── nested_complex.q │ │ │ │ ├── nestedvirtual.q │ │ │ │ ├── newline.q │ │ │ │ ├── no_hooks.q │ │ │ │ ├── noalias_subq1.q │ │ │ │ ├── nomore_ambiguous_table_col.q │ │ │ │ ├── nonblock_op_deduplicate.q │ │ │ │ ├── nonmr_fetch.q │ │ │ │ ├── nonmr_fetch_threshold.q │ │ │ │ ├── nonreserved_keywords_input37.q │ │ │ │ ├── nonreserved_keywords_insert_into1.q │ │ │ │ ├── notable_alias1.q │ │ │ │ ├── notable_alias2.q │ │ │ │ ├── notable_alias3.q │ │ │ │ ├── null_cast.q │ │ │ │ ├── null_column.q │ │ │ │ ├── nullformat.q │ │ │ │ ├── nullformatCTAS.q │ │ │ │ ├── nullformatdir.q │ │ │ │ ├── nullgroup.q │ │ │ │ ├── nullgroup2.q │ │ │ │ ├── nullgroup3.q │ │ │ │ ├── nullgroup4.q │ │ │ │ ├── nullgroup4_multi_distinct.q │ │ │ │ ├── nullgroup5.q │ │ │ │ ├── nullinput.q │ │ │ │ ├── nullinput2.q │ │ │ │ ├── nullscript.q │ │ │ │ ├── num_op_type_conv.q │ │ │ │ ├── ops_comparison.q │ │ │ │ ├── optional_outer.q │ │ │ │ ├── orc_analyze.q │ │ │ │ ├── orc_create.q │ │ │ │ ├── orc_createas1.q │ │ │ │ ├── orc_dictionary_threshold.q │ │ │ │ ├── orc_diff_part_cols.q │ │ │ │ ├── orc_diff_part_cols2.q │ │ │ │ ├── orc_empty_files.q │ │ │ │ ├── orc_empty_strings.q │ │ │ │ ├── orc_ends_with_nulls.q │ │ │ │ ├── orc_min_max.q │ │ │ │ ├── orc_ppd_char.q │ │ │ │ ├── orc_ppd_date.q │ │ │ │ ├── orc_ppd_decimal.q │ │ │ │ ├── orc_ppd_varchar.q │ │ │ │ ├── orc_predicate_pushdown.q │ │ │ │ ├── orc_split_elimination.q │ │ │ │ ├── orc_vectorization_ppd.q │ │ │ │ ├── order.q │ │ │ │ ├── order2.q │ │ │ │ ├── order_within_subquery.q │ │ │ │ ├── outer_join_ppr.q │ │ │ │ ├── overridden_confs.q │ │ │ │ ├── parallel.q │ │ │ │ ├── parallel_orderby.q │ │ │ │ ├── parenthesis_star_by.q │ │ │ │ ├── parquet_create.q │ │ │ │ ├── parquet_ctas.q │ │ │ │ ├── parquet_partitioned.q │ │ │ │ ├── parquet_types.q │ │ │ │ ├── partInit.q │ │ │ │ ├── part_inherit_tbl_props.q │ │ │ │ ├── part_inherit_tbl_props_empty.q │ │ │ │ ├── part_inherit_tbl_props_with_star.q │ │ │ │ ├── partcols1.q │ │ │ │ ├── partition_date.q │ │ │ │ ├── partition_date2.q │ │ │ │ ├── partition_decode_name.q │ │ │ │ ├── partition_schema1.q │ │ │ │ ├── partition_serde_format.q │ │ │ │ ├── partition_special_char.q │ │ │ │ ├── partition_type_check.q │ │ │ │ ├── partition_varchar1.q │ │ │ │ ├── partition_varchar2.q │ │ │ │ ├── partition_vs_table_metadata.q │ │ │ │ ├── partition_wise_fileformat.q │ │ │ │ ├── partition_wise_fileformat10.q │ │ │ │ ├── partition_wise_fileformat11.q │ │ │ │ ├── partition_wise_fileformat12.q │ │ │ │ ├── partition_wise_fileformat13.q │ │ │ │ ├── partition_wise_fileformat14.q │ │ │ │ ├── partition_wise_fileformat15.q │ │ │ │ ├── partition_wise_fileformat16.q │ │ │ │ ├── partition_wise_fileformat17.q │ │ │ │ ├── partition_wise_fileformat18.q │ │ │ │ ├── partition_wise_fileformat2.q │ │ │ │ ├── partition_wise_fileformat3.q │ │ │ │ ├── partition_wise_fileformat4.q │ │ │ │ ├── partition_wise_fileformat5.q │ │ │ │ ├── partition_wise_fileformat6.q │ │ │ │ ├── partition_wise_fileformat7.q │ │ │ │ ├── partition_wise_fileformat8.q │ │ │ │ ├── partition_wise_fileformat9.q │ │ │ │ ├── partitions_json.q │ │ │ │ ├── pcr.q │ │ │ │ ├── plan_json.q │ │ │ │ ├── ppd1.q │ │ │ │ ├── ppd2.q │ │ │ │ ├── ppd_clusterby.q │ │ │ │ ├── ppd_constant_expr.q │ │ │ │ ├── ppd_constant_where.q │ │ │ │ ├── ppd_gby.q │ │ │ │ ├── ppd_gby2.q │ │ │ │ ├── ppd_gby_join.q │ │ │ │ ├── ppd_join.q │ │ │ │ ├── ppd_join2.q │ │ │ │ ├── ppd_join3.q │ │ │ │ ├── ppd_join4.q │ │ │ │ ├── ppd_join_filter.q │ │ │ │ ├── ppd_multi_insert.q │ │ │ │ ├── ppd_outer_join1.q │ │ │ │ ├── ppd_outer_join2.q │ │ │ │ ├── ppd_outer_join3.q │ │ │ │ ├── ppd_outer_join4.q │ │ │ │ ├── ppd_outer_join5.q │ │ │ │ ├── ppd_random.q │ │ │ │ ├── ppd_repeated_alias.q │ │ │ │ ├── ppd_transform.q │ │ │ │ ├── ppd_udf_case.q │ │ │ │ ├── ppd_udf_col.q │ │ │ │ ├── ppd_udtf.q │ │ │ │ ├── ppd_union.q │ │ │ │ ├── ppd_union_view.q │ │ │ │ ├── ppd_vc.q │ │ │ │ ├── ppr_allchildsarenull.q │ │ │ │ ├── ppr_pushdown.q │ │ │ │ ├── ppr_pushdown2.q │ │ │ │ ├── ppr_pushdown3.q │ │ │ │ ├── print_header.q │ │ │ │ ├── progress_1.q │ │ │ │ ├── protectmode.q │ │ │ │ ├── protectmode2.q │ │ │ │ ├── ptf.q │ │ │ │ ├── ptf_decimal.q │ │ │ │ ├── ptf_general_queries.q │ │ │ │ ├── ptf_matchpath.q │ │ │ │ ├── ptf_rcfile.q │ │ │ │ ├── ptf_register_tblfn.q │ │ │ │ ├── ptf_seqfile.q │ │ │ │ ├── push_or.q │ │ │ │ ├── ql_rewrite_gbtoidx.q │ │ │ │ ├── query_properties.q │ │ │ │ ├── query_result_fileformat.q │ │ │ │ ├── query_with_semi.q │ │ │ │ ├── quote1.q │ │ │ │ ├── quote2.q │ │ │ │ ├── quotedid_alter.q │ │ │ │ ├── quotedid_basic.q │ │ │ │ ├── quotedid_partition.q │ │ │ │ ├── quotedid_skew.q │ │ │ │ ├── quotedid_smb.q │ │ │ │ ├── quotedid_tblproperty.q │ │ │ │ ├── rand_partitionpruner1.q │ │ │ │ ├── rand_partitionpruner2.q │ │ │ │ ├── rand_partitionpruner3.q │ │ │ │ ├── rcfile_bigdata.q │ │ │ │ ├── rcfile_columnar.q │ │ │ │ ├── rcfile_createas1.q │ │ │ │ ├── rcfile_default_format.q │ │ │ │ ├── rcfile_lazydecompress.q │ │ │ │ ├── rcfile_merge1.q │ │ │ │ ├── rcfile_merge2.q │ │ │ │ ├── rcfile_merge3.q │ │ │ │ ├── rcfile_merge4.q │ │ │ │ ├── rcfile_null_value.q │ │ │ │ ├── rcfile_toleratecorruptions.q │ │ │ │ ├── rcfile_union.q │ │ │ │ ├── recursive_dir.q │ │ │ │ ├── reduce_deduplicate.q │ │ │ │ ├── reduce_deduplicate_exclude_gby.q │ │ │ │ ├── reduce_deduplicate_exclude_join.q │ │ │ │ ├── reduce_deduplicate_extended.q │ │ │ │ ├── reducesink_dedup.q │ │ │ │ ├── regex_col.q │ │ │ │ ├── regexp_extract.q │ │ │ │ ├── remote_script.q │ │ │ │ ├── rename_column.q │ │ │ │ ├── rename_external_partition_location.q │ │ │ │ ├── rename_partition_location.q │ │ │ │ ├── rename_table_location.q │ │ │ │ ├── repair.q │ │ │ │ ├── reset_conf.q │ │ │ │ ├── root_dir_external_table.q │ │ │ │ ├── router_join_ppr.q │ │ │ │ ├── sample1.q │ │ │ │ ├── sample10.q │ │ │ │ ├── sample2.q │ │ │ │ ├── sample3.q │ │ │ │ ├── sample4.q │ │ │ │ ├── sample5.q │ │ │ │ ├── sample6.q │ │ │ │ ├── sample7.q │ │ │ │ ├── sample8.q │ │ │ │ ├── sample9.q │ │ │ │ ├── sample_islocalmode_hook.q │ │ │ │ ├── sample_islocalmode_hook_hadoop20.q │ │ │ │ ├── schemeAuthority.q │ │ │ │ ├── schemeAuthority2.q │ │ │ │ ├── script_env_var1.q │ │ │ │ ├── script_env_var2.q │ │ │ │ ├── script_pipe.q │ │ │ │ ├── scriptfile1.q │ │ │ │ ├── scriptfile1_win.q │ │ │ │ ├── select_as_omitted.q │ │ │ │ ├── select_dummy_source.q │ │ │ │ ├── select_transform_hint.q │ │ │ │ ├── select_unquote_and.q │ │ │ │ ├── select_unquote_not.q │ │ │ │ ├── select_unquote_or.q │ │ │ │ ├── semicolon.q │ │ │ │ ├── semijoin.q │ │ │ │ ├── serde_regex.q │ │ │ │ ├── serde_reported_schema.q │ │ │ │ ├── serde_user_properties.q │ │ │ │ ├── set_processor_namespaces.q │ │ │ │ ├── set_variable_sub.q │ │ │ │ ├── show_columns.q │ │ │ │ ├── show_create_table_alter.q │ │ │ │ ├── show_create_table_db_table.q │ │ │ │ ├── show_create_table_delimited.q │ │ │ │ ├── show_create_table_partitioned.q │ │ │ │ ├── show_create_table_serde.q │ │ │ │ ├── show_create_table_view.q │ │ │ │ ├── show_describe_func_quotes.q │ │ │ │ ├── show_functions.q │ │ │ │ ├── show_indexes_edge_cases.q │ │ │ │ ├── show_indexes_syntax.q │ │ │ │ ├── show_partitions.q │ │ │ │ ├── show_roles.q │ │ │ │ ├── show_tables.q │ │ │ │ ├── show_tablestatus.q │ │ │ │ ├── show_tblproperties.q │ │ │ │ ├── showparts.q │ │ │ │ ├── skewjoin.q │ │ │ │ ├── skewjoin_noskew.q │ │ │ │ ├── skewjoin_union_remove_1.q │ │ │ │ ├── skewjoin_union_remove_2.q │ │ │ │ ├── skewjoinopt1.q │ │ │ │ ├── skewjoinopt10.q │ │ │ │ ├── skewjoinopt11.q │ │ │ │ ├── skewjoinopt12.q │ │ │ │ ├── skewjoinopt13.q │ │ │ │ ├── skewjoinopt14.q │ │ │ │ ├── skewjoinopt15.q │ │ │ │ ├── skewjoinopt16.q │ │ │ │ ├── skewjoinopt17.q │ │ │ │ ├── skewjoinopt18.q │ │ │ │ ├── skewjoinopt19.q │ │ │ │ ├── skewjoinopt2.q │ │ │ │ ├── skewjoinopt20.q │ │ │ │ ├── skewjoinopt3.q │ │ │ │ ├── skewjoinopt4.q │ │ │ │ ├── skewjoinopt5.q │ │ │ │ ├── skewjoinopt6.q │ │ │ │ ├── skewjoinopt7.q │ │ │ │ ├── skewjoinopt8.q │ │ │ │ ├── skewjoinopt9.q │ │ │ │ ├── smb_mapjoin9.q │ │ │ │ ├── smb_mapjoin_1.q │ │ │ │ ├── smb_mapjoin_10.q │ │ │ │ ├── smb_mapjoin_11.q │ │ │ │ ├── smb_mapjoin_12.q │ │ │ │ ├── smb_mapjoin_13.q │ │ │ │ ├── smb_mapjoin_14.q │ │ │ │ ├── smb_mapjoin_15.q │ │ │ │ ├── smb_mapjoin_16.q │ │ │ │ ├── smb_mapjoin_17.q │ │ │ │ ├── smb_mapjoin_18.q │ │ │ │ ├── smb_mapjoin_19.q │ │ │ │ ├── smb_mapjoin_2.q │ │ │ │ ├── smb_mapjoin_20.q │ │ │ │ ├── smb_mapjoin_21.q │ │ │ │ ├── smb_mapjoin_22.q │ │ │ │ ├── smb_mapjoin_25.q │ │ │ │ ├── smb_mapjoin_3.q │ │ │ │ ├── smb_mapjoin_4.q │ │ │ │ ├── smb_mapjoin_5.q │ │ │ │ ├── smb_mapjoin_6.q │ │ │ │ ├── smb_mapjoin_7.q │ │ │ │ ├── smb_mapjoin_8.q │ │ │ │ ├── sort.q │ │ │ │ ├── sort_merge_join_desc_1.q │ │ │ │ ├── sort_merge_join_desc_2.q │ │ │ │ ├── sort_merge_join_desc_3.q │ │ │ │ ├── sort_merge_join_desc_4.q │ │ │ │ ├── sort_merge_join_desc_5.q │ │ │ │ ├── sort_merge_join_desc_6.q │ │ │ │ ├── sort_merge_join_desc_7.q │ │ │ │ ├── source.q │ │ │ │ ├── split.q │ │ │ │ ├── split_sample.q │ │ │ │ ├── stats0.q │ │ │ │ ├── stats1.q │ │ │ │ ├── stats10.q │ │ │ │ ├── stats11.q │ │ │ │ ├── stats12.q │ │ │ │ ├── stats13.q │ │ │ │ ├── stats14.q │ │ │ │ ├── stats15.q │ │ │ │ ├── stats16.q │ │ │ │ ├── stats18.q │ │ │ │ ├── stats19.q │ │ │ │ ├── stats2.q │ │ │ │ ├── stats20.q │ │ │ │ ├── stats3.q │ │ │ │ ├── stats4.q │ │ │ │ ├── stats5.q │ │ │ │ ├── stats6.q │ │ │ │ ├── stats7.q │ │ │ │ ├── stats8.q │ │ │ │ ├── stats9.q │ │ │ │ ├── stats_aggregator_error_1.q │ │ │ │ ├── stats_counter.q │ │ │ │ ├── stats_counter_partitioned.q │ │ │ │ ├── stats_empty_dyn_part.q │ │ │ │ ├── stats_empty_partition.q │ │ │ │ ├── stats_invalidation.q │ │ │ │ ├── stats_list_bucket.q │ │ │ │ ├── stats_noscan_1.q │ │ │ │ ├── stats_noscan_2.q │ │ │ │ ├── stats_only_null.q │ │ │ │ ├── stats_partscan_1.q │ │ │ │ ├── stats_partscan_1_23.q │ │ │ │ ├── stats_publisher_error_1.q │ │ │ │ ├── statsfs.q │ │ │ │ ├── str_to_map.q │ │ │ │ ├── subq.q │ │ │ │ ├── subq2.q │ │ │ │ ├── subq_where_serialization.q │ │ │ │ ├── subquery_alias.q │ │ │ │ ├── subquery_exists.q │ │ │ │ ├── subquery_exists_having.q │ │ │ │ ├── subquery_in.q │ │ │ │ ├── subquery_in_having.q │ │ │ │ ├── subquery_multiinsert.q │ │ │ │ ├── subquery_notexists.q │ │ │ │ ├── subquery_notexists_having.q │ │ │ │ ├── subquery_notin.q │ │ │ │ ├── subquery_notin_having.q │ │ │ │ ├── subquery_unqualcolumnrefs.q │ │ │ │ ├── subquery_views.q │ │ │ │ ├── symlink_text_input_format.q │ │ │ │ ├── table_access_keys_stats.q │ │ │ │ ├── tablename_with_select.q │ │ │ │ ├── test_boolean_whereclause.q │ │ │ │ ├── tez_dml.q │ │ │ │ ├── tez_fsstat.q │ │ │ │ ├── tez_insert_overwrite_local_directory_1.q │ │ │ │ ├── tez_join_tests.q │ │ │ │ ├── tez_joins_explain.q │ │ │ │ ├── tez_schema_evolution.q │ │ │ │ ├── tez_union.q │ │ │ │ ├── timestamp_1.q │ │ │ │ ├── timestamp_2.q │ │ │ │ ├── timestamp_3.q │ │ │ │ ├── timestamp_comparison.q │ │ │ │ ├── timestamp_lazy.q │ │ │ │ ├── timestamp_null.q │ │ │ │ ├── timestamp_udf.q │ │ │ │ ├── touch.q │ │ │ │ ├── transform1.q │ │ │ │ ├── transform2.q │ │ │ │ ├── transform_ppr1.q │ │ │ │ ├── transform_ppr2.q │ │ │ │ ├── truncate_column.q │ │ │ │ ├── truncate_column_buckets.q │ │ │ │ ├── truncate_column_list_bucket.q │ │ │ │ ├── truncate_column_merge.q │ │ │ │ ├── truncate_table.q │ │ │ │ ├── type_cast_1.q │ │ │ │ ├── type_conversions_1.q │ │ │ │ ├── type_widening.q │ │ │ │ ├── udaf_collect_set.q │ │ │ │ ├── udaf_context_ngrams.q │ │ │ │ ├── udaf_corr.q │ │ │ │ ├── udaf_covar_pop.q │ │ │ │ ├── udaf_covar_samp.q │ │ │ │ ├── udaf_histogram_numeric.q │ │ │ │ ├── udaf_ngrams.q │ │ │ │ ├── udaf_number_format.q │ │ │ │ ├── udaf_percentile.q │ │ │ │ ├── udaf_percentile_approx_20.q │ │ │ │ ├── udaf_percentile_approx_23.q │ │ │ │ ├── udaf_sum_list.q │ │ │ │ ├── udf1.q │ │ │ │ ├── udf2.q │ │ │ │ ├── udf3.q │ │ │ │ ├── udf4.q │ │ │ │ ├── udf5.q │ │ │ │ ├── udf6.q │ │ │ │ ├── udf7.q │ │ │ │ ├── udf8.q │ │ │ │ ├── udf9.q │ │ │ │ ├── udf_10_trims.q │ │ │ │ ├── udf_E.q │ │ │ │ ├── udf_PI.q │ │ │ │ ├── udf_abs.q │ │ │ │ ├── udf_acos.q │ │ │ │ ├── udf_add.q │ │ │ │ ├── udf_array.q │ │ │ │ ├── udf_array_contains.q │ │ │ │ ├── udf_ascii.q │ │ │ │ ├── udf_asin.q │ │ │ │ ├── udf_atan.q │ │ │ │ ├── udf_avg.q │ │ │ │ ├── udf_between.q │ │ │ │ ├── udf_bigint.q │ │ │ │ ├── udf_bin.q │ │ │ │ ├── udf_bitmap_and.q │ │ │ │ ├── udf_bitmap_empty.q │ │ │ │ ├── udf_bitmap_or.q │ │ │ │ ├── udf_bitwise_and.q │ │ │ │ ├── udf_bitwise_not.q │ │ │ │ ├── udf_bitwise_or.q │ │ │ │ ├── udf_bitwise_xor.q │ │ │ │ ├── udf_boolean.q │ │ │ │ ├── udf_case.q │ │ │ │ ├── udf_case_column_pruning.q │ │ │ │ ├── udf_case_thrift.q │ │ │ │ ├── udf_ceil.q │ │ │ │ ├── udf_ceiling.q │ │ │ │ ├── udf_coalesce.q │ │ │ │ ├── udf_compare_java_string.q │ │ │ │ ├── udf_concat.q │ │ │ │ ├── udf_concat_insert1.q │ │ │ │ ├── udf_concat_insert2.q │ │ │ │ ├── udf_concat_ws.q │ │ │ │ ├── udf_context_aware.q │ │ │ │ ├── udf_conv.q │ │ │ │ ├── udf_cos.q │ │ │ │ ├── udf_count.q │ │ │ │ ├── udf_current_database.q │ │ │ │ ├── udf_date_add.q │ │ │ │ ├── udf_date_sub.q │ │ │ │ ├── udf_datediff.q │ │ │ │ ├── udf_day.q │ │ │ │ ├── udf_dayofmonth.q │ │ │ │ ├── udf_degrees.q │ │ │ │ ├── udf_div.q │ │ │ │ ├── udf_divide.q │ │ │ │ ├── udf_double.q │ │ │ │ ├── udf_elt.q │ │ │ │ ├── udf_equal.q │ │ │ │ ├── udf_exp.q │ │ │ │ ├── udf_explode.q │ │ │ │ ├── udf_field.q │ │ │ │ ├── udf_find_in_set.q │ │ │ │ ├── udf_float.q │ │ │ │ ├── udf_floor.q │ │ │ │ ├── udf_format_number.q │ │ │ │ ├── udf_from_unixtime.q │ │ │ │ ├── udf_get_json_object.q │ │ │ │ ├── udf_greaterthan.q │ │ │ │ ├── udf_greaterthanorequal.q │ │ │ │ ├── udf_hash.q │ │ │ │ ├── udf_hex.q │ │ │ │ ├── udf_hour.q │ │ │ │ ├── udf_if.q │ │ │ │ ├── udf_in.q │ │ │ │ ├── udf_in_file.q │ │ │ │ ├── udf_index.q │ │ │ │ ├── udf_inline.q │ │ │ │ ├── udf_instr.q │ │ │ │ ├── udf_int.q │ │ │ │ ├── udf_isnotnull.q │ │ │ │ ├── udf_isnull.q │ │ │ │ ├── udf_isnull_isnotnull.q │ │ │ │ ├── udf_java_method.q │ │ │ │ ├── udf_lcase.q │ │ │ │ ├── udf_length.q │ │ │ │ ├── udf_lessthan.q │ │ │ │ ├── udf_lessthanorequal.q │ │ │ │ ├── udf_like.q │ │ │ │ ├── udf_ln.q │ │ │ │ ├── udf_locate.q │ │ │ │ ├── udf_log.q │ │ │ │ ├── udf_log10.q │ │ │ │ ├── udf_log2.q │ │ │ │ ├── udf_logic_java_boolean.q │ │ │ │ ├── udf_lower.q │ │ │ │ ├── udf_lpad.q │ │ │ │ ├── udf_ltrim.q │ │ │ │ ├── udf_map.q │ │ │ │ ├── udf_map_keys.q │ │ │ │ ├── udf_map_values.q │ │ │ │ ├── udf_max.q │ │ │ │ ├── udf_min.q │ │ │ │ ├── udf_minute.q │ │ │ │ ├── udf_modulo.q │ │ │ │ ├── udf_month.q │ │ │ │ ├── udf_named_struct.q │ │ │ │ ├── udf_negative.q │ │ │ │ ├── udf_not.q │ │ │ │ ├── udf_notequal.q │ │ │ │ ├── udf_notop.q │ │ │ │ ├── udf_nvl.q │ │ │ │ ├── udf_or.q │ │ │ │ ├── udf_parse_url.q │ │ │ │ ├── udf_percentile.q │ │ │ │ ├── udf_pmod.q │ │ │ │ ├── udf_positive.q │ │ │ │ ├── udf_pow.q │ │ │ │ ├── udf_power.q │ │ │ │ ├── udf_printf.q │ │ │ │ ├── udf_radians.q │ │ │ │ ├── udf_rand.q │ │ │ │ ├── udf_reflect.q │ │ │ │ ├── udf_reflect2.q │ │ │ │ ├── udf_regexp.q │ │ │ │ ├── udf_regexp_extract.q │ │ │ │ ├── udf_regexp_replace.q │ │ │ │ ├── udf_repeat.q │ │ │ │ ├── udf_reverse.q │ │ │ │ ├── udf_rlike.q │ │ │ │ ├── udf_round.q │ │ │ │ ├── udf_round_2.q │ │ │ │ ├── udf_round_3.q │ │ │ │ ├── udf_rpad.q │ │ │ │ ├── udf_rtrim.q │ │ │ │ ├── udf_second.q │ │ │ │ ├── udf_sentences.q │ │ │ │ ├── udf_sign.q │ │ │ │ ├── udf_sin.q │ │ │ │ ├── udf_size.q │ │ │ │ ├── udf_smallint.q │ │ │ │ ├── udf_sort_array.q │ │ │ │ ├── udf_space.q │ │ │ │ ├── udf_split.q │ │ │ │ ├── udf_sqrt.q │ │ │ │ ├── udf_std.q │ │ │ │ ├── udf_stddev.q │ │ │ │ ├── udf_stddev_pop.q │ │ │ │ ├── udf_stddev_samp.q │ │ │ │ ├── udf_string.q │ │ │ │ ├── udf_struct.q │ │ │ │ ├── udf_substr.q │ │ │ │ ├── udf_substring.q │ │ │ │ ├── udf_subtract.q │ │ │ │ ├── udf_sum.q │ │ │ │ ├── udf_tan.q │ │ │ │ ├── udf_testlength.q │ │ │ │ ├── udf_testlength2.q │ │ │ │ ├── udf_tinyint.q │ │ │ │ ├── udf_to_boolean.q │ │ │ │ ├── udf_to_byte.q │ │ │ │ ├── udf_to_date.q │ │ │ │ ├── udf_to_double.q │ │ │ │ ├── udf_to_float.q │ │ │ │ ├── udf_to_long.q │ │ │ │ ├── udf_to_short.q │ │ │ │ ├── udf_to_string.q │ │ │ │ ├── udf_to_unix_timestamp.q │ │ │ │ ├── udf_translate.q │ │ │ │ ├── udf_trim.q │ │ │ │ ├── udf_ucase.q │ │ │ │ ├── udf_unhex.q │ │ │ │ ├── udf_union.q │ │ │ │ ├── udf_unix_timestamp.q │ │ │ │ ├── udf_upper.q │ │ │ │ ├── udf_using.q │ │ │ │ ├── udf_var_pop.q │ │ │ │ ├── udf_var_samp.q │ │ │ │ ├── udf_variance.q │ │ │ │ ├── udf_weekofyear.q │ │ │ │ ├── udf_when.q │ │ │ │ ├── udf_xpath.q │ │ │ │ ├── udf_xpath_boolean.q │ │ │ │ ├── udf_xpath_double.q │ │ │ │ ├── udf_xpath_float.q │ │ │ │ ├── udf_xpath_int.q │ │ │ │ ├── udf_xpath_long.q │ │ │ │ ├── udf_xpath_short.q │ │ │ │ ├── udf_xpath_string.q │ │ │ │ ├── udtf_explode.q │ │ │ │ ├── udtf_json_tuple.q │ │ │ │ ├── udtf_parse_url_tuple.q │ │ │ │ ├── udtf_posexplode.q │ │ │ │ ├── udtf_stack.q │ │ │ │ ├── unicode_notation.q │ │ │ │ ├── union.q │ │ │ │ ├── union10.q │ │ │ │ ├── union11.q │ │ │ │ ├── union12.q │ │ │ │ ├── union13.q │ │ │ │ ├── union14.q │ │ │ │ ├── union15.q │ │ │ │ ├── union16.q │ │ │ │ ├── union17.q │ │ │ │ ├── union18.q │ │ │ │ ├── union19.q │ │ │ │ ├── union2.q │ │ │ │ ├── union20.q │ │ │ │ ├── union21.q │ │ │ │ ├── union22.q │ │ │ │ ├── union23.q │ │ │ │ ├── union24.q │ │ │ │ ├── union25.q │ │ │ │ ├── union26.q │ │ │ │ ├── union27.q │ │ │ │ ├── union28.q │ │ │ │ ├── union29.q │ │ │ │ ├── union3.q │ │ │ │ ├── union30.q │ │ │ │ ├── union31.q │ │ │ │ ├── union32.q │ │ │ │ ├── union33.q │ │ │ │ ├── union34.q │ │ │ │ ├── union4.q │ │ │ │ ├── union5.q │ │ │ │ ├── union6.q │ │ │ │ ├── union7.q │ │ │ │ ├── union8.q │ │ │ │ ├── union9.q │ │ │ │ ├── union_date.q │ │ │ │ ├── union_lateralview.q │ │ │ │ ├── union_null.q │ │ │ │ ├── union_ppr.q │ │ │ │ ├── union_remove_1.q │ │ │ │ ├── union_remove_10.q │ │ │ │ ├── union_remove_11.q │ │ │ │ ├── union_remove_12.q │ │ │ │ ├── union_remove_13.q │ │ │ │ ├── union_remove_14.q │ │ │ │ ├── union_remove_15.q │ │ │ │ ├── union_remove_16.q │ │ │ │ ├── union_remove_17.q │ │ │ │ ├── union_remove_18.q │ │ │ │ ├── union_remove_19.q │ │ │ │ ├── union_remove_2.q │ │ │ │ ├── union_remove_20.q │ │ │ │ ├── union_remove_21.q │ │ │ │ ├── union_remove_22.q │ │ │ │ ├── union_remove_23.q │ │ │ │ ├── union_remove_24.q │ │ │ │ ├── union_remove_3.q │ │ │ │ ├── union_remove_4.q │ │ │ │ ├── union_remove_5.q │ │ │ │ ├── union_remove_6.q │ │ │ │ ├── union_remove_7.q │ │ │ │ ├── union_remove_8.q │ │ │ │ ├── union_remove_9.q │ │ │ │ ├── union_script.q │ │ │ │ ├── union_top_level.q │ │ │ │ ├── union_view.q │ │ │ │ ├── uniquejoin.q │ │ │ │ ├── unset_table_view_property.q │ │ │ │ ├── updateAccessTime.q │ │ │ │ ├── varchar_1.q │ │ │ │ ├── varchar_2.q │ │ │ │ ├── varchar_cast.q │ │ │ │ ├── varchar_comparison.q │ │ │ │ ├── varchar_join1.q │ │ │ │ ├── varchar_nested_types.q │ │ │ │ ├── varchar_serde.q │ │ │ │ ├── varchar_udf1.q │ │ │ │ ├── varchar_union1.q │ │ │ │ ├── vector_between_in.q │ │ │ │ ├── vector_coalesce.q │ │ │ │ ├── vector_decimal_aggregate.q │ │ │ │ ├── vector_decimal_cast.q │ │ │ │ ├── vector_decimal_expressions.q │ │ │ │ ├── vector_decimal_mapjoin.q │ │ │ │ ├── vector_decimal_math_funcs.q │ │ │ │ ├── vector_left_outer_join.q │ │ │ │ ├── vector_non_string_partition.q │ │ │ │ ├── vectorization_0.q │ │ │ │ ├── vectorization_1.q │ │ │ │ ├── vectorization_10.q │ │ │ │ ├── vectorization_11.q │ │ │ │ ├── vectorization_12.q │ │ │ │ ├── vectorization_13.q │ │ │ │ ├── vectorization_14.q │ │ │ │ ├── vectorization_15.q │ │ │ │ ├── vectorization_16.q │ │ │ │ ├── vectorization_2.q │ │ │ │ ├── vectorization_3.q │ │ │ │ ├── vectorization_4.q │ │ │ │ ├── vectorization_5.q │ │ │ │ ├── vectorization_6.q │ │ │ │ ├── vectorization_7.q │ │ │ │ ├── vectorization_8.q │ │ │ │ ├── vectorization_9.q │ │ │ │ ├── vectorization_decimal_date.q │ │ │ │ ├── vectorization_div0.q │ │ │ │ ├── vectorization_limit.q │ │ │ │ ├── vectorization_nested_udf.q │ │ │ │ ├── vectorization_not.q │ │ │ │ ├── vectorization_part.q │ │ │ │ ├── vectorization_part_project.q │ │ │ │ ├── vectorization_pushdown.q │ │ │ │ ├── vectorization_short_regress.q │ │ │ │ ├── vectorized_bucketmapjoin1.q │ │ │ │ ├── vectorized_case.q │ │ │ │ ├── vectorized_casts.q │ │ │ │ ├── vectorized_context.q │ │ │ │ ├── vectorized_date_funcs.q │ │ │ │ ├── vectorized_distinct_gby.q │ │ │ │ ├── vectorized_mapjoin.q │ │ │ │ ├── vectorized_math_funcs.q │ │ │ │ ├── vectorized_nested_mapjoin.q │ │ │ │ ├── vectorized_rcfile_columnar.q │ │ │ │ ├── vectorized_shufflejoin.q │ │ │ │ ├── vectorized_string_funcs.q │ │ │ │ ├── vectorized_timestamp_funcs.q │ │ │ │ ├── view.q │ │ │ │ ├── view_cast.q │ │ │ │ ├── view_inputs.q │ │ │ │ ├── virtual_column.q │ │ │ │ ├── windowing.q │ │ │ │ ├── windowing_adjust_rowcontainer_sz.q │ │ │ │ ├── windowing_columnPruning.q │ │ │ │ ├── windowing_expressions.q │ │ │ │ ├── windowing_multipartitioning.q │ │ │ │ ├── windowing_navfn.q │ │ │ │ ├── windowing_ntile.q │ │ │ │ ├── windowing_rank.q │ │ │ │ ├── windowing_udaf.q │ │ │ │ ├── windowing_udaf2.q │ │ │ │ └── windowing_windowspec.q │ │ ├── regression-test-SPARK-8489 │ │ │ ├── Main.scala │ │ │ ├── MyCoolClass.scala │ │ │ └── test-2.13.jar │ │ ├── sample.json │ │ ├── schemaWithOneField.avsc │ │ ├── schemaWithTwoFields.avsc │ │ └── test-script.sh │ │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ ├── execution │ │ └── benchmark │ │ │ ├── InsertIntoHiveTableBenchmark.scala │ │ │ └── ObjectHashAggregateExecBenchmark.scala │ │ ├── hive │ │ ├── CachedTableSuite.scala │ │ ├── ClasspathDependenciesSuite.scala │ │ ├── CompressionCodecSuite.scala │ │ ├── DynamicPartitionPruningHiveScanSuite.scala │ │ ├── ErrorPositionSuite.scala │ │ ├── HiveCharVarcharTestSuite.scala │ │ ├── HiveContextCompatibilitySuite.scala │ │ ├── HiveExternalCatalogSuite.scala │ │ ├── HiveExternalCatalogVersionsSuite.scala │ │ ├── HiveExternalSessionCatalogSuite.scala │ │ ├── HiveInspectorSuite.scala │ │ ├── HiveMetadataCacheSuite.scala │ │ ├── HiveMetastoreCatalogSuite.scala │ │ ├── HiveParquetMetastoreSuite.scala │ │ ├── HiveParquetSourceSuite.scala │ │ ├── HiveParquetSuite.scala │ │ ├── HiveSQLInsertTestSuite.scala │ │ ├── HiveScalaReflectionSuite.scala │ │ ├── HiveSchemaInferenceSuite.scala │ │ ├── HiveSessionStateSuite.scala │ │ ├── HiveSharedStateSuite.scala │ │ ├── HiveShimSuite.scala │ │ ├── HiveSparkSubmitSuite.scala │ │ ├── HiveTableRelationResolverSuite.scala │ │ ├── HiveUDFDynamicLoadSuite.scala │ │ ├── HiveUserDefinedTypeSuite.scala │ │ ├── HiveUtilsSuite.scala │ │ ├── HiveVariableSubstitutionSuite.scala │ │ ├── InsertSuite.scala │ │ ├── ListTablesSuite.scala │ │ ├── MetastoreDataSourcesSuite.scala │ │ ├── MultiDatabaseSuite.scala │ │ ├── OptimizeHiveMetadataOnlyQuerySuite.scala │ │ ├── ParquetEncryptionSuite.scala │ │ ├── ParquetHiveCompatibilitySuite.scala │ │ ├── ParquetPartitioningTest.scala │ │ ├── PartitionProviderCompatibilitySuite.scala │ │ ├── PartitionedTablePerfStatsSuite.scala │ │ ├── QueryPartitionSuite.scala │ │ ├── StatisticsSuite.scala │ │ ├── TestHiveSuite.scala │ │ ├── UDFSuite.scala │ │ ├── client │ │ │ ├── FiltersSuite.scala │ │ │ ├── HadoopVersionInfoSuite.scala │ │ │ ├── HiveClientBuilder.scala │ │ │ ├── HiveClientSuite.scala │ │ │ ├── HiveClientSuites.scala │ │ │ ├── HiveClientUserNameSuite.scala │ │ │ ├── HiveClientUserNameSuites.scala │ │ │ ├── HiveClientVersions.scala │ │ │ ├── HivePartitionFilteringSuite.scala │ │ │ ├── HivePartitionFilteringSuites.scala │ │ │ └── HiveVersionSuite.scala │ │ ├── connector │ │ │ └── HiveSourceRowLevelOperationSuite.scala │ │ ├── execution │ │ │ ├── AggregationQuerySuite.scala │ │ │ ├── BigDataBenchmarkSuite.scala │ │ │ ├── ConcurrentHiveSuite.scala │ │ │ ├── HiveCommandSuite.scala │ │ │ ├── HiveComparisonTest.scala │ │ │ ├── HiveDDLSuite.scala │ │ │ ├── HiveExplainSuite.scala │ │ │ ├── HiveIncompatibleColTypeChangeSuite.scala │ │ │ ├── HivePlanTest.scala │ │ │ ├── HiveQueryFileTest.scala │ │ │ ├── HiveQuerySuite.scala │ │ │ ├── HiveResolutionSuite.scala │ │ │ ├── HiveSQLViewSuite.scala │ │ │ ├── HiveScriptTransformationSuite.scala │ │ │ ├── HiveSerDeReadWriteSuite.scala │ │ │ ├── HiveSerDeSuite.scala │ │ │ ├── HiveTableScanSuite.scala │ │ │ ├── HiveTypeCoercionSuite.scala │ │ │ ├── HiveUDAFSuite.scala │ │ │ ├── HiveUDFSuite.scala │ │ │ ├── ObjectHashAggregateSuite.scala │ │ │ ├── PruneHiveTablePartitionsSuite.scala │ │ │ ├── PruningSuite.scala │ │ │ ├── SQLMetricsSuite.scala │ │ │ ├── SQLQuerySuite.scala │ │ │ ├── TestingTypedCount.scala │ │ │ ├── UDAQuerySuite.scala │ │ │ ├── WindowQuerySuite.scala │ │ │ └── command │ │ │ │ ├── AlterNamespaceSetLocationSuite.scala │ │ │ │ ├── AlterNamespaceSetPropertiesSuite.scala │ │ │ │ ├── AlterNamespaceUnsetPropertiesSuite.scala │ │ │ │ ├── AlterTableAddColumnsSuite.scala │ │ │ │ ├── AlterTableAddPartitionSuite.scala │ │ │ │ ├── AlterTableClusterBySuite.scala │ │ │ │ ├── AlterTableDropColumnSuite.scala │ │ │ │ ├── AlterTableDropPartitionSuite.scala │ │ │ │ ├── AlterTableRecoverPartitionsSuite.scala │ │ │ │ ├── AlterTableRenameColumnSuite.scala │ │ │ │ ├── AlterTableRenamePartitionSuite.scala │ │ │ │ ├── AlterTableRenameSuite.scala │ │ │ │ ├── AlterTableSetLocationSuite.scala │ │ │ │ ├── AlterTableSetSerdeSuite.scala │ │ │ │ ├── AlterTableSetTblPropertiesSuite.scala │ │ │ │ ├── AlterTableUnsetTblPropertiesSuite.scala │ │ │ │ ├── CommandSuiteBase.scala │ │ │ │ ├── CreateNamespaceSuite.scala │ │ │ │ ├── CreateTableClusterBySuite.scala │ │ │ │ ├── DescribeNamespaceSuite.scala │ │ │ │ ├── DescribeTableSuite.scala │ │ │ │ ├── DropNamespaceSuite.scala │ │ │ │ ├── DropTableSuite.scala │ │ │ │ ├── MsckRepairTableSuite.scala │ │ │ │ ├── ShowColumnsSuite.scala │ │ │ │ ├── ShowCreateTableSuite.scala │ │ │ │ ├── ShowFunctionsSuite.scala │ │ │ │ ├── ShowNamespacesSuite.scala │ │ │ │ ├── ShowPartitionsSuite.scala │ │ │ │ ├── ShowTablesSuite.scala │ │ │ │ ├── ShowTblPropertiesSuite.scala │ │ │ │ ├── TruncateTableSuite.scala │ │ │ │ └── V1WriteHiveCommandSuite.scala │ │ ├── orc │ │ │ ├── HiveOrcPartitionDiscoverySuite.scala │ │ │ ├── HiveOrcQuerySuite.scala │ │ │ ├── HiveOrcSourceSuite.scala │ │ │ ├── OrcHadoopFsRelationSuite.scala │ │ │ └── OrcReadBenchmark.scala │ │ ├── pipelines │ │ │ └── HiveMaterializeTablesSuite.scala │ │ ├── security │ │ │ └── HiveHadoopDelegationTokenManagerSuite.scala │ │ └── test │ │ │ ├── TestHive.scala │ │ │ └── TestHiveSingleton.scala │ │ └── sources │ │ ├── BucketedReadWithHiveSupportSuite.scala │ │ ├── BucketedWriteWithHiveSupportSuite.scala │ │ ├── CommitFailureTestRelationSuite.scala │ │ ├── CommitFailureTestSource.scala │ │ ├── DisableUnnecessaryBucketedScanWithHiveSupportSuite.scala │ │ ├── HadoopFsRelationTest.scala │ │ ├── JsonHadoopFsRelationSuite.scala │ │ ├── ParquetHadoopFsRelationSuite.scala │ │ ├── SimpleTextHadoopFsRelationSuite.scala │ │ └── SimpleTextRelation.scala ├── mkdocs.yml └── pipelines │ ├── pom.xml │ └── src │ ├── main │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ └── sql │ │ └── pipelines │ │ ├── AnalysisWarning.scala │ │ ├── Language.scala │ │ ├── common │ │ └── GraphStates.scala │ │ ├── graph │ │ ├── CoreDataflowNodeProcessor.scala │ │ ├── DataflowGraph.scala │ │ ├── DataflowGraphTransformer.scala │ │ ├── DatasetManager.scala │ │ ├── Flow.scala │ │ ├── FlowAnalysis.scala │ │ ├── FlowAnalysisContext.scala │ │ ├── FlowExecution.scala │ │ ├── FlowPlanner.scala │ │ ├── GraphElementTypeUtils.scala │ │ ├── GraphErrors.scala │ │ ├── GraphExecution.scala │ │ ├── GraphFilter.scala │ │ ├── GraphIdentifierManager.scala │ │ ├── GraphOperations.scala │ │ ├── GraphRegistrationContext.scala │ │ ├── GraphValidations.scala │ │ ├── PipelineExecution.scala │ │ ├── PipelineUpdateContext.scala │ │ ├── PipelineUpdateContextImpl.scala │ │ ├── PipelinesErrors.scala │ │ ├── PipelinesTableProperties.scala │ │ ├── QueryOrigin.scala │ │ ├── QueryOriginType.scala │ │ ├── RunTerminationReason.scala │ │ ├── SqlGraphRegistrationContext.scala │ │ ├── State.scala │ │ ├── SystemMetadata.scala │ │ ├── TriggeredGraphExecution.scala │ │ ├── UncaughtExceptionHandler.scala │ │ ├── ViewHelpers.scala │ │ └── elements.scala │ │ ├── logging │ │ ├── ConstructPipelineEvent.scala │ │ ├── FlowProgressEventLogger.scala │ │ ├── PipelineEvent.scala │ │ └── StreamListener.scala │ │ └── util │ │ ├── BackoffStrategy.scala │ │ ├── InputReadInfo.scala │ │ ├── SchemaInferenceUtils.scala │ │ ├── SchemaMergingUtils.scala │ │ └── SparkSessionUtils.scala │ └── test │ ├── resources │ └── log4j2.properties │ └── scala │ └── org │ └── apache │ └── spark │ └── sql │ └── pipelines │ ├── graph │ ├── ConnectInvalidPipelineSuite.scala │ ├── ConnectValidPipelineSuite.scala │ ├── MaterializeTablesSuite.scala │ ├── PipelineUpdateContextImplSuite.scala │ ├── SinkExecutionSuite.scala │ ├── SqlPipelineSuite.scala │ ├── SqlQueryOriginSuite.scala │ ├── SystemMetadataSuite.scala │ ├── TriggeredGraphExecutionSuite.scala │ └── ViewSuite.scala │ ├── logging │ └── ConstructPipelineEventSuite.scala │ ├── util │ └── SchemaInferenceUtilsSuite.scala │ └── utils │ ├── APITest.scala │ ├── BaseCoreExecutionTest.scala │ ├── ExecutionTest.scala │ ├── PipelineRunEventBuffer.scala │ ├── PipelineTest.scala │ ├── SparkErrorTestMixin.scala │ ├── StorageRootMixin.scala │ └── TestGraphRegistrationContext.scala ├── streaming ├── pom.xml └── src │ ├── main │ ├── java │ │ └── org │ │ │ └── apache │ │ │ └── spark │ │ │ ├── status │ │ │ └── api │ │ │ │ └── v1 │ │ │ │ └── streaming │ │ │ │ └── BatchStatus.java │ │ │ └── streaming │ │ │ ├── StreamingContextState.java │ │ │ └── util │ │ │ ├── WriteAheadLog.java │ │ │ └── WriteAheadLogRecordHandle.java │ └── scala │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── status │ │ └── api │ │ │ └── v1 │ │ │ └── streaming │ │ │ ├── ApiStreamingApp.scala │ │ │ ├── ApiStreamingRootResource.scala │ │ │ └── api.scala │ │ └── streaming │ │ ├── Checkpoint.scala │ │ ├── ContextWaiter.scala │ │ ├── DStreamGraph.scala │ │ ├── Duration.scala │ │ ├── Interval.scala │ │ ├── State.scala │ │ ├── StateSpec.scala │ │ ├── StreamingConf.scala │ │ ├── StreamingContext.scala │ │ ├── StreamingSource.scala │ │ ├── Time.scala │ │ ├── api │ │ ├── java │ │ │ ├── JavaDStream.scala │ │ │ ├── JavaDStreamLike.scala │ │ │ ├── JavaInputDStream.scala │ │ │ ├── JavaMapWithStateDStream.scala │ │ │ ├── JavaPairDStream.scala │ │ │ ├── JavaPairInputDStream.scala │ │ │ ├── JavaPairReceiverInputDStream.scala │ │ │ ├── JavaReceiverInputDStream.scala │ │ │ ├── JavaStreamingContext.scala │ │ │ ├── JavaStreamingListener.scala │ │ │ ├── JavaStreamingListenerWrapper.scala │ │ │ ├── package-info.java │ │ │ └── package.scala │ │ └── python │ │ │ └── PythonDStream.scala │ │ ├── dstream │ │ ├── ConstantInputDStream.scala │ │ ├── DStream.scala │ │ ├── DStreamCheckpointData.scala │ │ ├── FileInputDStream.scala │ │ ├── FilteredDStream.scala │ │ ├── FlatMapValuedDStream.scala │ │ ├── FlatMappedDStream.scala │ │ ├── ForEachDStream.scala │ │ ├── GlommedDStream.scala │ │ ├── InputDStream.scala │ │ ├── MapPartitionedDStream.scala │ │ ├── MapValuedDStream.scala │ │ ├── MapWithStateDStream.scala │ │ ├── MappedDStream.scala │ │ ├── PairDStreamFunctions.scala │ │ ├── PluggableInputDStream.scala │ │ ├── QueueInputDStream.scala │ │ ├── RawInputDStream.scala │ │ ├── ReceiverInputDStream.scala │ │ ├── ReducedWindowedDStream.scala │ │ ├── ShuffledDStream.scala │ │ ├── SocketInputDStream.scala │ │ ├── StateDStream.scala │ │ ├── TransformedDStream.scala │ │ ├── UnionDStream.scala │ │ ├── WindowedDStream.scala │ │ ├── package-info.java │ │ └── package.scala │ │ ├── package.scala │ │ ├── rdd │ │ ├── MapWithStateRDD.scala │ │ └── WriteAheadLogBackedBlockRDD.scala │ │ ├── receiver │ │ ├── BlockGenerator.scala │ │ ├── RateLimiter.scala │ │ ├── ReceivedBlock.scala │ │ ├── ReceivedBlockHandler.scala │ │ ├── Receiver.scala │ │ ├── ReceiverMessage.scala │ │ ├── ReceiverSupervisor.scala │ │ └── ReceiverSupervisorImpl.scala │ │ ├── scheduler │ │ ├── BatchInfo.scala │ │ ├── ExecutorAllocationManager.scala │ │ ├── InputInfoTracker.scala │ │ ├── Job.scala │ │ ├── JobGenerator.scala │ │ ├── JobScheduler.scala │ │ ├── JobSet.scala │ │ ├── OutputOperationInfo.scala │ │ ├── RateController.scala │ │ ├── ReceivedBlockInfo.scala │ │ ├── ReceivedBlockTracker.scala │ │ ├── ReceiverInfo.scala │ │ ├── ReceiverSchedulingPolicy.scala │ │ ├── ReceiverTracker.scala │ │ ├── ReceiverTrackingInfo.scala │ │ ├── StreamingListener.scala │ │ ├── StreamingListenerBus.scala │ │ └── rate │ │ │ ├── PIDRateEstimator.scala │ │ │ └── RateEstimator.scala │ │ ├── ui │ │ ├── AllBatchesTable.scala │ │ ├── BatchPage.scala │ │ ├── BatchUIData.scala │ │ ├── StreamingJobProgressListener.scala │ │ ├── StreamingPage.scala │ │ ├── StreamingTab.scala │ │ └── UIUtils.scala │ │ └── util │ │ ├── BatchedWriteAheadLog.scala │ │ ├── FileBasedWriteAheadLog.scala │ │ ├── FileBasedWriteAheadLogRandomReader.scala │ │ ├── FileBasedWriteAheadLogReader.scala │ │ ├── FileBasedWriteAheadLogSegment.scala │ │ ├── FileBasedWriteAheadLogWriter.scala │ │ ├── HdfsUtils.scala │ │ ├── RateLimitedOutputStream.scala │ │ ├── RawTextHelper.scala │ │ ├── RawTextSender.scala │ │ ├── RecurringTimer.scala │ │ ├── StateMap.scala │ │ └── WriteAheadLogUtils.scala │ └── test │ ├── java │ ├── org │ │ └── apache │ │ │ └── spark │ │ │ └── streaming │ │ │ ├── JavaDurationSuite.java │ │ │ ├── JavaMapWithStateSuite.java │ │ │ ├── JavaReceiverAPISuite.java │ │ │ ├── JavaStreamingListenerAPISuite.java │ │ │ ├── JavaTimeSuite.java │ │ │ ├── JavaWriteAheadLogSuite.java │ │ │ └── LocalJavaStreamingContext.java │ └── test │ │ └── org │ │ └── apache │ │ └── spark │ │ └── streaming │ │ ├── Java8APISuite.java │ │ └── JavaAPISuite.java │ ├── resources │ └── log4j2.properties │ └── scala │ └── org │ └── apache │ └── spark │ ├── streaming │ ├── BasicOperationsSuite.scala │ ├── CheckpointSuite.scala │ ├── DStreamClosureSuite.scala │ ├── DStreamScopeSuite.scala │ ├── DurationSuite.scala │ ├── FailureSuite.scala │ ├── InputStreamsSuite.scala │ ├── JavaTestUtils.scala │ ├── LocalStreamingContext.scala │ ├── MapWithStateSuite.scala │ ├── MasterFailureTest.scala │ ├── ReceivedBlockHandlerSuite.scala │ ├── ReceivedBlockTrackerSuite.scala │ ├── ReceiverInputDStreamSuite.scala │ ├── ReceiverSuite.scala │ ├── StateMapSuite.scala │ ├── StreamingContextSuite.scala │ ├── StreamingListenerSuite.scala │ ├── TestSuiteBase.scala │ ├── TimeSuite.scala │ ├── UISeleniumSuite.scala │ ├── WindowOperationsSuite.scala │ ├── api │ │ └── java │ │ │ └── JavaStreamingListenerWrapperSuite.scala │ ├── rdd │ │ ├── MapWithStateRDDSuite.scala │ │ └── WriteAheadLogBackedBlockRDDSuite.scala │ ├── receiver │ │ ├── BlockGeneratorSuite.scala │ │ └── RateLimiterSuite.scala │ ├── scheduler │ │ ├── ExecutorAllocationManagerSuite.scala │ │ ├── InputInfoTrackerSuite.scala │ │ ├── JobGeneratorSuite.scala │ │ ├── RateControllerSuite.scala │ │ ├── ReceiverSchedulingPolicySuite.scala │ │ ├── ReceiverTrackerSuite.scala │ │ └── rate │ │ │ └── PIDRateEstimatorSuite.scala │ ├── ui │ │ ├── StreamingJobProgressListenerSuite.scala │ │ └── UIUtilsSuite.scala │ └── util │ │ ├── RateLimitedOutputStreamSuite.scala │ │ ├── RecurringTimerSuite.scala │ │ ├── WriteAheadLogSuite.scala │ │ └── WriteAheadLogUtilsSuite.scala │ └── streamingtest │ └── ImplicitSuite.scala ├── tools ├── pom.xml └── src │ └── main │ └── scala │ └── org │ └── apache │ └── spark │ └── tools │ └── GenerateMIMAIgnore.scala └── ui-test ├── package-lock.json ├── package.json └── tests ├── flamegraph.test.js ├── scroll-button.test.js ├── structured-streaming-page.test.js └── utils.test.js /.asf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/.asf.yaml -------------------------------------------------------------------------------- /.gitattributes: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/.gitattributes -------------------------------------------------------------------------------- /.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/.gitignore -------------------------------------------------------------------------------- /.mvn/jvm.config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/.mvn/jvm.config -------------------------------------------------------------------------------- /.mvn/maven.config: -------------------------------------------------------------------------------- 1 | -Dnisse.compat.osDetector 2 | -------------------------------------------------------------------------------- /.nojekyll: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /CONTRIBUTING.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/CONTRIBUTING.md -------------------------------------------------------------------------------- /LICENSE: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/LICENSE -------------------------------------------------------------------------------- /LICENSE-binary: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/LICENSE-binary -------------------------------------------------------------------------------- /NOTICE: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/NOTICE -------------------------------------------------------------------------------- /NOTICE-binary: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/NOTICE-binary -------------------------------------------------------------------------------- /R/.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/.gitignore -------------------------------------------------------------------------------- /R/CRAN_RELEASE.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/CRAN_RELEASE.md -------------------------------------------------------------------------------- /R/WINDOWS.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/WINDOWS.md -------------------------------------------------------------------------------- /R/check-cran.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/check-cran.sh -------------------------------------------------------------------------------- /R/create-docs.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/create-docs.sh -------------------------------------------------------------------------------- /R/create-rd.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/create-rd.sh -------------------------------------------------------------------------------- /R/find-r.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/find-r.sh -------------------------------------------------------------------------------- /R/install-dev.bat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/install-dev.bat -------------------------------------------------------------------------------- /R/install-dev.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/install-dev.sh -------------------------------------------------------------------------------- /R/pkg/.gitignore: -------------------------------------------------------------------------------- 1 | docs 2 | -------------------------------------------------------------------------------- /R/pkg/.lintr: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/.lintr -------------------------------------------------------------------------------- /R/pkg/DESCRIPTION: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/DESCRIPTION -------------------------------------------------------------------------------- /R/pkg/NAMESPACE: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/NAMESPACE -------------------------------------------------------------------------------- /R/pkg/R/RDD.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/RDD.R -------------------------------------------------------------------------------- /R/pkg/R/backend.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/backend.R -------------------------------------------------------------------------------- /R/pkg/R/catalog.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/catalog.R -------------------------------------------------------------------------------- /R/pkg/R/client.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/client.R -------------------------------------------------------------------------------- /R/pkg/R/column.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/column.R -------------------------------------------------------------------------------- /R/pkg/R/context.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/context.R -------------------------------------------------------------------------------- /R/pkg/R/group.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/group.R -------------------------------------------------------------------------------- /R/pkg/R/install.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/install.R -------------------------------------------------------------------------------- /R/pkg/R/jobj.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/jobj.R -------------------------------------------------------------------------------- /R/pkg/R/jvm.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/jvm.R -------------------------------------------------------------------------------- /R/pkg/R/pairRDD.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/pairRDD.R -------------------------------------------------------------------------------- /R/pkg/R/schema.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/schema.R -------------------------------------------------------------------------------- /R/pkg/R/sparkR.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/sparkR.R -------------------------------------------------------------------------------- /R/pkg/R/stats.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/stats.R -------------------------------------------------------------------------------- /R/pkg/R/types.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/types.R -------------------------------------------------------------------------------- /R/pkg/R/utils.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/utils.R -------------------------------------------------------------------------------- /R/pkg/R/window.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/window.R -------------------------------------------------------------------------------- /R/pkg/R/zzz.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/R/zzz.R -------------------------------------------------------------------------------- /R/pkg/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/pkg/README.md -------------------------------------------------------------------------------- /R/run-tests.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/R/run-tests.sh -------------------------------------------------------------------------------- /README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/README.md -------------------------------------------------------------------------------- /assembly/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/assembly/pom.xml -------------------------------------------------------------------------------- /bin/beeline: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/beeline -------------------------------------------------------------------------------- /bin/beeline.cmd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/beeline.cmd -------------------------------------------------------------------------------- /bin/pyspark: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/pyspark -------------------------------------------------------------------------------- /bin/pyspark.cmd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/pyspark.cmd -------------------------------------------------------------------------------- /bin/pyspark2.cmd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/pyspark2.cmd -------------------------------------------------------------------------------- /bin/run-example: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/run-example -------------------------------------------------------------------------------- /bin/spark-class: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/spark-class -------------------------------------------------------------------------------- /bin/spark-shell: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/spark-shell -------------------------------------------------------------------------------- /bin/spark-sql: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/spark-sql -------------------------------------------------------------------------------- /bin/spark-sql.cmd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/spark-sql.cmd -------------------------------------------------------------------------------- /bin/spark-submit: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/spark-submit -------------------------------------------------------------------------------- /bin/sparkR: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/sparkR -------------------------------------------------------------------------------- /bin/sparkR.cmd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/sparkR.cmd -------------------------------------------------------------------------------- /bin/sparkR2.cmd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/bin/sparkR2.cmd -------------------------------------------------------------------------------- /binder/Dockerfile: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/binder/Dockerfile -------------------------------------------------------------------------------- /binder/postBuild: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/binder/postBuild -------------------------------------------------------------------------------- /core/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/core/pom.xml -------------------------------------------------------------------------------- /data/artifact-tests/crc/smallJar.txt: -------------------------------------------------------------------------------- 1 | 1631702900 -------------------------------------------------------------------------------- /data/mllib/images/origin/kittens/not-image.txt: -------------------------------------------------------------------------------- 1 | not an image 2 | -------------------------------------------------------------------------------- /dev/.rat-excludes: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/.rat-excludes -------------------------------------------------------------------------------- /dev/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/README.md -------------------------------------------------------------------------------- /dev/check-license: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/check-license -------------------------------------------------------------------------------- /dev/eslint.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/eslint.js -------------------------------------------------------------------------------- /dev/gen-protos.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/gen-protos.sh -------------------------------------------------------------------------------- /dev/is-changed.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/is-changed.py -------------------------------------------------------------------------------- /dev/lint-java: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/lint-java -------------------------------------------------------------------------------- /dev/lint-js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/lint-js -------------------------------------------------------------------------------- /dev/lint-python: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/lint-python -------------------------------------------------------------------------------- /dev/lint-r: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/lint-r -------------------------------------------------------------------------------- /dev/lint-r.R: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/lint-r.R -------------------------------------------------------------------------------- /dev/lint-scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/lint-scala -------------------------------------------------------------------------------- /dev/mima: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/mima -------------------------------------------------------------------------------- /dev/package.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/package.json -------------------------------------------------------------------------------- /dev/py-cleanup: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/py-cleanup -------------------------------------------------------------------------------- /dev/run-pip-tests: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/run-pip-tests -------------------------------------------------------------------------------- /dev/run-tests: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/run-tests -------------------------------------------------------------------------------- /dev/run-tests.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/run-tests.py -------------------------------------------------------------------------------- /dev/scalafmt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/scalafmt -------------------------------------------------------------------------------- /dev/scalastyle: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/scalastyle -------------------------------------------------------------------------------- /dev/test-jars.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/test-jars.txt -------------------------------------------------------------------------------- /dev/tox.ini: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/dev/tox.ini -------------------------------------------------------------------------------- /docs/.gitignore: -------------------------------------------------------------------------------- 1 | generated-*.html 2 | -------------------------------------------------------------------------------- /docs/404.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/404.md -------------------------------------------------------------------------------- /docs/Gemfile: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/Gemfile -------------------------------------------------------------------------------- /docs/Gemfile.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/Gemfile.lock -------------------------------------------------------------------------------- /docs/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/README.md -------------------------------------------------------------------------------- /docs/_config.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/_config.yml -------------------------------------------------------------------------------- /docs/index.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/index.md -------------------------------------------------------------------------------- /docs/js/main.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/js/main.js -------------------------------------------------------------------------------- /docs/ml-ann.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/ml-ann.md -------------------------------------------------------------------------------- /docs/ml-guide.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/ml-guide.md -------------------------------------------------------------------------------- /docs/ml-tuning.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/ml-tuning.md -------------------------------------------------------------------------------- /docs/security.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/security.md -------------------------------------------------------------------------------- /docs/sparkr.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/sparkr.md -------------------------------------------------------------------------------- /docs/sql-ref.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/sql-ref.md -------------------------------------------------------------------------------- /docs/tuning.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/tuning.md -------------------------------------------------------------------------------- /docs/web-ui.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/docs/web-ui.md -------------------------------------------------------------------------------- /examples/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/examples/pom.xml -------------------------------------------------------------------------------- /examples/src/main/resources/dir1/file3.json: -------------------------------------------------------------------------------- 1 | {"file":"corrupt.json"} 2 | -------------------------------------------------------------------------------- /examples/src/main/resources/people.txt: -------------------------------------------------------------------------------- 1 | Michael, 29 2 | Andy, 30 3 | Justin, 19 4 | -------------------------------------------------------------------------------- /graphx/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/graphx/pom.xml -------------------------------------------------------------------------------- /launcher/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/launcher/pom.xml -------------------------------------------------------------------------------- /mllib/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/mllib/pom.xml -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtc-2.4.7/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtc-2.4.7/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtc-2.4.7/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtc-2.4.7/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtr-2.4.7/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtr-2.4.7/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtr-2.4.7/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/dtr-2.4.7/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtc-2.4.7/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtc-2.4.7/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtc-2.4.7/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtc-2.4.7/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtc-2.4.7/treesMetadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtc-2.4.7/treesMetadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtr-2.4.7/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtr-2.4.7/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtr-2.4.7/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtr-2.4.7/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtr-2.4.7/treesMetadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/gbtr-2.4.7/treesMetadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/hashingTF-2.4.4/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/hashingTF-2.4.4/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/mlp-2.4.4/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/mlp-2.4.4/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/mlp-2.4.4/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/mlp-2.4.4/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfc-2.4.7/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfc-2.4.7/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfc-2.4.7/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfc-2.4.7/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfc-2.4.7/treesMetadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfc-2.4.7/treesMetadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfr-2.4.7/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfr-2.4.7/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfr-2.4.7/metadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfr-2.4.7/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfr-2.4.7/treesMetadata/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/rfr-2.4.7/treesMetadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/strIndexerModel-2.4.4/data/._SUCCESS.crc: -------------------------------------------------------------------------------- 1 | crc -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/strIndexerModel-2.4.4/data/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /mllib/src/test/resources/ml-models/strIndexerModel-2.4.4/metadata/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/pom.xml -------------------------------------------------------------------------------- /python/.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/python/.gitignore -------------------------------------------------------------------------------- /python/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/python/README.md -------------------------------------------------------------------------------- /python/mypy.ini: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/python/mypy.ini -------------------------------------------------------------------------------- /python/pyspark/py.typed: -------------------------------------------------------------------------------- 1 | partial 2 | -------------------------------------------------------------------------------- /python/run-tests: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/python/run-tests -------------------------------------------------------------------------------- /python/test_support/hello/hello.txt: -------------------------------------------------------------------------------- 1 | Hello World! 2 | -------------------------------------------------------------------------------- /python/test_support/hello/sub_hello/sub_hello.txt: -------------------------------------------------------------------------------- 1 | Sub Hello World! 2 | -------------------------------------------------------------------------------- /python/test_support/sql/orc_partitioned/_SUCCESS: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /python/test_support/sql/people1.json: -------------------------------------------------------------------------------- 1 | {"name":"Jonathan", "aka": "John"} 2 | 3 | -------------------------------------------------------------------------------- /python/test_support/sql/streaming/text-test.txt: -------------------------------------------------------------------------------- 1 | hello 2 | this -------------------------------------------------------------------------------- /python/test_support/sql/text-test.txt: -------------------------------------------------------------------------------- 1 | hello 2 | this -------------------------------------------------------------------------------- /repl/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/repl/pom.xml -------------------------------------------------------------------------------- /sbin/start-all.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sbin/start-all.sh -------------------------------------------------------------------------------- /sbin/stop-all.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sbin/stop-all.sh -------------------------------------------------------------------------------- /sbin/workers.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sbin/workers.sh -------------------------------------------------------------------------------- /sql/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sql/README.md -------------------------------------------------------------------------------- /sql/api/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sql/api/pom.xml -------------------------------------------------------------------------------- /sql/connect/common/src/test/resources/artifact-tests/crc/Hello.txt: -------------------------------------------------------------------------------- 1 | 553633018 -------------------------------------------------------------------------------- /sql/connect/common/src/test/resources/artifact-tests/crc/smallJar.txt: -------------------------------------------------------------------------------- 1 | 1631702900 -------------------------------------------------------------------------------- /sql/core/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sql/core/pom.xml -------------------------------------------------------------------------------- /sql/core/src/test/resources/sql-tests/inputs/nonansi/array.sql: -------------------------------------------------------------------------------- 1 | --IMPORT array.sql -------------------------------------------------------------------------------- /sql/core/src/test/resources/sql-tests/inputs/nonansi/cast.sql: -------------------------------------------------------------------------------- 1 | --IMPORT cast.sql 2 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/sql-tests/inputs/nonansi/date.sql: -------------------------------------------------------------------------------- 1 | --IMPORT date.sql 2 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/sql-tests/inputs/nonansi/map.sql: -------------------------------------------------------------------------------- 1 | --IMPORT map.sql 2 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/sql-tests/inputs/nonansi/math.sql: -------------------------------------------------------------------------------- 1 | --IMPORT math.sql 2 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/test-data/disable_comments.csv: -------------------------------------------------------------------------------- 1 | #1,2,3 2 | 4,5,6 3 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/test-data/empty.csv: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/test-data/more-columns.csv: -------------------------------------------------------------------------------- 1 | 1,3.14,string,5,7 -------------------------------------------------------------------------------- /sql/core/src/test/resources/test-data/test-archive.har/part-0: -------------------------------------------------------------------------------- 1 | 1 2 | 2 3 | 3 4 | -------------------------------------------------------------------------------- /sql/core/src/test/resources/test-data/xml-resources/empty.xml: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sql/hive/pom.xml -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/T3.txt: -------------------------------------------------------------------------------- 1 | 212 2 | 414 3 | 616 4 | 717 5 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/char_varchar_udf.txt: -------------------------------------------------------------------------------- 1 | 47.3224 2923.29346 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/dim-data.txt: -------------------------------------------------------------------------------- 1 | 11 2 | 22 3 | 33 4 | 44 5 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/empty1.txt: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/empty2.txt: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/header_footer_table_3/empty1.txt: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/header_footer_table_3/empty2.txt: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/hive_626_bar.txt: -------------------------------------------------------------------------------- 1 | 10,0,1,1,bar10,a,b,c,d 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/hive_626_count.txt: -------------------------------------------------------------------------------- 1 | 10,2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/hive_626_foo.txt: -------------------------------------------------------------------------------- 1 | 1,foo1,a,b,c,d 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/in1.txt: -------------------------------------------------------------------------------- 1 | 35 2 | 48 3 | 100100 4 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/in2.txt: -------------------------------------------------------------------------------- 1 | 135 2 | 148 3 | 200200 4 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/kv4.txt: -------------------------------------------------------------------------------- 1 | 邵铮 -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/leftsemijoin_mr_t1.txt: -------------------------------------------------------------------------------- 1 | 1 2 | 1 3 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/non_ascii_tbl.txt: -------------------------------------------------------------------------------- 1 | 1|Garçu Kôkaku kidôtai 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/nullfile.txt: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/sales.txt: -------------------------------------------------------------------------------- 1 | Joe 2 2 | Hank 2 3 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/symlink2.txt: -------------------------------------------------------------------------------- 1 | ../../data/files/T2.txt 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/test.dat: -------------------------------------------------------------------------------- 1 | 1 2 | 2 3 | 3 4 | 4 5 | 5 6 | 6 -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/things.txt: -------------------------------------------------------------------------------- 1 | 2 Tie 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/things2.txt: -------------------------------------------------------------------------------- 1 | 2 Tie 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/tiny_a.txt: -------------------------------------------------------------------------------- 1 | 103200920268924913312 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/x.txt: -------------------------------------------------------------------------------- 1 | Joe 2 2 | Hank 2 3 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/y.txt: -------------------------------------------------------------------------------- 1 | 2 Tie 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/data/files/z.txt: -------------------------------------------------------------------------------- 1 | 2 Tie 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1 + 1-0-83de1c24fd6dee00409e8fdd99306ed6: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1 + 1L-0-917a033ac7f8f8b3a2e8e961dc91f35e: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1 + 1S-0-2e99da48f67f588c9e632a57c713522e: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1 + 1Y-0-1ff4db1fdac05de5b092095c2402fc5f: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1L + 1-0-1864a260554255a09e4f28b8551eef9d: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1L + 1L-0-e54a673c779f31597acdc5bd7d315d9f: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1L + 1S-0-b8e70f71c32aac77e2683ba20ab99688: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1L + 1Y-0-55de31e21660fa7d213b1f68d636cbf9: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1S + 1-0-c378b0b2a57c54b3815e8a64686756d3: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1S + 1L-0-9d3ff8b5d4883a4a5a1dc0dd4f0c1116: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1S + 1S-0-5054df6e72be611d6ee2a4e135bd949e: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1S + 1Y-0-e59bc8279cd364224476ffc504c7685b: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1Y + 1-0-a4541db51882b19503649138fbb295f: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1Y + 1L-0-2aa9a7b23c741d78032def0641a21cb1: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1Y + 1S-0-93a44c4952c4d343d3885edfc95b4b80: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/1Y + 1Y-0-3d9619d963e7f1cb4ab3e8b5e24ff0d5: -------------------------------------------------------------------------------- 1 | 2 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/IgnoreExplain-0-85d398864d4aa1d0e10ffd668fdf1a59: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-0-85e494848d1525843a3ff9b2b77f92: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-10-2d1f665a92fe72bd253ae57c46d7b9da: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-12-75a213649242c2410ea6846f08c91d75: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-13-ca51e03a3de391983429b6ad877e573c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-16-77500c83ffcece95511a4b21d67382dd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-19-3d80bb2d1c541460b5b17c4124fa647: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-2-75a213649242c2410ea6846f08c91d75: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-21-a6ea9efed3b9c680fca93588019ac5e3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-22-ea07b8f664208f93a1a8b97fd486d226: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-23-9c36cac1372650b703400c60dd29042c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-24-775d69742a1c07df8da87e8a017d955: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-26-63f13c364546ddce5d2176c6604a948f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-27-ba521286c12ba29329bfa71bb185c62f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-3-ca51e03a3de391983429b6ad877e573c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-30-a336adf1d0ff00633c53600fc75ca3ae: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-33-1934026d0228967097280eed35551f74: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-34-23b00f9c0101348e87da8a339b9da8b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-36-63f13c364546ddce5d2176c6604a948f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-37-ba521286c12ba29329bfa71bb185c62f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-40-a336adf1d0ff00633c53600fc75ca3ae: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-43-1934026d0228967097280eed35551f74: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-44-7a9e67189d3d4151f23b12c22bde06b5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-45-adbc01277c01cc5647e89c8a2430b8c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-6-77500c83ffcece95511a4b21d67382dd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter2-9-1986a53bb1944fe5f43e3e65693e7b1e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-0-1c1a75eeb97d4d8b9120d762aa0d2ade: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-1-47f70392b97b94cdb425b25bde204f58: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-10-bd9604a8b7eaecd785bc1e5163ec53a1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-11-10e58aa21d9af1817c71d83ec8e3a4d8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-13-4d7fd1a73dc8dde03c5627fb5e1dc17b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-14-3fa4d8a690a45cbf7b44cecfd352864f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-15-5c6b489b14a4d8bc4ce9a26d8465d6f2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-17-a9908f67f97588cbf15c0e7caddcbb0b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-18-581b65f9f467d0d4a33a16dda144a31d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-19-9c36cac1372650b703400c60dd29042c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-2-5a67d369d700eb96f806f8320c04d61f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-20-8114bed96bb7bff5b4fa18069c8d6d00: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-21-91e32b3028ecc352dad8884829148311: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-22-362c1a2c9cb223f05b33c3cc193a4d24: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-23-7ad62b397f6c9341da6bf0e9361314e2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-24-9c23b682abda3841f01b4d9b750c68d9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-26-3c725018f74a69f4d859c66af2f5b11e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-3-f031aa27bf7b494cb8de20a305be7064: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-30-cd5c7d666fdea990be3cf66e43c7b8f4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-31-5a41cf8c1a828ac2c372536ee4afd962: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-4-399fc26b344c98ababa104522601c0cc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter3-6-fe6db2a539df10e4bc4715e2ed755135: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-0-c261e1fa9f838dd034d37af38305e9c6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-11-7db7af854e4e10fb6f0338b85d65549d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-13-e9879d6bebc109340bbeecc3ca77492f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-14-7a9e67189d3d4151f23b12c22bde06b5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-15-63a545ee0e751a2729c8758a14712da5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-2-7db7af854e4e10fb6f0338b85d65549d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-4-cc9c0034efdeb0bf94ad774aeb703c39: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-6-acd58e84952d310aeddf78579c36286: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-7-8e6ec3396f25c124de5b212d8ce6c568: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-8-9c36cac1372650b703400c60dd29042c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter4-9-c261e1fa9f838dd034d37af38305e9c6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-0-953553e14d835682fa47338dcfffe227: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-1-cbad54fbd4a08fc8717708f93358ec3e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-11-e63fa029ab22ac4f5c880f2848f1b956: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-12-6b160869b8a9c846bc55a14f85bc5b52: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-13-9c36cac1372650b703400c60dd29042c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-14-92fbb4bc42ef462dcb4a06442b0c4023: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-15-cbad54fbd4a08fc8717708f93358ec3e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-16-4b76b7ff0df6adeded64b2a2f305530d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-17-9176dc5fb5206209fa907a289db1263d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-19-2f6ab691e291c74ecc4305eeb30e3438: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-2-4b76b7ff0df6adeded64b2a2f305530d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-3-2fc59e32c07186869811705c89aafadc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-5-2f6ab691e291c74ecc4305eeb30e3438: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-8-89c414c65a129f2fc408b3124f292b29: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter5-9-1e085f9741197e659413828c42386733: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_index-0-21bcf37075b02097f16c8fc8130a83b8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_index-1-4c8f6b48c437bf0be109fc0be1dc840e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_index-3-33474b65c86b949d266541e0385bc6bb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_index-5-21bcf37075b02097f16c8fc8130a83b8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-0-48044f1a60d3e15e4e17f8f95098d995: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-1-3a102e7798dbcc7948223c18ddaa8cb5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-11-efe4e50f2330d4f0a737183ea51836c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-3-bc9bb363f9a2026cfc70a31bb4551352: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-4-d3bf7703ba00cf7c40f2a2dbb8ca7224: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-5-6319bf26f3739260b1a77e2ea89ef147: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/alter_merge_2-8-c1b9f23f413b1cceaeea94d3a86f09cc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ambiguous_col-1-b4fe82679efdf6a15e9ecff53baf8d8d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ambiguous_col-2-dadfa3854356dead14b93c5a71a5d8ab: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ambiguous_col-3-70509ccd2765d90b98666b6dff8afe1b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/attr-0-24e06ffd262f2a5a6eec3314445d83ba: -------------------------------------------------------------------------------- 1 | 0 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join0-1-383f34dec3ac939b7af2c9093a557641: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join1-1-f1293ebf768eb04f2f0bfe6297c4509e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join1-2-8a9624554e208e3d8fbe42908c715b92: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join1-3-f6046c5229e3b0aa21498a3872f43b2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join10-1-dc932cb87d4d1a90dc5733c544b6a3d0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join11-1-82ea193ec76c2c6acd5f7178ef5ec417: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join12-1-c2efec9ea2ba761603b723afc0d5d145: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join13-1-f5e043288a21ea691c74fef2e39a52b4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join14-1-c85f3dcbab496811604ea0ab84d0e995: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join14-5-2454f1ce2e8d0d03a30c479f7dcd8153: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join14-6-de39302191b63d7aa8f92885b089fe2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join15-1-e23b9aa655061fb5a70d1f8f28f170f5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join17-1-387dd86b1e13f788ec677a08dc162c97: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join17-2-c2fd9f9c4cc80f21ea8c10edaaf03808: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join17-3-478a9f270a5d70f6f82f81e6962fb251: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join18-1-3839d176ee45fb0fc6702f4a7794ca1b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join19-1-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join19-2-70f3756d8b44d637ac4596cbbd48dc77: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join19-3-a3751c195480244a5ed497fd053cd433: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join2-1-3d1692c4710db1ff716d35e921f2bcca: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join2-2-15d7a6cb2e2f21077de2447c656e7a34: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join2-3-d4673c03d04084b838fcd8149f59ad9a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join20-1-2afb0510178c4b66876dd91c7ca441fd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join20-3-cf1c52393ea3a7e21782a1c52b83f0ee: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join21-1-9dd59784ca1555b607df0137d2666fb8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join22-1-4044be0e5116357bd88b4eda0f9ccaa8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join23-1-b31437533a2b890788938455cb32f679: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join24-1-721dfa03bfea05e55506c571b6c3585b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join24-2-36de83b0ed6c9fdc03661b2f65b23a3d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join24-3-fa8b2736440ff35687dadb1bcae32666: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join25-10-f1293ebf768eb04f2f0bfe6297c4509e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join25-11-f6046c5229e3b0aa21498a3872f43b2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join25-4-d83e6df8cd60d8ebeebd2100c51002d9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join25-5-a3751c195480244a5ed497fd053cd433: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join25-7-3d1692c4710db1ff716d35e921f2bcca: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join25-8-d4673c03d04084b838fcd8149f59ad9a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join26-0-54a7280ab9eed0d2e3b33df35a721b66: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join26-2-5ebef1af539734d0335dbe6aacae3e13: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join26-3-fed383a65bd118b43de6b00be10fecb6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join27-1-c83f56f364b1da3def90d48953665fe5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join28-2-9dd59784ca1555b607df0137d2666fb8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join28-3-30739ff22c62b3becf56694642b7ae81: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join28-4-c178253e7ce91b5aa35c2cc424bfa27: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join28-5-142850e84341feb3f7f40dd4553f72e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join3-1-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join3-2-6bed7d8089695e23914b29edaab2537d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join3-3-e9f6d17b15064f953a588fb40aee2f90: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-1-8cef272a7680529de5c6bd227a83cbc0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-11-53e43f2e48f605ec92c8a18c53e80620: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-13-9ee597656aa92e48475d6542339915ba: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-15-47b7efabbd6046e2befcbbea7da62553: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-3-57e5f7c770abbe1de38cbbcd5fd332a2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-5-3916f4b640f3579035153f6940113ef2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-7-f07b674c31ca9fdf837406cb9a96108e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join30-9-4ee48fa9bfeb818c81768b6de0517263: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join31-1-5a2b4475d9a88e53a2b6ec29279253c0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-1-2e533cf988f613d5fc3fbde67ffd9118: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-10-2e8ccb343bce61564bae209a589cca85: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-11-4d6fc319375b6962eca0aa63dfabfdc1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-12-4a7d51ed5c1d98c518ea74f73c6c7d6c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-13-ee2dcaae78ae900ffce8d19fbadc3735: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-14-7927c2ce644d1ce1de251405c8563e99: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-15-4cd3b51861720ac06c6deb818c83670: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-16-2e8ccb343bce61564bae209a589cca85: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-17-4d6fc319375b6962eca0aa63dfabfdc1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-18-d1d78b19d484e55d9da8a320253ece0f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-19-83b9df41bc46afbbafd0cd30cb982332: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-2-865207407ff1acbccb47473d87e87e8d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-20-693874ea8e06a8b155394ac27af2b1a7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-21-bf8a1bb0baaae9fbf1c3aa656f991f42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-22-3d14d63e996851f51a98f987995d8da6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-23-8b183ec2c164b3b530e802ffc880a5fa: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-24-cda0994eb851b57fdb80e16b033d1b73: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-25-e46226186de575c81cfab296607e1b4b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-26-97d265cd7defca44e488c38bac4c5b7a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-27-b034eeb850810b5004ddff1f2a530bc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-28-751550ac0550e6a7dd737cad01d6d82: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-29-34ecfdabf9c769027706f53fa2d66ed3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-3-9ccdfe4052062a1dfc72c711179d9e43: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-30-d3903985844b06c4af11334b72f383d1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-31-2415fd7a0c2e37b09679bb4c64f321bd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-4-a28f563122d1f0debd04f74c534523cf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-8-999683fa0291bf439b03557edec7dcee: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join32-9-1e6d4ec86f29d74828891c17986e84a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join4-1-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join4-2-4a36be16bcfa2bc35a8c33fb71ce2c7a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join4-3-dc967001beb776f3a859e9360823c361: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join5-1-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join5-2-a13b6523395e55c551ad42d92f9dbcd6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join5-3-b07bb1fdcd0eeeb62a8f7acb70cd2330: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join6-1-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join6-2-46718fdfa123cc86fe288bff4185dc90: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join6-3-bc6b6640b266ebe9b73702d3baf09c20: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join7-1-8f82881057bec4abf5a4d770a6f35838: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join7-2-8a7f50dc7e382a11884f4e116041aa1e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join7-3-56a30a1aa948bcf5ee54481897fc2208: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join8-1-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join8-2-cdb9885fe05daa90c228cf5b6550eeab: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join8-3-f1196bca86a749375da35f134206a8ca: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join9-1-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join9-2-62638666bf7f60c0d298547ea5e93ea7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/auto_join9-3-971c44e81ce17eb0849850b72ebd20f1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ba_table_udfs-0-7a9e67189d3d4151f23b12c22bde06b5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ba_table_udfs-1-3baac4c47f9cb2895f01bcfccd5f904b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cast1-0-b0e8966b7c06be9e044ed30b487d0661: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cast1-1-1ee16b8209701131017533cfa6eb4680: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cast1-2-3fe73e7435e30b37266ef6a33537dc4c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-0-16681f9c2bdd44278817d72c138b6ee1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-10-bba339a22907c06d1d01ba9cd7ea8f5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-12-6ad920e2ae83c78fccb06ff65308a438: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-14-cd2e125bceb1611137f0750f5d69c475: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-16-a2d5e5ec2504041ea1a62856c7086451: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-18-e01f450969ae7e1cd018e6ef0cc67141: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-2-50197277eb03ad20696a135bd7d18de7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-20-294891c1d956245540a80aa800ba393d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-22-8801aa93cf6dba7e13e99a0260fde68: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-24-f492a7f78faf180621e83e5a69aa1eae: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-4-cb4af90f52f2626213f918fda3b81dfc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-6-56f8e3e7abe504522a2bfd77b5be3270: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cluster-8-251b178e4fe39ea03a30d2b9bd40710d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine1-4-9cbd6d400fb6c3cd09010e3dbd76601: -------------------------------------------------------------------------------- 1 | 0 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine1-7-f7d8d6d0e9504b4dd2f1a557c0c69c30: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine1-8-da1fda96db80592bf2bbda8f22b5687c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-0-7a9e67189d3d4151f23b12c22bde06b5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-10-54649f87d403c6fcb163c4d51e382d3a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-11-2d2d73a929c7d995ea57b40529b74b56: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-13-5ac3e540fd24f94fee378e49597817b3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-15-dd652175dac4463fed3c56aded11e6c1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-17-8e4598e3f0701478ed12042438699ce5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/combine2-4-9cbd6d400fb6c3cd09010e3dbd76601: -------------------------------------------------------------------------------- 1 | 0 2 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/count-0-dd24f2cc60a0cd0eba0a3f8ca8127a0b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/count-1-c47c4abedf055b4e734232fd2e274d55: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/count-11-29aa086fe75b55482a91316c38498565: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/count-4-590bf60b8d4dfa135f73dbb52180136f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/count-6-29aa086fe75b55482a91316c38498565: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/count-9-590bf60b8d4dfa135f73dbb52180136f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cp_mj_rc-0-645f784b04a91b8c8e5bb770f95c3766: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cp_mj_rc-1-128c219e87f95f0425c8545a8c4bb32: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cp_mj_rc-2-17bbe2a542acac5960b755979dcb6d5e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cp_mj_rc-3-b1746cc42d6bbd2b1d314a9e5b18eb60: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cp_mj_rc-4-15beca26e35c885dff3bfe2336c26673: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/cp_mj_rc-5-27550c25058249ebfc6cda30dcf513f9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_1-1-23edf29bf7376c70d5ecf12720f4b1eb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_1-17-23edf29bf7376c70d5ecf12720f4b1eb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_1-2-4ebe3571c13a8b0c03096fbd972b7f1b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_1-3-26b5c291400dfde455b3c1b878b71d0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_1-6-559d01fb0b42c42f0c4927fa0f9deac4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_1-9-8306558e0eabe936ac33dabaaa17fea4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_2-0-8acfa0b538112534f57a3e051f0216bd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_2-1-116032b973a2060b533e1cdc9dfda301: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_2-2-efdf7f5d9f15edcb59a30f8ea166fbf1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_2-6-f4edce7cb20f325e8b69e787b2ae8882: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-0-b84f7e931d710dcbe3c5126d998285a8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-1-6272f5e518f6a20bc96a5870ff315c4f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-1-b84f7e931d710dcbe3c5126d998285a8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-2-4a0e7bde447ef616b98e0f55d2886de0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-2-6272f5e518f6a20bc96a5870ff315c4f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-3-4a0e7bde447ef616b98e0f55d2886de0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-3-a23faa56b5d3ca9063a21f72b4278b00: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-4-6c4c2941bae77147a4d3d8fcaa1c88c8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-5-b84f7e931d710dcbe3c5126d998285a8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_4-6-b84f7e931d710dcbe3c5126d998285a8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-0-84604a42a5d7f2842f1eec10c689d447: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-1-5e8136f6a6503ae9bef9beca80fada13: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-2-10e337c34d1e82a360b8599988f4b266: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-3-29e406e613c0284b3e16a8943a4d31bd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-4-23653315213f578856ab5c3bd80c0264: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-5-891fd92a4787b9789f6d1f51c1eddc8a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-6-3473c118d20783eafb456043a2ee5d5b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-7-9fb5165824e161074565e7500959c1b2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/date_udf-7-ef82dff775f4aba5d7a638b4e5fd9c5d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/decimal_1-2-ee665100ca5de3a006df43e97cfa707: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/decimal_1-5-bfab296ca5693e647e33899dfeeb256: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby1-2-f90acd59ace31e16059bae52583188cc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby1-4-19094f229f8af852ef8dad406333ae08: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby1-6-977359ea0d2f429a9a35bbd8599cddea: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby2-3-6b5d354a5a81c0171c3cc8d553bfdb9b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby2-4-67a2618eb44e68e6d8cf8792ded802f7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby2-5-c0660310e5d882732d07cb76bc0a7939: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby4-2-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby4-3-132eabb30b8d011c848c531a6ab54529: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby4-4-ac19a9a7f4a16763bfe7998179257933: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby5-2-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby5-3-a773aeb40af0516f2527f8e9d6907420: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby5-4-c4570c2676d599793e1e9ece32aa596e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby6-2-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby6-3-ae61517a9997b80d512a9089cdb71fac: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby6-4-3f468a119e7975110b4063adb42c7dd9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby7-2-3678fb67b5c739bd87d4907630da1208: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby7-3-95474af63c0f92717ed49c3a0f37b10a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby7-6-b2af91348c5fa9605702be50983c3bd2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby8-2-3678fb67b5c739bd87d4907630da1208: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby8-3-95474af63c0f92717ed49c3a0f37b10a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby8-4-a0a22ec83d6632cba3f17d79dbb9494d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby8-5-83296fd5b5fc22af0c51514c4e67c95f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby8-9-a0a22ec83d6632cba3f17d79dbb9494d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby9-0-3678fb67b5c739bd87d4907630da1208: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby9-1-6ffcd6fad9ca3e9934f521673f5039a5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby9-2-a4e1a4b250c160f9b90b12a2e7c5e82f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby9-3-9f4c2e7d95494bcdc7c4ed19e0434de6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby9-6-55781df7ed3ff9e37001fbd7739b9c2e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/groupby9-7-ccc5914317422f569e8b7171a3b2b243: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/having-0-57f3f26c0203c29c2a91a7cca557ce55: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/having-2-a2b4f52cb92f730ddb912b063636d6c1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/having-4-e9918bd385cb35db4ebcbd4e398547f4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/having-6-9f50df5b5f31c7166b0396ab434dc095: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/having-8-4aa7197e20b5a64461ca670a79488103: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input-0-42022446607cfbe8a64d8fd7b9898ce7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input0-0-fb47f8a8a8e3213f3fe47825a556c593: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input1-0-28c9f2913833d6911f22e2e2e8c60f68: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input1-1-8aaad4ee49c9bdf7b34642cc75f6a1a0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input10-0-acdd72fda64c5463ce29f31020012d42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input10-1-6970b6d2d451612b59fccbfd7ec68f74: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input11-0-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input11-1-3e66f12ae780a85721fa21c42fb3c8fb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input11-2-24fe55bae88ad4a8e240376d012bc491: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input12-3-5186c4f54bcc1d9a2afb953c8dd5d8d7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input12-4-f69ce1f5b3e0e77d1c487877580e6a23: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input12-5-d83ffe497d7f7a8f72a6844dc6dad3cf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input12-6-f6ae011490e0c8c037927767ad966ce4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input12-7-16da1c1293626b943343443368679e9c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input14-0-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input14-1-d0a1caeeeb79580713b7ecc28543f74a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input14-2-1d791beabaa5288ea2fcf6b3675eda26: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input15-0-1570712216ce86428ee39974242ae961: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input15-1-86edc12357bf278d5e601a654358c32f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input19-0-a8eaa79d3a2762cdb263bc822d62df3a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input19-1-f32df514de8156b5f5b435eea2c9be40: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input2-0-eaf4ec8905774e4be6ea3fa4f32a456c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input2-3-45b9f786f64afa5e039d1856fe926649: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input2-6-4a6b9674c126337f71834f11613f996d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input2-8-28c3fc507cd2e02a3a39331fc9c95334: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input2-9-48bf8c06ed0a264d0863613fe79795e1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input21-0-7f40c525398953892ffd6283f54ba427: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input21-1-c45ad493e95150b580be778da6065f36: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input21-2-a4b3aeb45ae0cf38777e126faed0eff7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input22-0-b9cd4041ca510639838a97376747b498: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input22-1-b663ec84da3f9d9b9594ea2da81b1442: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input22-2-10e46b53620b6b05019da4e58f53e6c3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input23-0-c983ab8049996ad5e1e0296b51ae81cf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input23-1-c8e32187d09172eb32b0480fcd28cccb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input24-0-f8116598acadb7589ae02b13b65e1ad8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input24-1-f57485de80ad64f9931bf92514fa1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input24-2-3fc20939000a5324a928feeb673a1ee2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input25-0-f8116598acadb7589ae02b13b65e1ad8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input25-1-f57485de80ad64f9931bf92514fa1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input25-2-74a4b9d59ee26b650f567c07e9103b66: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input25-3-d4940dd537ae72d234ffea23f8f0b103: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input25-4-72c74c55dd7d85d194448e9c58488938: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input26-0-1b6e9e73dd7ee60644c0997b21f48430: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input28-0-b85d5edb4640c4b154e91e9a1beeef8a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input28-1-f57485de80ad64f9931bf92514fa1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input28-2-e88e8d960eeb128fbc6642274780ce4c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input28-3-a3da4a5ba73e312a8adafc1bc8a0f930: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input4-0-b9cd4041ca510639838a97376747b498: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input4-1-7ce0bc5e5feeb09bf3fc139e102fb00e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input4-2-b663ec84da3f9d9b9594ea2da81b1442: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input4-3-d9280be6c9dd1e2263f8d50f0f43a486: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input40-0-37e74908fd43254141ae3664f13a48d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input40-1-a8adb8ae1d13607851431a1baf7578ba: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input40-3-12f634800ffae17942ddd789a01af227: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input40-4-fdeea6b676c670b17c8d91e24a97a127: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input40-6-6651f53efc5d03ed2d43b9d7aecc0002: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input41-1-8112b3a278e8337dbd6f017ae178658b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input41-2-61812b3093413d09f0fd2372c61f7d53: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input49-0-2bd546beeb607da5b925ffbea20a741c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input49-1-e2b5acbef6ef09cb3eecdb0ce2729e8d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input49-3-4b0fff4bd5c63666ccc22b07a521b7b0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input6-0-659e06570690cceeb3f37e10e855d2ea: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input6-1-21149162906e31964a328b6cb2d5286e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input6-2-9601ace6dce45dc8d6281cc248c9e28c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input7-0-8daa7823607b82336736a9d4f9a2ce45: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input7-1-bb25de1b9a7791ec5609303bab350da0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input7-2-c740098a289f9a4267d26fc10347a0dc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input8-0-584fc8ceef39e1e1333ebaeec3e9e7fa: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input8-1-c9f9239e73b04fc5c0e0219f438ceefa: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input8-2-4a4cb89ba45d26bb3dd73e44620578ba: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input9-0-8cc1539c21d92af8ea8c1431b0e3d85: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input9-1-b30105391cb53915997a84ca3137bd0a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input9-2-171ea277f05a642699a0f91bacffccd8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/input9-3-adc1ec67836b26b60d8547c4996bfd8f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-0-7faa9807151781e4207103aa568e321c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-1-91d7b05c9024bff60b55f415cbeacc8b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-10-64f83491a8fe675ef3a4a9a474ac0439: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-11-6f2797b6f81943d3b53b8d247ae8512b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-12-7a3c0a3f06484c912b9e951d8a2d8ac6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-13-42b03f938894fdafc7fff640711a9b2f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-14-e021dfb28597811870c03b3242972927: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-16-7a9e67189d3d4151f23b12c22bde06b5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-17-5528e36b3b0f5b14313898cc45f9c23a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-18-16d78fba2d86277bc2f804037cc0a8b4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-19-62518ff6810db9cdd8926702192a206b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-2-3f1de4475930285c3fdbe3a5ccd4e868: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-20-f4dc51ad64bb8662d066a8b9003da3d4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-3-89f8a028e32fae213b575b4df4e26e9c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-4-c7a68c0884785d0f5e62b287eb305d64: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-5-cb87ee12092fdf05daed82485c32a285: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-6-b97ba93a2c9ae671ecfc4fa95c024dda: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-7-a2cd0615b9e79befd9c1842516150a61: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-8-5942e331621fe522fc297844046d2370: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/insert1-9-5c5132707d7a4fb6e6a3de1a6719721a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join0-0-7fbd114e2fc7f55cf1421698eac39397: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join0-1-83f5e512d6058a47f92b5218781f5070: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join1-1-f1293ebf768eb04f2f0bfe6297c4509e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join1-2-7b07671864bbfdc627ee794932e32b1e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join1-3-f6046c5229e3b0aa21498a3872f43b2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join10-0-1e7a0e1d539a39ed19833e6a6d0b1644: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join11-0-e2cc67c543c1209ebcd3f9048c4cb29: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join12-0-12fa53be2c0ddbcfc85212e573a46af1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join13-0-c4ebf24269e27919f4ba9ce3993e48f7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join14-0-c85f3dcbab496811604ea0ab84d0e995: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join14-5-4c3f537b4df1ef16788a53cf65574187: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join14-6-de39302191b63d7aa8f92885b089fe2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join15-0-930db2823512f7f8f34cac104f2162e0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join16-0-1bec3b0892d5c4a174d1b39f6d1b610c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join17-0-387dd86b1e13f788ec677a08dc162c97: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join17-1-37cef87fe56f66692799ccda8cda2e8b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join17-2-478a9f270a5d70f6f82f81e6962fb251: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join18-0-269843197b598569f4b50cbe911960a5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join19-0-26ba1cd9acfcd799239da60c38e68a39: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join19-1-7e7d1f07c34dd4be5425264196201766: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join2-0-3d1692c4710db1ff716d35e921f2bcca: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join2-1-87896c3f04a259b81b1cfde3eec7d64c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join2-2-d4673c03d04084b838fcd8149f59ad9a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join20-0-16cda49c2b2cd0c0cdae40af4d5c900e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join20-2-222655137ca9242f063c7717acbe4c65: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join21-0-d89bb8082a39fcaf8ed23a0f5b1cb410: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join22-0-97081b5f73052a612fb391a57ad9b7b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join23-0-1fb76d3404f09a5c2b10422157c3cf5d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join24-0-721dfa03bfea05e55506c571b6c3585b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join24-1-36de83b0ed6c9fdc03661b2f65b23a3d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join25-1-360b3676605ccb3d89cf555342db87af: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join25-2-ef930bed933341636c71622e6f89e9e9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join25-3-e39577008d28ddd5741d8518b92eaa94: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join26-0-775b1af8eae9b2250052be1b72b4086: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join26-1-10fbe6c99e93cfeafcd454261744728e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join26-2-8aa0193a2a80d4efe4c66bca19218a4d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join27-0-360b3676605ccb3d89cf555342db87af: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join27-1-d56d8bbececcf48417b7dde9292a9cc6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join27-2-6d139e1aa07ff8d02bdf52b409956879: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join28-0-7f2c5c987bc8e918f7b6fc222e1abc62: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join28-4-bd4e19a3608681b0270668fe68b7d124: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join28-5-24cc9ff9485313ade08ee83ecc4c0621: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join29-0-e78402f7585b17c76c32790571d749eb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join29-4-b0524de7985cdb7b57fd995721654856: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join29-5-9e35870a3bc8224cde6b1ab322568d2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join3-0-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join3-1-4ef57a9e40b2e7fd01e1778bed71b5b2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join3-2-e9f6d17b15064f953a588fb40aee2f90: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join30-0-54a7280ab9eed0d2e3b33df35a721b66: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join30-1-5859eba43fb180c2142035cd4c77ea4d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join30-2-194edec0592cf441617ca7caf9756baa: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join31-0-619db2f9dd69aa236aa804cced726c9a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join31-4-34e30fa5d6f35a20561c7754197f0626: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join31-5-a2082be28be44e2bfa9a58fb45c23f07: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join32-0-775b1af8eae9b2250052be1b72b4086: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join32-4-fc6880e4e0750a3daa7fc108b72d11bb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join32-5-425c5c35b23c42254dabec49aa6613bf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join33-0-775b1af8eae9b2250052be1b72b4086: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join33-4-fc6880e4e0750a3daa7fc108b72d11bb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join33-5-425c5c35b23c42254dabec49aa6613bf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join34-0-775b1af8eae9b2250052be1b72b4086: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join34-4-51cc5d253befd784a9d466c0b402f47a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join34-5-abf5cf110d6a0eb85ae257768c805f39: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join35-0-1ef68e1b8dd5f69f4a5149f3ebec42b9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join35-4-99cb704ccc2813400908a62571891dc7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join35-5-60956f3307651237f52ffbe41c827c1c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-1-3aba153d62042206c0f001ea74980da: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-2-5b1cac8ef7857d2f8c675ed6f0224471: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-3-c87d5b10b6ce87ac8ee2ab0d2b3755e8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-4-fbe7d714e988877ebe6202a60e8ef776: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-5-9353d3e0b11c781f782af4013e8569e3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-6-d76aff886201d223c7dbed2b0f0d5512: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join36-7-171ede21302050a33468d95e329a38a3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join37-1-360b3676605ccb3d89cf555342db87af: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join37-2-2310f2b8726137811543e04db98dd1db: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join37-3-c4b3a85965108ad7013ac3931598af09: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join38-0-42e6ad674a5142d05258a2d29578e046: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join38-1-d8ba5ec8a5a0bb702958400a3b3e458f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join38-3-22ead86c36dcd9ac9403fb52ac752046: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join39-0-54e9f7924abb40d1c601de908de6f25b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join39-1-60178dec03adcbccbd4e5cae936c38f2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join39-2-7fe3308e0a153b36c8eb21edcd3dbe96: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join4-0-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join4-1-8884a9b112b0c767aa0bd8e745bd7b21: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join4-2-dc967001beb776f3a859e9360823c361: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join40-1-4b663d50fee0a8afd32cdf25c3b82de8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join40-11-c8c5b97a744acf897888ab2d51d33a80: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join40-3-4ef939dcda3b87f66c1bb3b2ebe32ec6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join40-5-16cda49c2b2cd0c0cdae40af4d5c900e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join40-7-222655137ca9242f063c7717acbe4c65: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join40-9-6b7404af014eeb4de196577f14ef18cc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join41-0-b74d94933c6670ccc4a1ad8161185686: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join41-2-e02c931c8bb07ad765d0a6cd73abc2a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join41-5-f18ea17bcfafde311a4bdc589362e00e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join5-0-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join5-1-76feff1282895f38b673f52acfd7429e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join5-2-b07bb1fdcd0eeeb62a8f7acb70cd2330: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join6-0-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join6-1-c3702956d2a1ff2bf1ae967b9f04bad3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join6-2-bc6b6640b266ebe9b73702d3baf09c20: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join7-0-8f82881057bec4abf5a4d770a6f35838: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join7-1-1aa2f2b13c2522b0457c0dd2ceb615d8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join7-2-56a30a1aa948bcf5ee54481897fc2208: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join8-0-531e91e11b3891627c2675935fda14cd: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join8-1-13f11eaafaa42f8bdf0ed0a446f5bfa7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join8-2-f1196bca86a749375da35f134206a8ca: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join9-0-13ab74a58da514fe01dbeda0c3e79883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join9-1-fb3387ec28fc9d527e773c8b70bdf67a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join9-2-971c44e81ce17eb0849850b72ebd20f1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join_rc-0-fcbbe26c6881f81800fe86abbfe6aa87: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join_rc-1-6a7685f30de00ebb4867a4002d641a5e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join_rc-2-88aabbe1fcd7735ae8cc97418b4a59a3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join_rc-3-4a737f3e518f5322ba41a189e79c1dee: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/join_rc-4-f60f7fdd08e85fae90af59475192b725: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/lineage1-0-c021950f995f1d6a7b83ffe044daa750: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/lineage1-1-aeb863486b8fe899ee741fc8c8418fc9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/lineage1-2-f92e96c6357273ea6cbb2195a418df9c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/loadpart1-5-892cb7ecc26e84f1c033b95a3ee3edc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/loadpart1-6-ca5e3149f2b190d7df923a3e5c1cb07: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/loadpart1-8-ca5e3149f2b190d7df923a3e5c1cb07: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-1-5ff5e8795c13303db5d3ea88e1e918b6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-10-45148a37f6ee9cf498dc7308cbd81a1c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-12-62b999122975c2a5de8e49fee089c041: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-14-3a31df84432674ad410f44b137e32c2d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-15-56966c45104c0d9bc407e79538c2c029: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-16-56966c45104c0d9bc407e79538c2c029: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-18-bddb2fe17cd4d850c4462b7eb2b9bc2a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-19-e3c828c372607b8bf7be00a99359b662: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-20-cb252a243d59809930a4ff371cbfa292: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-21-cb252a243d59809930a4ff371cbfa292: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-3-ddc4cb920b0a68e06551cd34ae4e29ff: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-4-86292bbb7f147393c38bca051768dbda: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-5-ca270bff813e5ab18a6a799016693aa8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-6-8976be22af3aba0cc4905e014b4e24fe: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-8-3d25ffda9ab348f3e39ad967fc0e5020: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/macro-9-db5f5172704da1e6dd5d59c136b83e7e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-1-2c73c923962b91afdf0004a705432550: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-10-49d94c94e0a08155c9e5cb6e4efc6501: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-11-dcc5d9564bb8df6bac382c82c33ccd87: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-13-cb13a05d07f9f1ad6c43edfc8b0e9359: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-14-dcc5d9564bb8df6bac382c82c33ccd87: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-2-34854e1283de8e9ada3edd6bf897bc67: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-3-1f560722f18ef618a0343313a0cac462: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-5-2f16345a20407b01e5cc5ae26ea902b0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-6-1c02b26792354eae7fb53fa3cb752ac1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-7-5570ef5461d4a5cd01ec91da3a474dd2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-8-37bd183ad3b7ad1e8550a138f7beb88a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge1-9-64678b0928c4fd054e1578458001c86: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-10-9f60e54bc4add2b1aff8473e2a756c79: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-11-1c02b26792354eae7fb53fa3cb752ac1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-12-d2a36a13f8531cde3c66d4003048416: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-13-37bd183ad3b7ad1e8550a138f7beb88a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-14-64678b0928c4fd054e1578458001c86: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-15-aaaf38f80d7313738a51a49bd5aa14c3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-16-d75f4405b860e4187882a72418ed6c83: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-18-945682265ce2c1fe7fa69aeb57b4290f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-19-d75f4405b860e4187882a72418ed6c83: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-6-319e3c6b684d2abd4dfd7314a05d4307: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-7-fa2f100bc67426120cb97cfc75a5fb36: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge2-8-7435e0bf03e747705b0858d5dcccfcc1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-10-692a197bd688b48f762e72978f54aa32: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-12-62541540a18d68a3cb8497a741061d11: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-13-ed1103f06609365b40e78d13c654cc71: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-5-3d24d877366c42030f6d9a596665720d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-6-b3a76420183795720ab3a384046e5af: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-7-631a45828eae3f5f562d992efe4cd56d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/merge4-9-ad3dc168c8b6f048717e39ab16b0a319: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/order-0-5c2fda577771db3b316e0d2bd02d048a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/order-2-fe90320d98850ea5e9b6100f6d259fbf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/order2-1-484c94d6b57ccc9fffda150bee0bccdf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/parallel-3-195007722f0c2921f9c6c1eb461b6d2a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/parallel-4-fcf032bbe1f1569d934da7090db60a83: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/parallel-5-e27b511ffc5828b09069121031d17a2f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/parallel-6-d196279de0b7c4b42521aa23634ca506: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd1-2-ae8aea06b05358ef9c486b61c9e30a69: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd1-5-ae8aea06b05358ef9c486b61c9e30a69: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd2-2-4d5021216c5bc600a8c5344945f55a4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd2-4-4e457825319166f3bd2ad07d8f7c2f69: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd2-5-a2d5e5ec2504041ea1a62856c7086451: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd2-8-4d5021216c5bc600a8c5344945f55a4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd_gby-2-fea67192aba8704a64a85da47f7f321e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd_gby-5-fea67192aba8704a64a85da47f7f321e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd_gby2-2-25541db999d8c1d56ba36b63949b6073: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd_gby2-5-25541db999d8c1d56ba36b63949b6073: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd_join-2-4c4dcd0c288653e39cfe077c19c68570: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/ppd_join-5-4c4dcd0c288653e39cfe077c19c68570: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/push_or-0-82eac35d076df1ee8020d57832f0f895: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/push_or-1-4c03e0f7fa028897c0caee62167eb68e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/push_or-2-62abd65e444981a96f7cf3dab3e013f1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/push_or-3-34a713b9523589f1eb3205037d56a5b4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/push_or-4-22888cdef1b94bde983541c1f3d510d9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/quote1-0-54ea0f3c04b185472a38a744d8003c13: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/quote1-1-965ec21dbb2cdbfb0e8a8cb20ea96416: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/quote1-2-14d4949bc9215a1004c945885ef10de4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/quote1-3-f36bdb38d0c1b79c6113fa0795d14533: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/quote2-1-ea1a1d0c5f9a3248afbb65e6632c5118: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-0-1631b71327abf75b96116036b977b26c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-16-d3a72a90515ac4a8d8e9ac923bcda3d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-2-deb9c3286ae8e851b1fdb270085b16bc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-38-f37547c73a48ce3ba089531b176e6ba: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-4-dfdad5a2742f93e8ea888191460809c0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-6-90bb51b1330230d10a14fb7517457aa0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-7-333d72e8bce6d11a35fc7a30418f225b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/semijoin-8-d46607be851a6f4e27e98cbbefdee994: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/sort-0-eee35bbc888a705ae527625447668032: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-10-ee1bfc1f0047527d9bd745dcc747ab6c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-11-82294461be4728b4b191414bf2fb3bd7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-18-bb8d8522a40a50fb684fabffd2fa7d17: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-19-eb5c7d6fd7433dfe9684e43e4a3419ed: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-20-5f7439f97275da70f633e135205f2095: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-21-6bcc1360b3d777a8b51ae416ff43898a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-22-85de3349a12a9fa0536f20ad0377fca1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-25-98c925a2b2c4de06e270e1b52437a98b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-26-ee1bfc1f0047527d9bd745dcc747ab6c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-27-82294461be4728b4b191414bf2fb3bd7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-4-5f7439f97275da70f633e135205f2095: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-5-6bcc1360b3d777a8b51ae416ff43898a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-6-85de3349a12a9fa0536f20ad0377fca1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/stats0-9-98c925a2b2c4de06e270e1b52437a98b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/subq2-0-279fb87476c70e9384874fa6bf77a380: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-0-cd46bc635e3010cf1b990a652a584a09: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-1-27ad2962fed131f51ba802596ba37278: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-10-27ad2962fed131f51ba802596ba37278: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-2-3e95421993ab28d18245ec2340f580a3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-3-c0c18ac884677231a41eea8d980d0451: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-4-c06da7f8c1e98dc22e3171018e357f6a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-5-af459a0264559a2aeaa1341ce779ab3c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-6-5c7b24abea435f2628fe618f3a82e115: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-7-3752320b12abae0d138148d56a27c5b1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-8-3562ab40242756452595cd7eae79b0ce: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/touch-9-cd46bc635e3010cf1b990a652a584a09: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf2-0-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf2-1-f60851dc36f579e83d6848d7d3c589e6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf2-2-31c8af064bac42541558a95fad3bca97: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf5-0-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf5-1-f60851dc36f579e83d6848d7d3c589e6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf5-2-e08fad5ccbf165f44ecabb9356e58b24: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf5-4-1b35f4ee3febf99804db1f481af80b23: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf6-0-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf6-1-f60851dc36f579e83d6848d7d3c589e6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf6-2-4d2a0815afe8c050cabf7a2efbce8521: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf6-4-29f45ffe530dd8c27dfb82268017dbb2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf7-0-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf7-1-f60851dc36f579e83d6848d7d3c589e6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf7-2-645d8fe7ab47806e0427c3deeedb5ec6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf8-0-2a18d9570d9b676e240cda76df818c42: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf8-1-63c38297946a2060c0cff4a426b0520c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf8-2-700c31cc5099ea2c3bbb9fbf5c43a32: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf8-3-72c1a1dd1627491550f6e19581a654cb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf9-0-a05de5714d8ccb2ac31dfe4f178fd358: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_E-1-cad0779d18f326c8e453bf2b5fe43596: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_E-5-9d54c12bf727e05e9f9d67c61402a1d4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_PI-1-13fd9345fd15b654d18b2707e5274b2b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_PI-5-cd1c31c39277a02bab8e44f8c29a6c2d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_abs-3-50cb3c23902cd29e0dbff188c71062e5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_abs-5-5cd4c198e0de884ad436864b95fece6c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_case-3-48789112d79aeb450d9f49184fc20e1c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_elt-3-c2554fac72a2a51bb33faae16aec3507: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_field-7-3fd8b0c333acdf28c676315b03e2e10: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_hash-3-2646a87ce26c383a9dafea9b56281ab7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_if-2-f2b010128e922d0096a65ddd9ae1d0b4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_if-3-59e90bb74481aaf35480076806daf365: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_if-4-174dae8a1eb4cad6ccf6f67203de71ca: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_if-5-841a8068d35a42179d3654e1a2848c43: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_like-3-dbc46cb33f0dd356af03006d9492f8b7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_lpad-3-ea9a05f035dedfe15d3a7f3d7756a2d7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_map-3-be7b52baa973b8b59b7ca63fea19aa99: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_nvl-3-47199a1c23cb1cc6827c601bb66513d3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_rpad-3-66acb969c28a8e376782ccd0d442b450: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_sign-1-cddd6ec2a7dfc2f8f7e35bc39df541f9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_sign-7-ed2aaa1a416c0cccc04de970424e1860: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/udf_when-3-734890c41528b9d918db66b0582228a4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union10-1-c5b4e04f745a28463e64aeeec6d4b2af: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union10-2-60ee9eae687170317ff91dafe6b799bf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union10-3-6b4ed91859c7ab8d3548d4c7eeb65182: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union11-1-a6f37db310de2edce6696c25a4fe96e3: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union13-0-6970d1e2405f3769a28a8804887ac657: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union14-1-11603fb6225423979af6c062cfa9389b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union15-1-caf8a4bf47a5f5dfd27388fe00686c56: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union16-0-7d7f87e388835405f8c7baba969e04f5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union17-0-383b0c63b3fe31509d23612cb6ae88a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union17-1-9491c271b7e2c351ddcf126f73679892: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union17-2-e6fb104913b9da8193167ee263993dd1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union17-3-eef8248caa65e21a7c2956aa488297a0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union18-0-383b0c63b3fe31509d23612cb6ae88a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union18-1-9491c271b7e2c351ddcf126f73679892: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union18-2-584e61e1599fe449cc998a3332dcb7e5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union18-3-b86b4936bb620a8f5d929943f4aa75f2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union19-0-383b0c63b3fe31509d23612cb6ae88a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union19-1-9491c271b7e2c351ddcf126f73679892: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union19-2-b6161b64e57a2502c79662866782cbdf: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union19-3-4e2ace50cdaad15bbe48cb793f72cbd2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union2-0-58813daf3d1af57b17518b606f8345b2: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union20-0-a7f64187712936e741d5c33b2f5dfa6d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union22-0-4bd6583b3635f1db95765565518bda8d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union22-1-9037e5e0cb2d64e4efe6280dc03396f7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union22-2-a4c7c7ba0177c0a8fe415e2bd3e93002: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union22-3-291783e57ccb7c6cad6b5e8d2dae89a0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union22-8-c78e8af8e8e327c58a74f7cb34a1c912: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union22-9-f4414e4636a16596d04fcc433d1119b6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union23-0-c86f3e120d66f1b06a8b916a4a67e4b4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-0-5659f2e36b79fa312aaf6e233dc575c9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-1-92aaed1a225be0e1b3d4556680a77b8c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-10-ae53b6e1d433f000da3fbe130222b89: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-2-4afc74338258d50ae6ecdb0589bd2a38: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-3-d3370b90a3ace4b4d1cefd1ffc79906f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-6-83d9274a535ebebe0170ce8f16062ef4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union24-8-b6d9a41e2b537869e977cfb969b51edb: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union25-0-f4e883ee4edf8fbb95efed8ae41cff1c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union25-1-8f4a32f3c1551b4e4f22c3b776a92043: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union25-2-f61103bb2045761ba95828898e63b92b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union26-0-a0d1a7f8eb3fba9455ab517aab14552d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union27-0-7f319eff3c0237b6c06cb704dcde9195: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union27-1-fb2ddef0c7d9b05d7fb26442599d354f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union27-2-10d1593b6663231ff7de938024ce6bb6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union28-0-6bccc08f175712c17aa66cebbf5b7e36: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union28-1-f1bd585c115dbabf655d8dc38cd4e026: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union28-2-9985bbc70b8dd624fac261eafb10a78f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union29-0-6bccc08f175712c17aa66cebbf5b7e36: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union29-1-a40036f756a306f4226634b6ab67c72c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union29-2-c7fab64fc276c13149e1e68c0deb6594: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union3-0-99620f72f0282904846a596ca5b3e46c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union3-1-ae80732ae5db530cc4e355d5d4724457: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union3-2-90ca96ea59fd45cf0af8c020ae77c908: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union30-0-6bccc08f175712c17aa66cebbf5b7e36: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union30-1-1aff6fba829bae7d20266cf91383ef78: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union30-2-252f12f7532ca67132bfc62063c58430: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-0-ca16024e6f5399b1d035f5b9fd665163: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-1-b12aa87aaf64b573ce0be7013117651b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-10-ca695e6973bc98b7f06c998b964ae339: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-11-70dda95c1b749e4104cc2c767cd7fec0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-12-de2477a134ab37bb22d879028becf2e5: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-13-22b1078764cb1c9b2fb95358c968e987: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-16-ca16024e6f5399b1d035f5b9fd665163: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-17-b12aa87aaf64b573ce0be7013117651b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-18-1522ec86f2e6735cf809a52c1f6f7883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-19-1e9320795b3e4acd7e6d89a8c9ba897e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-2-1522ec86f2e6735cf809a52c1f6f7883: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-20-dceb6d9a03096d68d090557692ed6899: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-21-bda2e62d0ecd30200b2359df420da574: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-22-fa1c85506afbfa956251cd1253f5d79a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-23-c9d9d45a7d1a0c69efb8d8babc4a50df: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-3-35d1dd67e8c3d76c77baaeae0760ddfc: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-4-77653483e5ce18437c9f85d3b297335d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-5-4651987fca60c1c1a59b8b28713ea737: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-6-69c2b75a25f884a72d89e43e0186f5a6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union31-7-7b021f95774705e4d7ff7049ee0e0b74: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union33-1-1df7c476abb48234c839878414720873: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union33-2-3987150ad66482f5186826efcfb117f7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union33-3-bfe75625806b414a5098af487b91046a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union33-5-13c01085e0a2c46e745985fa11bedf34: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union33-6-796e4fce2bfb63c09bc04ac6eca7c9d8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-0-a9a6e5b0059d8f66a79ee702f2bec0a4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-1-320c2fe802fab386957039aaff6399f1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-2-5707c9fd2cfd049426383e5e5dc80d7: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-3-c179e14d840249d6953cb552279822f1: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-4-70479e10c016e5ac448394dbadb32794: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-6-ff0312eeb487fc393a06880ef5bb286f: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union34-9-d82ffe361a119651bbf41a149b6eba91: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union4-1-88deb3987655dc41989f39c0827cec74: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union4-2-41739c4bd273f0cfa94b347c36a71f38: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union4-3-2fb47e6ec0a780da5bda97752e573c0b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union5-1-54c6369ded20ba12138e6c53a157dae8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union6-1-7d631b7dbfe39ccaf995e16186b3e94d: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union6-2-31cbd867e4b88605d230c542af64b7c4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union6-3-c39f37580f6b3cecbcf3192ee0cd2aa9: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union7-1-f449f20f6bfc4f038c79c3b7e8f48c37: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union8-0-d0a83a1cedcbd1d2158acf7eb938d18e: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/union9-0-fad6a053ab42c3cad89052e88d819e83: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-0-5528e36b3b0f5b14313898cc45f9c23a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-1-7650b86c86dd6b1a99c86ddc5a31bd63: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-10-7aae4448a05e8a8a3bace7522e952cd0: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-11-dc95343d3e57846485dd543476391376: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-12-371764e1cae31ea0518c03060528d239: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-13-2abce88008f8a19164758ee821aaa8a6: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-14-deb504f4f70fd7db975950c3c47959ee: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-15-6f2797b6f81943d3b53b8d247ae8512b: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-2-9c529f486fa81a032bfe1253808fca8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-3-e7dd3b24daa60d8955b22f0441f01a6a: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-4-4a64d1a623ca71e515796787dbd0f904: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-5-7abee38ed087f13f03ac216ef0decf4c: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-6-47b5043f03a84695b6784682b4402ac8: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-7-8b1bbdadfd1e11af1b56064196164e58: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-8-60d2f3ee552ae7021f9fa72f0dcf2867: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/hive/src/test/resources/golden/view-9-66c68babac10ae0f645fe8334c5a42d4: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /sql/mkdocs.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/sql/mkdocs.yml -------------------------------------------------------------------------------- /tools/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/apache/spark/HEAD/tools/pom.xml --------------------------------------------------------------------------------