@InterfaceAudience.Private public class FanOutOneBlockAsyncDFSOutput extends Object implements AsyncFSOutput
Use the createOutput method in FanOutOneBlockAsyncDFSOutputHelper to create. The mainly
usage of this class is implementing WAL, so we only expose a little HDFS configurations in the
method. And we place it here under io package because we want to make it independent of WAL
implementation thus easier to move it to HDFS project finally.
Note that, although we support pipelined flush, i.e, write new data and then flush before the previous flush succeeds, the implementation is not thread safe, so you should not call its methods concurrently.
Advantages compare to DFSOutputStream:
| Modifier and Type | Method and Description |
|---|---|
int |
buffered()
Return the current size of buffered data.
|
void |
close()
End the current block and complete file at namenode.
|
CompletableFuture<Long> |
flush(boolean syncBlock)
Flush the buffer out to datanodes.
|
org.apache.hadoop.hdfs.protocol.DatanodeInfo[] |
getPipeline()
Return current pipeline.
|
boolean |
isBroken()
Whether the stream is broken.
|
void |
recoverAndClose(CancelableProgressable reporter)
The close method when error occurred.
|
void |
write(byte[] b)
Just call write(b, 0, b.length).
|
void |
write(byte[] b,
int off,
int len)
Copy the data into the buffer.
|
void |
write(ByteBuffer bb)
Copy the data in the given
bb into the buffer. |
void |
writeInt(int i)
Write an int to the buffer.
|
public void writeInt(int i)
AsyncFSOutputwriteInt in interface AsyncFSOutputpublic void write(ByteBuffer bb)
AsyncFSOutputbb into the buffer.write in interface AsyncFSOutputpublic void write(byte[] b)
AsyncFSOutputwrite in interface AsyncFSOutputAsyncFSOutput.write(byte[], int, int)public void write(byte[] b,
int off,
int len)
AsyncFSOutputAsyncFSOutput.flush(boolean) to flush the
buffer manually.write in interface AsyncFSOutputpublic int buffered()
AsyncFSOutputbuffered in interface AsyncFSOutputpublic org.apache.hadoop.hdfs.protocol.DatanodeInfo[] getPipeline()
AsyncFSOutputgetPipeline in interface AsyncFSOutputpublic CompletableFuture<Long> flush(boolean syncBlock)
flush in interface AsyncFSOutputsyncBlock - will call hsync if true, otherwise hflush.public void recoverAndClose(CancelableProgressable reporter) throws IOException
recoverAndClose in interface AsyncFSOutputIOExceptionpublic void close()
throws IOException
recoverAndClose(CancelableProgressable) if this method throws an exception.close in interface Closeableclose in interface AutoCloseableclose in interface AsyncFSOutputIOExceptionpublic boolean isBroken()
AsyncFSOutputisBroken in interface AsyncFSOutputCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.