Package | Description |
---|---|
org.apache.flink.runtime.io.disk | |
org.apache.flink.runtime.io.disk.iomanager | |
org.apache.flink.runtime.operators.hash |
Constructor and Description |
---|
FileChannelOutputView(BlockChannelWriter<MemorySegment> writer,
MemoryManager memManager,
List<MemorySegment> memory,
int segmentSize) |
Modifier and Type | Class and Description |
---|---|
class |
AsynchronousBlockWriter |
Modifier and Type | Method and Description |
---|---|
BlockChannelWriter<MemorySegment> |
IOManager.createBlockChannelWriter(FileIOChannel.ID channelID)
Creates a block channel writer that writes to the given channel.
|
abstract BlockChannelWriter<MemorySegment> |
IOManager.createBlockChannelWriter(FileIOChannel.ID channelID,
LinkedBlockingQueue<MemorySegment> returnQueue)
Creates a block channel writer that writes to the given channel.
|
BlockChannelWriter<MemorySegment> |
IOManagerAsync.createBlockChannelWriter(FileIOChannel.ID channelID,
LinkedBlockingQueue<MemorySegment> returnQueue) |
Constructor and Description |
---|
ChannelWriterOutputView(BlockChannelWriter<MemorySegment> writer,
int segmentSize)
Creates an new ChannelWriterOutputView that writes to the given channel.
|
ChannelWriterOutputView(BlockChannelWriter<MemorySegment> writer,
List<MemorySegment> memory,
int segmentSize)
Creates an new ChannelWriterOutputView that writes to the given channel and buffers data
in the given memory segments.
|
Modifier and Type | Field and Description |
---|---|
protected BlockChannelWriter<MemorySegment> |
HashPartition.probeSideChannel |
Modifier and Type | Method and Description |
---|---|
BlockChannelWriter<MemorySegment> |
HashPartition.getBuildSideChannel() |
BlockChannelWriter<MemorySegment> |
HashPartition.getProbeSideChannel() |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.