Modifier and Type | Class and Description |
---|---|
class |
ChunkImpl |
Modifier and Type | Method and Description |
---|---|
Chunk |
ChunkBuilder.getChunk() |
Modifier and Type | Method and Description |
---|---|
void |
ChunkReceiver.add(Chunk event)
Add a chunk to the queue, potentially blocking.
|
void |
ChunkQueue.add(Chunk chunk)
Add a chunk to the queue, blocking if queue is full.
|
Modifier and Type | Method and Description |
---|---|
void |
ChunkQueue.collect(List<Chunk> chunks,
int count)
Return at least one, and no more than count, Chunks into chunks.
|
Modifier and Type | Method and Description |
---|---|
void |
WaitingQueue.add(Chunk event) |
void |
MemLimitQueue.add(Chunk chunk) |
Modifier and Type | Method and Description |
---|---|
void |
WaitingQueue.add(List<Chunk> events) |
void |
WaitingQueue.collect(List<Chunk> events,
int maxCount) |
void |
MemLimitQueue.collect(List<Chunk> events,
int maxSize) |
Modifier and Type | Method and Description |
---|---|
List<Chunk> |
Protocol.parseFrom(byte[] bytes) |
List<Chunk> |
Protocol.parseFrom(InputStream input) |
Modifier and Type | Method and Description |
---|---|
byte[] |
Protocol.toByteArray(List<Chunk> chunks) |
Modifier and Type | Method and Description |
---|---|
List<ChukwaHttpSender.CommitListEntry> |
ChukwaSender.send(List<Chunk> chunksToSend) |
List<ChukwaHttpSender.CommitListEntry> |
ChukwaHttpSender.send(List<Chunk> toSend)
grab all of the chunks currently in the chunkQueue, stores a copy of them
locally, calculates their size, sets them up
|
Modifier and Type | Method and Description |
---|---|
Chunk |
InMemoryWriter.readOutChunk(int bytes,
int ms)
Try to read bytes, waiting up to ms
|
Modifier and Type | Method and Description |
---|---|
void |
SeqFileWriter.add(Chunk chunk) |
void |
InMemoryWriter.add(Chunk data) |
void |
ConsoleWriter.add(Chunk data) |
Modifier and Type | Method and Description |
---|---|
void |
SeqFileWriter.add(List<Chunk> chunks) |
void |
PipelineStageWriter.add(List<Chunk> chunks) |
void |
InMemoryWriter.add(List<Chunk> chunks) |
void |
Dedup.add(List<Chunk> chunks) |
void |
ConsoleWriter.add(List<Chunk> chunks) |
void |
ChukwaWriter.add(List<Chunk> chunks) |
Modifier and Type | Method and Description |
---|---|
void |
MapProcessor.process(ChukwaArchiveKey archiveKey,
Chunk chunk,
org.apache.hadoop.mapred.OutputCollector<ChukwaRecordKey,ChukwaRecord> output,
org.apache.hadoop.mapred.Reporter reporter) |
void |
AbstractProcessor.process(ChukwaArchiveKey archiveKey,
Chunk chunk,
org.apache.hadoop.mapred.OutputCollector<ChukwaRecordKey,ChukwaRecord> output,
org.apache.hadoop.mapred.Reporter reporter) |
void |
ChunkProcessor.process(Chunk chunk,
org.apache.hadoop.mapred.OutputCollector<org.apache.hadoop.io.Text,ChukwaRecord> output,
org.apache.hadoop.mapred.Reporter reporter) |
protected void |
AbstractProcessor.reset(Chunk chunk) |
static ChukwaRecord |
ChunkSaver.saveChunk(Chunk chunk,
Throwable throwable,
org.apache.hadoop.mapred.OutputCollector<ChukwaRecordKey,ChukwaRecord> output,
org.apache.hadoop.mapred.Reporter reporter) |
Copyright © ${year} The Apache Software Foundation