You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@hbase.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2014/03/14 22:48:01 UTC

Build failed in Jenkins: HBase-0.94.18 #16

See <https://builds.apache.org/job/HBase-0.94.18/16/>

------------------------------------------
[...truncated 5369 lines...]
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public Void put(ByteBuffer table, APut aput) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:436: cannot find symbol
[WARNING] symbol  : class AIOError
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public Void put(ByteBuffer table, APut aput) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:456: cannot find symbol
[WARNING] symbol  : class ADelete
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public Void delete(ByteBuffer table, ADelete adelete) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:456: cannot find symbol
[WARNING] symbol  : class AIOError
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public Void delete(ByteBuffer table, ADelete adelete) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:476: cannot find symbol
[WARNING] symbol  : class AIOError
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public long incrementColumnValue(ByteBuffer table, ByteBuffer row, ByteBuffer family, ByteBuffer qualifier, long amount, boolean writeToWAL) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:499: cannot find symbol
[WARNING] symbol  : class AScan
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public int scannerOpen(ByteBuffer table, AScan ascan) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:499: cannot find symbol
[WARNING] symbol  : class AIOError
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public int scannerOpen(ByteBuffer table, AScan ascan) throws AIOError {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:519: cannot find symbol
[WARNING] symbol  : class AIOError
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public Void scannerClose(int scannerId) throws AIOError, AIllegalArgument {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:519: cannot find symbol
[WARNING] symbol  : class AIllegalArgument
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public Void scannerClose(int scannerId) throws AIOError, AIllegalArgument {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:537: cannot find symbol
[WARNING] symbol  : class AResult
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public GenericArray<AResult> scannerGetRows(int scannerId, int numberOfRows) throws AIOError, AIllegalArgument {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:537: cannot find symbol
[WARNING] symbol  : class AIOError
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public GenericArray<AResult> scannerGetRows(int scannerId, int numberOfRows) throws AIOError, AIllegalArgument {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/avro/AvroServer.java>:537: cannot find symbol
[WARNING] symbol  : class AIllegalArgument
[WARNING] location: class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
[WARNING] public GenericArray<AResult> scannerGetRows(int scannerId, int numberOfRows) throws AIOError, AIllegalArgument {
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/RSStatusServlet.java>:29: package org.apache.hadoop.hbase.tmpl.regionserver does not exist
[WARNING] import org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl;
[WARNING] ^
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseFileSystem.java>:175: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseFileSystem.java>:203: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseFileSystem.java>:228: warning - @param argument "dir" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:36: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:43: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:50: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:36: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:36: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:43: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:43: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:50: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:50: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/FileLink.java>:89: warning - Tag @link: reference not found: CleanerChore
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/BlockCache.java>:56: warning - Tag @see cannot be used in inline documentation.  It can only be used in the following types of documentation: overview, package, class/interface, constructor, field, method.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/BlockCache.java>:56: warning - Tag @see cannot be used in inline documentation.  It can only be used in the following types of documentation: overview, package, class/interface, constructor, field, method.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/HFileBlock.java>:628: warning - Tag @link: can't find startWriting(BlockType, boolean) in org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/HFileBlock.java>:628: warning - Tag @link: can't find getHeaderAndData() in org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/HFileBlock.java>:734: warning - @param argument "dataBlockEncoderAlgo" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/HFileReaderV1.java>:418: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/LruBlockCache.java>:355: warning - Tag @see cannot be used in inline documentation.  It can only be used in the following types of documentation: overview, package, class/interface, constructor, field, method.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/BlockCache.java>:56: warning - Tag @see cannot be used in inline documentation.  It can only be used in the following types of documentation: overview, package, class/interface, constructor, field, method.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/io/hfile/BlockCache.java>:56: warning - Tag @see cannot be used in inline documentation.  It can only be used in the following types of documentation: overview, package, class/interface, constructor, field, method.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/zookeeper/ZKTableReadOnly.java>:52: warning - Tag @link: can't find isDisabledTable(String) in org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/zookeeper/ZKUtil.java>:1276: warning - Tag @link: reference not found: ZKOp
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/zookeeper/ZKUtil.java>:1358: warning - Tag @return cannot be used in class documentation.  It can only be used in the following types of documentation: method.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/ByteBufferUtils.java>:409: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/ByteBufferUtils.java>:386: warning - @param argument "rightArray" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/ChecksumFactory.java>:57: warning - @param argument "theClass" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/ChecksumType.java>:172: warning - @param argument "b" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/FSUtils.java>:1300: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/FSUtils.java>:1351: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/FSUtils.java>:131: warning - DEFAULT_BUFFER_SIZE (referenced by @value tag) is an unknown reference.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/FSUtils.java>:154: warning - DEFAULT_BUFFER_SIZE (referenced by @value tag) is an unknown reference.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/HBaseFsckRepair.java>:87: warning - @param argument "conf" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/HFileArchiveUtil.java>:50: warning - @param argument "family" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/RegionSplitter.java>:149: warning - Tag @link: can't find rollingSplit(String, String, Configuration) in org.apache.hadoop.hbase.util.RegionSplitter
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HTableInterface.java>:512: warning - Tag @link: can't find autoFlush in org.apache.hadoop.hbase.client.HTableInterface
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HTableInterface.java>:512: warning - Tag @link: can't find autoFlush in org.apache.hadoop.hbase.client.HTableInterface
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HTableInterface.java>:512: warning - Tag @link: can't find clearBufferOnFail in org.apache.hadoop.hbase.client.HTableInterface
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:91: warning - @param argument "region" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:99: warning - @param argument "region" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:99: warning - @param argument "timestamp" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:114: warning - @param argument "region" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:114: warning - @param argument "CF" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:123: warning - @param argument "region" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:123: warning - @param argument "CF" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:131: warning - @param argument "region" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/ipc/HRegionInterface.java>:676: warning - @param argument "Scan" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HConnectionManager.java>:1498: warning - @returns is an unknown tag.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HBaseAdmin.java>:545: warning - @link: is an unknown tag.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HBaseAdmin.java>:545: warning - @link: is an unknown tag.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HConnection.java>:351: warning - Tag @link: can't find withoutRetries(ServerCallable) in org.apache.hadoop.hbase.client.HConnectionManager
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HConnection.java>:338: warning - Tag @link: can't find withoutRetries(ServerCallable) in org.apache.hadoop.hbase.client.HConnectionManager
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HTable.java>:514: warning - @param argument "startRow" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HTable.java>:514: warning - @param argument "endRow" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/HTableInterface.java>:274: warning - @param argument "arm" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java>:276: warning - @Deprecated is an unknown tag -- same as a known tag except for case.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java>:276: warning - @param argument "connection" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/ServerCallable.java>:148: warning - @param argument "<T>" is not a type parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/ServerCallable.java>:223: warning - @param argument "<T>" is not a type parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/client/UserProvider.java>:99: warning - @param argument "conf" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/master/SplitLogManager.java>:138: warning - Tag @link: can't find SplitLogManager(ZooKeeperWatcher, Configuration,
[WARNING] Stoppable, String, TaskFinisher) in org.apache.hadoop.hbase.master.SplitLogManager
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/master/handler/ServerShutdownHandler.java>:384: warning - @param argument "hris" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/master/cleaner/TimeToLiveHFileCleaner.java>:32: warning - TimeToLiveHFileCleaner#DEFAULT_TTL (referenced by @value tag) is an unknown reference.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/replication/regionserver/ReplicationHLogReaderManager.java>:64: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/coprocessor/RegionObserver.java>:244: warning - @param argument "scantype" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/coprocessor/example/BulkDeleteProtocol.java>:82: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java>:442: warning - @param argument "conf" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java>:4366: warning - @param argument "boolean" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java>:4394: warning - @param argument "boolean" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java>:4394: warning - @param argument "boolean" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/RegionCoprocessorHost.java>:531: warning - Tag @link: can't find preFlush(ObserverContext, Store, KeyValueScanner) in org.apache.hadoop.hbase.coprocessor.RegionObserver
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/RegionSplitPolicy.java>:98: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/RegionSplitPolicy.java>:98: warning - @param argument "htd" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/StoreFile.java>:94: warning - Tag @link: can't find WriterBuilder in org.apache.hadoop.hbase.regionserver.StoreFile
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/StoreFile.java>:254: warning - @param argument "blockcache" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/StoreFileScanner.java>:221: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionRequest.java>:124: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactSelection.java>:134: warning - @return tag has no arguments.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactSelection.java>:134: warning - @param argument "currentHour" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/regionserver/metrics/OperationMetrics.java>:99: warning - @param argument "conf" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/fs/HFileSystem.java>:56: warning - @param argument "useHBaseChecksums" is not a parameter name.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/mapreduce/MultithreadedTableMapper.java>:62: warning - Tag @link: can't find setMapperClass(Configuration, Class) in org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/mapreduce/MultithreadedTableMapper.java>:62: warning - Missing closing '}' character for inline tag: "{@link #getNumberOfThreads(Configuration) method. The default
[WARNING] value is 10 threads.
[WARNING] <p>"
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:36: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:43: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/HBaseIOException.java>:50: warning - Tag @inheritDoc cannot be used in constructor documentation.  It can only be used in the following types of documentation: method, inline text.
[INFO] Generating "Source Xref" report    --- maven-jxr-plugin:2.1
[INFO] Generating "Test Source Xref" report    --- maven-jxr-plugin:2.1
[INFO] Generating "RAT Report" report    --- apache-rat-plugin:0.8
[INFO] No excludes
[INFO] Generating "Surefire Report" report    --- maven-surefire-report-plugin:2.7.2
[INFO] 
[INFO] --- maven-antrun-plugin:1.6:run (arc-setup) @ hbase ---
[WARNING] Parameter tasks is deprecated, use target instead
[INFO] Executing tasks

main:
[INFO] Executed tasks
[INFO] 
[INFO] --- avro-maven-plugin:1.5.3:schema (generate-avro-sources) @ hbase ---
[INFO] 
[INFO] --- avro-maven-plugin:1.5.3:protocol (generate-avro-sources) @ hbase ---
[INFO] 
[INFO] --- maven-antrun-plugin:1.6:run (generate) @ hbase ---
[INFO] Executing tasks

main:
14/03/14 21:47:42 INFO mortbay.log: Logging to org.slf4j.impl.Log4jLoggerAdapter(org.mortbay.log) via org.mortbay.log.Slf4jLog
[INFO] Executed tasks
[INFO] 
[INFO] --- build-helper-maven-plugin:1.5:add-source (jspcSource-packageInfo-Avro-source) @ hbase ---
[INFO] Source directory: <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/target/generated-jamon> added.
[INFO] Source directory: <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/target/generated-sources/java> added.
[INFO] 
[INFO] --- jamon-maven-plugin:2.3.4:translate (default) @ hbase ---
[INFO] 
[INFO] --- maven-remote-resources-plugin:1.1:process (default) @ hbase ---
[INFO] Setting property: classpath.resource.loader.class => 'org.codehaus.plexus.velocity.ContextClassLoaderResourceLoader'.
[INFO] Setting property: velocimacro.messages.on => 'false'.
[INFO] Setting property: resource.loader => 'classpath'.
[INFO] Setting property: resource.manager.logwhenfound => 'false'.
[INFO] 
[INFO] --- maven-resources-plugin:2.4:resources (default-resources) @ hbase ---
[INFO] Using 'UTF-8' encoding to copy filtered resources.
[INFO] Copying 1 resource
[INFO] Copying 12 resources
[INFO] Copying 3 resources
[INFO] 
[INFO] --- maven-antrun-plugin:1.6:run (default) @ hbase ---
[INFO] Executing tasks

main:
    [mkdir] Created dir: <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/target/nativelib>
     [exec] tar: hadoop-snappy-nativelibs.tar: Cannot open: No such file or directory
     [exec] tar: Error is not recoverable: exiting now
     [exec] Result: 2
[INFO] Executed tasks
[INFO] 
[INFO] --- maven-compiler-plugin:2.5.1:compile (default-compile) @ hbase ---
[INFO] Compiling 842 source files to <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/target/classes>
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/Bytes.java>:[44,15] sun.misc.Unsafe is Sun proprietary API and may be removed in a future release
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/Bytes.java>:[1051,19] sun.misc.Unsafe is Sun proprietary API and may be removed in a future release
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/Bytes.java>:[1057,21] sun.misc.Unsafe is Sun proprietary API and may be removed in a future release
[WARNING] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/main/java/org/apache/hadoop/hbase/util/Bytes.java>:[1062,28] sun.misc.Unsafe is Sun proprietary API and may be removed in a future release
[INFO] 
[INFO] --- build-helper-maven-plugin:1.5:add-test-resource (add-test-resource) @ hbase ---
[INFO] 
[INFO] --- maven-resources-plugin:2.4:testResources (default-testResources) @ hbase ---
[INFO] Using 'UTF-8' encoding to copy filtered resources.
[INFO] Copying 4 resources
[INFO] Copying 3 resources
[INFO] Copying 1 resource
[INFO] 
[INFO] --- maven-compiler-plugin:2.5.1:testCompile (default-testCompile) @ hbase ---
[INFO] Compiling 477 source files to <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/target/test-classes>
[INFO] -------------------------------------------------------------
[ERROR] COMPILATION ERROR : 
[INFO] -------------------------------------------------------------
[ERROR] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegion.java>:[3265,15] cannot find symbol
symbol  : class DroppedSnapshotException
location: class org.apache.hadoop.hbase.regionserver.TestHRegion
[INFO] 1 error
[INFO] -------------------------------------------------------------
[INFO] ------------------------------------------------------------------------
[INFO] BUILD FAILURE
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 2:27.273s
[INFO] Finished at: Fri Mar 14 21:47:59 UTC 2014
[INFO] Final Memory: 49M/654M
[INFO] ------------------------------------------------------------------------
[ERROR] Failed to execute goal org.apache.maven.plugins:maven-compiler-plugin:2.5.1:testCompile (default-testCompile) on project hbase: Compilation failure
[ERROR] <https://builds.apache.org/job/HBase-0.94.18/ws/trunk/src/test/java/org/apache/hadoop/hbase/regionserver/TestHRegion.java>:[3265,15] cannot find symbol
[ERROR] symbol  : class DroppedSnapshotException
[ERROR] location: class org.apache.hadoop.hbase.regionserver.TestHRegion
[ERROR] -> [Help 1]
[ERROR] 
[ERROR] To see the full stack trace of the errors, re-run Maven with the -e switch.
[ERROR] Re-run Maven using the -X switch to enable full debug logging.
[ERROR] 
[ERROR] For more information about the errors and possible solutions, please read the following articles:
[ERROR] [Help 1] http://cwiki.apache.org/confluence/display/MAVEN/MojoFailureException
Build step 'Invoke top-level Maven targets' marked build as failure
Archiving artifacts
Recording test results

Jenkins build is back to normal : HBase-0.94.18 #17

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/HBase-0.94.18/17/changes>