Class DummyDFSOutputStream

java.lang.Object
java.io.OutputStream
org.apache.hadoop.fs.FSOutputSummer
org.apache.hadoop.hdfs.DFSOutputStream
org.apache.hadoop.hdfs.DummyDFSOutputStream
All Implemented Interfaces:
Closeable, Flushable, AutoCloseable, org.apache.hadoop.fs.CanSetDropBehind, org.apache.hadoop.fs.StreamCapabilities, org.apache.hadoop.fs.Syncable

@Private public final class DummyDFSOutputStream extends org.apache.hadoop.hdfs.DFSOutputStream
A dummy DFSOutputStream which is mainly used for lease renewal.

We have to put it under this package as we want to override a package private method.

  • Nested Class Summary

    Nested classes/interfaces inherited from interface org.apache.hadoop.fs.StreamCapabilities

    org.apache.hadoop.fs.StreamCapabilities.StreamCapability
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private final AsyncFSOutput
     

    Fields inherited from class org.apache.hadoop.hdfs.DFSOutputStream

    blockSize, byteArrayManager, bytesPerChecksum, cachingStrategy, chunksPerPacket, closed, CREATE_RETRY_COUNT, currentPacket, dfsClient, fileId, initialFileSize, lastFlushOffset, LOG, packetSize, shouldSyncBlock, src, streamer, SUPPORTED_CRYPTO_VERSIONS

    Fields inherited from interface org.apache.hadoop.fs.StreamCapabilities

    ABORTABLE_STREAM, DROPBEHIND, HFLUSH, HSYNC, IOSTATISTICS, IOSTATISTICS_CONTEXT, PREADBYTEBUFFER, READAHEAD, READBYTEBUFFER, UNBUFFER, VECTOREDIO
  • Constructor Summary

    Constructors
    Constructor
    Description
    DummyDFSOutputStream(AsyncFSOutput output, org.apache.hadoop.hdfs.DFSClient dfsClient, String src, org.apache.hadoop.hdfs.protocol.HdfsFileStatus stat, EnumSet<org.apache.hadoop.fs.CreateFlag> flag, org.apache.hadoop.util.DataChecksum checksum)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    void
     
    void
     

    Methods inherited from class org.apache.hadoop.hdfs.DFSOutputStream

    addBlock, adjustChunkBoundary, checkClosed, closeImpl, closeThreads, completeFile, completeFile, computePacketChunkSize, createPacket, createWriteTraceScope, endBlock, enqueueCurrentPacket, enqueueCurrentPacketFull, flushInternal, flushInternalWithoutWaitingAck, getAddBlockFlags, getBlock, getBlockToken, getCurrentBlockReplication, getFileEncryptionInfo, getFileId, getInitialLen, getNamespace, getNumCurrentReplicas, getPipeline, getSrc, getStreamer, getUniqKey, hasCapability, hflush, hsync, hsync, isClosed, isLeaseRecovered, newStreamForAppend, newStreamForCreate, recoverLease, setAppendChunk, setArtificialSlowdown, setBytesCurBlock, setChunksPerPacket, setClosed, setCurrentPacketToEmpty, setDropBehind, start, toString, writeChunk, writeChunk

    Methods inherited from class org.apache.hadoop.fs.FSOutputSummer

    convertToByteStream, flush, flushBuffer, flushBuffer, getBufferedDataSize, getChecksumSize, getDataChecksum, resetChecksumBufSize, setChecksumBufSize, write, write

    Methods inherited from class java.io.OutputStream

    nullOutputStream, write

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait