You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by HyukjinKwon <gi...@git.apache.org> on 2018/08/02 17:36:09 UTC

[GitHub] spark pull request #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build...

GitHub user HyukjinKwon opened a pull request:

    https://github.com/apache/spark/pull/21975

    [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnings

    ## What changes were proposed in this pull request?
    
    There are many warnings in the current build (for instance see https://amplab.cs.berkeley.edu/jenkins/job/spark-master-test-sbt-hadoop-2.7/4734/console).
    
    **common**:
    
    ```
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/kvstore/src/main/java/org/apache/spark/util/kvstore/LevelDB.java:237: warning: [rawtypes] found raw type: LevelDBIterator
    [warn]   void closeIterator(LevelDBIterator it) throws IOException {
    [warn]                      ^
    
    [warn]   missing type arguments for generic class LevelDBIterator<T>
    [warn]   where T is a type-variable:
    [warn]     T extends Object declared in class LevelDBIterator
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportServer.java:151: warning: [deprecation] group() in AbstractBootstrap has been deprecated
    [warn]     if (bootstrap != null && bootstrap.group() != null) {
    [warn]                                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportServer.java:152: warning: [deprecation] group() in AbstractBootstrap has been deprecated
    [warn]       bootstrap.group().shutdownGracefully();
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportServer.java:154: warning: [deprecation] childGroup() in ServerBootstrap has been deprecated
    [warn]     if (bootstrap != null && bootstrap.childGroup() != null) {
    [warn]                                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportServer.java:155: warning: [deprecation] childGroup() in ServerBootstrap has been deprecated
    [warn]       bootstrap.childGroup().shutdownGracefully();
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/util/NettyUtils.java:112: warning: [deprecation] PooledByteBufAllocator(boolean,int,int,int,int,int,int,int) in PooledByteBufAllocator has been deprecated
    [warn]     return new PooledByteBufAllocator(
    [warn]            ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/client/TransportClient.java:321: warning: [rawtypes] found raw type: Future
    [warn]     public void operationComplete(Future future) throws Exception {
    [warn]                                   ^
    
    [warn]   missing type arguments for generic class Future<V>
    [warn]   where V is a type-variable:
    [warn]     V extends Object declared in interface Future
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/client/TransportResponseHandler.java:215: warning: [rawtypes] found raw type: StreamInterceptor
    [warn]           StreamInterceptor interceptor = new StreamInterceptor(this, resp.streamId, resp.byteCount,
    [warn]           ^
    
    [warn]   missing type arguments for generic class StreamInterceptor<T>
    [warn]   where T is a type-variable:
    [warn]     T extends Message declared in class StreamInterceptor
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/client/TransportResponseHandler.java:215: warning: [rawtypes] found raw type: StreamInterceptor
    [warn]           StreamInterceptor interceptor = new StreamInterceptor(this, resp.streamId, resp.byteCount,
    [warn]                                               ^
    
    [warn]   missing type arguments for generic class StreamInterceptor<T>
    [warn]   where T is a type-variable:
    [warn]     T extends Message declared in class StreamInterceptor
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/client/TransportResponseHandler.java:215: warning: [unchecked] unchecked call to StreamInterceptor(MessageHandler<T>,String,long,StreamCallback) as a member of the raw type StreamInterceptor
    [warn]           StreamInterceptor interceptor = new StreamInterceptor(this, resp.streamId, resp.byteCount,
    [warn]                                           ^
    
    [warn]   where T is a type-variable:
    [warn]     T extends Message declared in class StreamInterceptor
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportRequestHandler.java:255: warning: [rawtypes] found raw type: StreamInterceptor
    [warn]         StreamInterceptor interceptor = new StreamInterceptor(this, wrappedCallback.getID(),
    [warn]         ^
    
    [warn]   missing type arguments for generic class StreamInterceptor<T>
    [warn]   where T is a type-variable:
    [warn]     T extends Message declared in class StreamInterceptor
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportRequestHandler.java:255: warning: [rawtypes] found raw type: StreamInterceptor
    [warn]         StreamInterceptor interceptor = new StreamInterceptor(this, wrappedCallback.getID(),
    [warn]                                             ^
    
    [warn]   missing type arguments for generic class StreamInterceptor<T>
    [warn]   where T is a type-variable:
    [warn]     T extends Message declared in class StreamInterceptor
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/server/TransportRequestHandler.java:255: warning: [unchecked] unchecked call to StreamInterceptor(MessageHandler<T>,String,long,StreamCallback) as a member of the raw type StreamInterceptor
    [warn]         StreamInterceptor interceptor = new StreamInterceptor(this, wrappedCallback.getID(),
    [warn]                                         ^
    
    [warn]   where T is a type-variable:
    [warn]     T extends Message declared in class StreamInterceptor
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/crypto/TransportCipher.java:270: warning: [deprecation] transfered() in FileRegion has been deprecated
    [warn]         region.transferTo(byteRawChannel, region.transfered());
    [warn]                                                 ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/main/java/org/apache/spark/network/sasl/SaslEncryption.java:304: warning: [deprecation] transfered() in FileRegion has been deprecated
    [warn]         region.transferTo(byteChannel, region.transfered());
    [warn]                                              ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/test/java/org/apache/spark/network/ProtocolSuite.java:119: warning: [deprecation] transfered() in FileRegion has been deprecated
    [warn]       while (in.transfered() < in.count()) {
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/network-common/src/test/java/org/apache/spark/network/ProtocolSuite.java:120: warning: [deprecation] transfered() in FileRegion has been deprecated
    [warn]         in.transferTo(channel, in.transfered());
    [warn]                                  ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/unsafe/src/test/java/org/apache/spark/unsafe/hash/Murmur3_x86_32Suite.java:80: warning: [static] static method should be qualified by type name, Murmur3_x86_32, instead of by an expression
    [warn]     Assert.assertEquals(-300363099, hasher.hashUnsafeWords(bytes, offset, 16, 42));
    [warn]                                           ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/unsafe/src/test/java/org/apache/spark/unsafe/hash/Murmur3_x86_32Suite.java:84: warning: [static] static method should be qualified by type name, Murmur3_x86_32, instead of by an expression
    [warn]     Assert.assertEquals(-1210324667, hasher.hashUnsafeWords(bytes, offset, 16, 42));
    [warn]                                            ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/common/unsafe/src/test/java/org/apache/spark/unsafe/hash/Murmur3_x86_32Suite.java:88: warning: [static] static method should be qualified by type name, Murmur3_x86_32, instead of by an expression
    [warn]     Assert.assertEquals(-634919701, hasher.hashUnsafeWords(bytes, offset, 16, 42));
    [warn]                                           ^
    ```
    
    **launcher**:
    
    ```
    [warn] Pruning sources from previous analysis, due to incompatible CompileSetup.
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/launcher/src/main/java/org/apache/spark/launcher/AbstractLauncher.java:31: warning: [rawtypes] found raw type: AbstractLauncher
    [warn] public abstract class AbstractLauncher<T extends AbstractLauncher> {
    [warn]                                                  ^
    [warn]   missing type arguments for generic class AbstractLauncher<T>
    [warn]   where T is a type-variable:
    [warn]     T extends AbstractLauncher declared in class AbstractLauncher
    ```
    
    **core**:
    
    ```
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/main/scala/org/apache/spark/api/r/RBackend.scala:99: method group in class AbstractBootstrap is deprecated: see corresponding Javadoc for more information.
    [warn]     if (bootstrap != null && bootstrap.group() != null) {
    [warn]                                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/main/scala/org/apache/spark/api/r/RBackend.scala:100: method group in class AbstractBootstrap is deprecated: see corresponding Javadoc for more information.
    [warn]       bootstrap.group().shutdownGracefully()
    [warn]                 ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/main/scala/org/apache/spark/api/r/RBackend.scala:102: method childGroup in class ServerBootstrap is deprecated: see corresponding Javadoc for more information.
    [warn]     if (bootstrap != null && bootstrap.childGroup() != null) {
    [warn]                                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/main/scala/org/apache/spark/api/r/RBackend.scala:103: method childGroup in class ServerBootstrap is deprecated: see corresponding Javadoc for more information.
    [warn]       bootstrap.childGroup().shutdownGracefully()
    [warn]                 ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/util/ClosureCleanerSuite.scala:151: reflective access of structural type member method getData should be enabled
    [warn] by making the implicit value scala.language.reflectiveCalls visible.
    [warn] This can be achieved by adding the import clause 'import scala.language.reflectiveCalls'
    [warn] or by setting the compiler option -language:reflectiveCalls.
    [warn] See the Scaladoc for value scala.language.reflectiveCalls for a discussion
    [warn] why the feature should be explicitly enabled.
    [warn]       val rdd = sc.parallelize(1 to 1).map(concreteObject.getData)
    [warn]                                                           ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/util/ClosureCleanerSuite.scala:175: reflective access of structural type member value innerObject2 should be enabled
    [warn] by making the implicit value scala.language.reflectiveCalls visible.
    [warn]       val rdd = sc.parallelize(1 to 1).map(concreteObject.innerObject2.getData)
    [warn]                                                           ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/util/ClosureCleanerSuite.scala:175: reflective access of structural type member method getData should be enabled
    [warn] by making the implicit value scala.language.reflectiveCalls visible.
    [warn]       val rdd = sc.parallelize(1 to 1).map(concreteObject.innerObject2.getData)
    [warn]                                                                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/LocalSparkContext.scala:32: constructor Slf4JLoggerFactory in class Slf4JLoggerFactory is deprecated: see corresponding Javadoc for more information.
    [warn]     InternalLoggerFactory.setDefaultFactory(new Slf4JLoggerFactory())
    [warn]                                             ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:218: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]         assert(wrapper.stageAttemptId === stages.head.attemptId)
    [warn]                                                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:261: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]       stageAttemptId = stages.head.attemptId))
    [warn]                                    ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:287: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]       stageAttemptId = stages.head.attemptId))
    [warn]                                    ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:471: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]       stageAttemptId = stages.last.attemptId))
    [warn]                                    ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:966: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]     listener.onTaskStart(SparkListenerTaskStart(dropped.stageId, dropped.attemptId, task))
    [warn]                                                                          ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:972: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]     listener.onTaskEnd(SparkListenerTaskEnd(dropped.stageId, dropped.attemptId,
    [warn]                                                                      ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:976: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]       .taskSummary(dropped.stageId, dropped.attemptId, Array(0.25d, 0.50d, 0.75d))
    [warn]                                             ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:1146: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]       SparkListenerTaskEnd(stage1.stageId, stage1.attemptId, "taskType", Success, tasks(1), null))
    [warn]                                                   ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/status/AppStatusListenerSuite.scala:1150: value attemptId in class StageInfo is deprecated: Use attemptNumber instead
    [warn]       SparkListenerTaskEnd(stage1.stageId, stage1.attemptId, "taskType", Success, tasks(0), null))
    [warn]                                                   ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/storage/DiskStoreSuite.scala:197: method transfered in trait FileRegion is deprecated: see corresponding Javadoc for more information.
    [warn]     while (region.transfered() < region.count()) {
    [warn]                   ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/core/src/test/scala/org/apache/spark/storage/DiskStoreSuite.scala:198: method transfered in trait FileRegion is deprecated: see corresponding Javadoc for more information.
    [warn]       region.transferTo(byteChannel, region.transfered())
    [warn]                                             ^
    ```
    
    **sql**:
    
    ```
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/analysis/AnalysisSuite.scala:534: abstract type T is unchecked since it is eliminated by erasure
    [warn]       assert(partitioning.isInstanceOf[T])
    [warn]                                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/analysis/AnalysisSuite.scala:534: abstract type T is unchecked since it is eliminated by erasure
    [warn]       assert(partitioning.isInstanceOf[T])
    [warn]             ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/expressions/ObjectExpressionsSuite.scala:323: inferred existential type Option[Class[_$1]]( forSome { type _$1 }), which cannot be expressed by wildcards,  should be enabled
    [warn] by making the implicit value scala.language.existentials visible.
    [warn] This can be achieved by adding the import clause 'import scala.language.existentials'
    [warn] or by setting the compiler option -language:existentials.
    [warn] See the Scaladoc for value scala.language.existentials for a discussion
    [warn] why the feature should be explicitly enabled.
    [warn]       val optClass = Option(collectionCls)
    [warn]                            ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetFileFormat.scala:368: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]         ParquetFileReader.readFooter(sharedConf, filePath, SKIP_ROW_GROUPS).getFileMetaData
    [warn]                           ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetFileFormat.scala:545: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]             ParquetFileReader.readFooter(
    [warn]                               ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:105: warning: [deprecation] readFooter(Configuration,Path,MetadataFilter) in ParquetFileReader has been deprecated
    [warn]       footer = readFooter(configuration, file, range(split.getStart(), split.getEnd()));
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:108: warning: [deprecation] filterRowGroups(Filter,List<BlockMetaData>,MessageType) in RowGroupFilter has been deprecated
    [warn]       blocks = filterRowGroups(filter, footer.getBlocks(), fileSchema);
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:111: warning: [deprecation] readFooter(Configuration,Path,MetadataFilter) in ParquetFileReader has been deprecated
    [warn]       footer = readFooter(configuration, file, NO_FILTER);
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:147: warning: [deprecation] ParquetFileReader(Configuration,FileMetaData,Path,List<BlockMetaData>,List<ColumnDescriptor>) in ParquetFileReader has been deprecated
    [warn]     this.reader = new ParquetFileReader(
    [warn]                   ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:203: warning: [deprecation] readFooter(Configuration,Path,MetadataFilter) in ParquetFileReader has been deprecated
    [warn]     ParquetMetadata footer = readFooter(config, file, range(0, length));
    [warn]                              ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:226: warning: [deprecation] ParquetFileReader(Configuration,FileMetaData,Path,List<BlockMetaData>,List<ColumnDescriptor>) in ParquetFileReader has been deprecated
    [warn]     this.reader = new ParquetFileReader(
    [warn]                   ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:178: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]             (descriptor.getType() == PrimitiveType.PrimitiveTypeName.INT32 ||
    [warn]                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:179: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]             (descriptor.getType() == PrimitiveType.PrimitiveTypeName.INT64  &&
    [warn]                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:181: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]             descriptor.getType() == PrimitiveType.PrimitiveTypeName.FLOAT ||
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:182: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]             descriptor.getType() == PrimitiveType.PrimitiveTypeName.DOUBLE ||
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:183: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]             descriptor.getType() == PrimitiveType.PrimitiveTypeName.BINARY))) {
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:198: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]         switch (descriptor.getType()) {
    [warn]                           ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:221: warning: [deprecation] getTypeLength() in ColumnDescriptor has been deprecated
    [warn]             readFixedLenByteArrayBatch(rowId, num, column, descriptor.getTypeLength());
    [warn]                                                                      ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:224: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]             throw new IOException("Unsupported type: " + descriptor.getType());
    [warn]                                                                    ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:246: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]       descriptor.getType().toString(),
    [warn]                 ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:258: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]     switch (descriptor.getType()) {
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java:384: warning: [deprecation] getType() in ColumnDescriptor has been deprecated
    [warn]         throw new UnsupportedOperationException("Unsupported type: " + descriptor.getType());
    [warn]                                                                                  ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/vectorized/ArrowColumnVector.java:458: warning: [static] static variable should be qualified by type name, BaseRepeatedValueVector, instead of by an expression
    [warn]       int index = rowId * accessor.OFFSET_WIDTH;
    [warn]                                   ^
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/vectorized/ArrowColumnVector.java:460: warning: [static] static variable should be qualified by type name, BaseRepeatedValueVector, instead of by an expression
    [warn]       int end = offsets.getInt(index + accessor.OFFSET_WIDTH);
    [warn]                                                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/BenchmarkQueryTest.scala:57: a pure expression does nothing in statement position; you may be omitting necessary parentheses
    [warn]       case s => s
    [warn]                 ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetInteroperabilitySuite.scala:182: inferred existential type org.apache.parquet.column.statistics.Statistics[?0]( forSome { type ?0 <: Comparable[?0] }), which cannot be expressed by wildcards,  should be enabled
    [warn] by making the implicit value scala.language.existentials visible.
    [warn] This can be achieved by adding the import clause 'import scala.language.existentials'
    [warn] or by setting the compiler option -language:existentials.
    [warn] See the Scaladoc for value scala.language.existentials for a discussion
    [warn] why the feature should be explicitly enabled.
    [warn]                 val columnStats = oneBlockColumnMeta.getStatistics
    [warn]                                                      ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/streaming/sources/ForeachBatchSinkSuite.scala:146: implicit conversion method conv should be enabled
    [warn] by making the implicit value scala.language.implicitConversions visible.
    [warn] This can be achieved by adding the import clause 'import scala.language.implicitConversions'
    [warn] or by setting the compiler option -language:implicitConversions.
    [warn] See the Scaladoc for value scala.language.implicitConversions for a discussion
    [warn] why the feature should be explicitly enabled.
    [warn]     implicit def conv(x: (Int, Long)): KV = KV(x._1, x._2)
    [warn]                  ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/streaming/continuous/shuffle/ContinuousShuffleSuite.scala:48: implicit conversion method unsafeRow should be enabled
    [warn] by making the implicit value scala.language.implicitConversions visible.
    [warn]   private implicit def unsafeRow(value: Int) = {
    [warn]                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetInteroperabilitySuite.scala:176: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]                   ParquetFileReader.readFooter(hadoopConf, part.getPath, NO_FILTER)
    [warn]                                     ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetInteroperabilitySuite.scala:178: method getType in class ColumnDescriptor is deprecated: see corresponding Javadoc for more information.
    [warn]                 assert(oneFooter.getFileMetaData.getSchema.getColumns.get(0).getType() ===
    [warn]                                                                              ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetTest.scala:154: method readAllFootersInParallel in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]     ParquetFileReader.readAllFootersInParallel(configuration, fs.getFileStatus(path)).asScala.toSeq
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetTest.scala:158: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]     ParquetFileReader.readFooter(
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/hive/src/test/scala/org/apache/spark/sql/hive/execution/HiveDDLSuite.scala:2117: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]         val footer = ParquetFileReader.readFooter(
    [warn]                                        ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/hive/src/test/java/org/apache/spark/sql/hive/test/Complex.java:679: warning: [cast] redundant cast to Complex
    [warn]     Complex typedOther = (Complex)other;
    [warn]                          ^
    ```
    
    **mllib**:
    
    ```
    [warn] Pruning sources from previous analysis, due to incompatible CompileSetup.
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/mllib/src/test/scala/org/apache/spark/ml/recommendation/ALSSuite.scala:597: match may not be exhaustive.
    [warn] It would fail on the following inputs: None, Some((x: Tuple2[?, ?] forSome x not in (?, ?)))
    [warn]     val df = dfs.find {
    [warn]                       ^
    ```
    
    This PR does not target fix all of them since some look pretty tricky to fix and there look too many warnings including false positive (like deprecated API but it's used in its test, etc.)
    
    ## How was this patch tested?
    
    Existing tests should cover this.


You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/HyukjinKwon/spark remove-build-warnings

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/spark/pull/21975.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #21975
    
----
commit b1f7294bb5e7e1cadd4fa44a0f7b0cbdaecb3c8c
Author: hyukjinkwon <gu...@...>
Date:   2018-08-02T17:18:17Z

    Fix miscellaneous build warnings

----


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94095 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94095/testReport)** for PR 21975 at commit [`9c5ba2b`](https://github.com/apache/spark/commit/9c5ba2bf89b220b66be8818f30cece9f095bcc3b).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94211 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94211/testReport)** for PR 21975 at commit [`6e85fc6`](https://github.com/apache/spark/commit/6e85fc651b59109b82899958b0c58ff5838e3d92).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94203 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94203/testReport)** for PR 21975 at commit [`6e85fc6`](https://github.com/apache/spark/commit/6e85fc651b59109b82899958b0c58ff5838e3d92).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207542952
  
    --- Diff: sql/hive/src/test/java/org/apache/spark/sql/hive/test/Complex.java ---
    @@ -676,7 +676,7 @@ public int compareTo(Complex other) {
         }
     
         int lastComparison = 0;
    -    Complex typedOther = (Complex)other;
    +    Complex typedOther = other;
    --- End diff --
    
    I hadn't touched code that seemed to be copied from Hive (it generates a ton of warnings) but think it's fine to make this change.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94120 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94120/testReport)** for PR 21975 at commit [`cbbeab2`](https://github.com/apache/spark/commit/cbbeab2c36f13f636c0b026580138776bad393ea).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94120 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94120/testReport)** for PR 21975 at commit [`cbbeab2`](https://github.com/apache/spark/commit/cbbeab2c36f13f636c0b026580138776bad393ea).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207542808
  
    --- Diff: sql/core/src/main/java/org/apache/spark/sql/vectorized/ArrowColumnVector.java ---
    @@ -455,9 +455,9 @@ final boolean isNullAt(int rowId) {
         @Override
         final ColumnarArray getArray(int rowId) {
           ArrowBuf offsets = accessor.getOffsetBuffer();
    -      int index = rowId * accessor.OFFSET_WIDTH;
    +      int index = rowId * BaseRepeatedValueVector.OFFSET_WIDTH;
    --- End diff --
    
    I had used `ListVector` here although it's actually defined in the superclass. `ListVector` was the type of `accessor`. Either is OK and I'd generally favor your change; `ListVector` is super conservative.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1740/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1801/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1685/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207542400
  
    --- Diff: sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java ---
    @@ -174,13 +174,15 @@ void readBatch(int total, WritableColumnVector column) throws IOException {
     
             // TIMESTAMP_MILLIS encoded as INT64 can't be lazily decoded as we need to post process
             // the values to add microseconds precision.
    +        PrimitiveType.PrimitiveTypeName typeName =
    +          descriptor.getPrimitiveType().getPrimitiveTypeName();
             if (column.hasDictionary() || (rowId == 0 &&
    -            (descriptor.getType() == PrimitiveType.PrimitiveTypeName.INT32 ||
    -            (descriptor.getType() == PrimitiveType.PrimitiveTypeName.INT64  &&
    +            (typeName == PrimitiveType.PrimitiveTypeName.INT32 ||
    --- End diff --
    
    Same comment about Parquet, though I remain a little uneasy about it. I just know it's a little more possible for different older Parquet to come in at runtime, and if we're changing to use a newer field that doesn't exist in older versions, could break. That said, I only didn't touch it because I didn't investigate. I also think that if older Parquet is on the classpath we have bigger problems, potentially. Especially if the newer field/method has existed for several versions, this seems OK.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94036 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94036/testReport)** for PR 21975 at commit [`b1f7294`](https://github.com/apache/spark/commit/b1f7294bb5e7e1cadd4fa44a0f7b0cbdaecb3c8c).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `public abstract class AbstractLauncher<T extends AbstractLauncher<T>> `


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94036/
    Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build...

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207459831
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetFileFormat.scala ---
    @@ -539,11 +539,10 @@ object ParquetFileFormat extends Logging {
           parFiles.flatMap { currentFile =>
             try {
               // Skips row group information since we only need the schema.
    -          // ParquetFileReader.readFooter throws RuntimeException, instead of IOException,
    +          // ParquetUtils.readFooter throws RuntimeException, instead of IOException,
               // when it can't read the footer.
               Some(new Footer(currentFile.getPath(),
    --- End diff --
    
    Seems it can't replace this here for now since it looks causing resource leak. I filed a JIRA https://issues.apache.org/jira/browse/PARQUET-1368


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207542543
  
    --- Diff: sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/VectorizedColumnReader.java ---
    @@ -195,7 +197,7 @@ void readBatch(int total, WritableColumnVector column) throws IOException {
               decodeDictionaryIds(0, rowId, column, column.getDictionaryIds());
             }
             column.setDictionary(null);
    -        switch (descriptor.getType()) {
    +        switch (descriptor.getPrimitiveType().getPrimitiveTypeName()) {
    --- End diff --
    
    Can you use `typeName` here too?


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207541708
  
    --- Diff: common/network-common/src/main/java/org/apache/spark/network/util/NettyUtils.java ---
    @@ -111,24 +110,14 @@ public static PooledByteBufAllocator createPooledByteBufAllocator(
         }
         return new PooledByteBufAllocator(
           allowDirectBufs && PlatformDependent.directBufferPreferred(),
    -      Math.min(getPrivateStaticField("DEFAULT_NUM_HEAP_ARENA"), numCores),
    -      Math.min(getPrivateStaticField("DEFAULT_NUM_DIRECT_ARENA"), allowDirectBufs ? numCores : 0),
    -      getPrivateStaticField("DEFAULT_PAGE_SIZE"),
    -      getPrivateStaticField("DEFAULT_MAX_ORDER"),
    -      allowCache ? getPrivateStaticField("DEFAULT_TINY_CACHE_SIZE") : 0,
    -      allowCache ? getPrivateStaticField("DEFAULT_SMALL_CACHE_SIZE") : 0,
    -      allowCache ? getPrivateStaticField("DEFAULT_NORMAL_CACHE_SIZE") : 0
    +      Math.min(PooledByteBufAllocator.defaultNumHeapArena(), numCores),
    --- End diff --
    
    I had shied away from touching the Netty warnings in the past because of some uncertainty about different versions coming in at runtime, but, I think that's not a valid concern now. I think this is good to fix up. Anything that's in Netty 4.1+ is fair game.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    cc @srowen 


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1794/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    retest this please


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Ooops, i didn't know you were looking into this @srowen. Thanks for reviewing this. Will make some changes per the review comments.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1726/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94091/
    Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94096/
    Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94120/
    Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94095/
    Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1731/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1730/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94096 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94096/testReport)** for PR 21975 at commit [`2354e10`](https://github.com/apache/spark/commit/2354e10bd82f4770fc58feb5ac2738dd0dd39070).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `public abstract class AbstractLauncher<T extends AbstractLauncher<T>> `


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94036 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94036/testReport)** for PR 21975 at commit [`b1f7294`](https://github.com/apache/spark/commit/b1f7294bb5e7e1cadd4fa44a0f7b0cbdaecb3c8c).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94112 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94112/testReport)** for PR 21975 at commit [`abb567b`](https://github.com/apache/spark/commit/abb567b3847d9e3e30f95b699cf2c4f412b05338).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94203/
    Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94096 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94096/testReport)** for PR 21975 at commit [`2354e10`](https://github.com/apache/spark/commit/2354e10bd82f4770fc58feb5ac2738dd0dd39070).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94091 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94091/testReport)** for PR 21975 at commit [`f9cc06c`](https://github.com/apache/spark/commit/f9cc06c6a7364b1ef1f03bbdf7bd3d9fef07bdac).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build...

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207459749
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetFileFormat.scala ---
    @@ -539,11 +539,10 @@ object ParquetFileFormat extends Logging {
           parFiles.flatMap { currentFile =>
             try {
               // Skips row group information since we only need the schema.
    -          // ParquetFileReader.readFooter throws RuntimeException, instead of IOException,
    +          // ParquetUtils.readFooter throws RuntimeException, instead of IOException,
               // when it can't read the footer.
               Some(new Footer(currentFile.getPath(),
    --- End diff --
    
    We can replace this here since it looks causing resource leak. I filed a JIRA https://issues.apache.org/jira/browse/PARQUET-1368


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94112/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/94211/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/1747/
    Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21975#discussion_r207701268
  
    --- Diff: sql/hive/src/test/java/org/apache/spark/sql/hive/test/Complex.java ---
    @@ -676,7 +676,7 @@ public int compareTo(Complex other) {
         }
     
         int lastComparison = 0;
    -    Complex typedOther = (Complex)other;
    +    Complex typedOther = other;
    --- End diff --
    
    Yes .. it does generated a hell of a lot and some looked probably false positive or required .. I don't have nerve to fix them .. but this one looked obvious.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94203 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94203/testReport)** for PR 21975 at commit [`6e85fc6`](https://github.com/apache/spark/commit/6e85fc651b59109b82899958b0c58ff5838e3d92).
     * This patch **fails MiMa tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test PASSed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark pull request #21975: [SPARK-25001][BUILD] Fix miscellaneous build warn...

Posted by asfgit <gi...@git.apache.org>.
Github user asfgit closed the pull request at:

    https://github.com/apache/spark/pull/21975


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94112 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94112/testReport)** for PR 21975 at commit [`abb567b`](https://github.com/apache/spark/commit/abb567b3847d9e3e30f95b699cf2c4f412b05338).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    **[Test build #94211 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94211/testReport)** for PR 21975 at commit [`6e85fc6`](https://github.com/apache/spark/commit/6e85fc651b59109b82899958b0c58ff5838e3d92).


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by HyukjinKwon <gi...@git.apache.org>.
Github user HyukjinKwon commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Note that 
    
    ```
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetFileFormat.scala:368: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]         ParquetFileReader.readFooter(sharedConf, filePath, SKIP_ROW_GROUPS).getFileMetaData
    [warn]                           ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetFileFormat.scala:545: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]             ParquetFileReader.readFooter(
    [warn]                               ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:105: warning: [deprecation] readFooter(Configuration,Path,MetadataFilter) in ParquetFileReader has been deprecated
    [warn]       footer = readFooter(configuration, file, range(split.getStart(), split.getEnd()));
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:108: warning: [deprecation] filterRowGroups(Filter,List<BlockMetaData>,MessageType) in RowGroupFilter has been deprecated
    [warn]       blocks = filterRowGroups(filter, footer.getBlocks(), fileSchema);
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:111: warning: [deprecation] readFooter(Configuration,Path,MetadataFilter) in ParquetFileReader has been deprecated
    [warn]       footer = readFooter(configuration, file, NO_FILTER);
    [warn]                ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:147: warning: [deprecation] ParquetFileReader(Configuration,FileMetaData,Path,List<BlockMetaData>,List<ColumnDescriptor>) in ParquetFileReader has been deprecated
    [warn]     this.reader = new ParquetFileReader(
    [warn]                   ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/main/java/org/apache/spark/sql/execution/datasources/parquet/SpecificParquetRecordReaderBase.java:203: warning: [deprecation] readFooter(Configuration,Path,MetadataFilter) in ParquetFileReader has been deprecated
    [warn]     ParquetMetadata footer = readFooter(config, file, range(0, length));
    [warn]                              ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetInteroperabilitySuite.scala:176: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]                   ParquetFileReader.readFooter(hadoopConf, part.getPath, NO_FILTER)
    [warn]                                     ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/core/src/test/scala/org/apache/spark/sql/execution/datasources/parquet/ParquetTest.scala:158: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]     ParquetFileReader.readFooter(
    [warn]                       ^
    
    [warn] /home/jenkins/workspace/spark-master-test-maven-hadoop-2.7/sql/hive/src/test/scala/org/apache/spark/sql/hive/execution/HiveDDLSuite.scala:2117: method readFooter in object ParquetFileReader is deprecated: see corresponding Javadoc for more information.
    [warn]         val footer = ParquetFileReader.readFooter(
    [warn]                                        ^
    ```
    
    are not handled here. Those were reverted in cbbeab2c36f13f636c0b026580138776bad393ea per PARQUET-1368
    
    Now the left changes are pretty safe ones.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [SPARK-25001][BUILD] Fix miscellaneous build warnings

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org


[GitHub] spark issue #21975: [WIP][SPARK-25001][BUILD] Fix miscellaneous build warnin...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/21975
  
    Merged build finished. Test FAILed.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org