| 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 | WriteaheadBuffered. add(Chunk event) | 
| void | MemBuffered. add(Chunk event) | 
| void | AbstractWrapper. add(Chunk event) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WaitingQueue. add(Chunk event) | 
| void | NonBlockingMemLimitQueue. add(Chunk chunk) | 
| 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 | NonBlockingMemLimitQueue. collect(List<Chunk> events,
       int maxSize) | 
| void | MemLimitQueue. collect(List<Chunk> events,
       int maxSize) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LogDisplayServlet. add(List<Chunk> chunks)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| Chunk | ChunkCatcherConnector. waitForAChunk() | 
| Chunk | ChunkCatcherConnector. waitForAChunk(long ms) | 
| 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 | 
|---|---|
| ChukwaWriter.CommitStatus | FilePerPostWriter. add(List<Chunk> chunks) | 
| 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 | InMemoryWriter. add(Chunk data) | 
| void | ConsoleWriter. add(Chunk data) | 
| Modifier and Type | Method and Description | 
|---|---|
| ChukwaWriter.CommitStatus | SocketTeeWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | SeqFileWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | PipelineStageWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | PipelineableWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | NullWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | InMemoryWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | ExtractorWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | Dedup. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | ConsoleWriter. add(List<Chunk> chunks) | 
| ChukwaWriter.CommitStatus | ChukwaWriter. add(List<Chunk> chunks)Called repeatedly with data that should be serialized. | 
| Modifier and Type | Method and Description | 
|---|---|
| ChukwaWriter.CommitStatus | HBaseWriter. add(List<Chunk> chunks) | 
| Modifier and Type | Method and Description | 
|---|---|
| ChukwaWriter.CommitStatus | LocalWriter. add(List<Chunk> chunks)Best effort, there's no guarantee that chunks 
  have really been written to disk | 
| Modifier and Type | Method and Description | 
|---|---|
| ChukwaWriter.CommitStatus | SolrWriter. add(List<Chunk> chunks) | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<Chunk> | SocketDataLoader. read() | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Chunk | AbstractProcessor. chunk | 
| 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| static String | RecordUtil. getClusterName(Chunk chunk)Uses a precompiled pattern, so theoretically faster than
 Chunk.getTag(). | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | ConstRateAdaptor. checkChunk(Chunk chunk) | 
| boolean | Filter. matches(Chunk chunk) | 
Copyright © 2014 Apache Software Foundation. All Rights Reserved.