Modifier and Type | Class and Description |
---|---|
class |
BatchOutputCollectorImpl |
Modifier and Type | Method and Description |
---|---|
void |
IBatchBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
T id) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionalGlobalCount.BatchCount.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
ReachTopology.PartialUniquer.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
ReachTopology.CountAggregator.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
TransactionalWords.KeyedCountUpdater.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
TransactionAttempt id) |
void |
TransactionalWords.BucketCountUpdater.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
TransactionAttempt attempt) |
void |
TransactionalGlobalCount.UpdateGlobalCount.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
TransactionAttempt attempt) |
Modifier and Type | Method and Description |
---|---|
void |
KeyedSummingBatchBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
KeyedCountingBatchBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
CountingBatchBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
BatchNumberList.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
Object id) |
void |
CountingCommitBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector,
TransactionAttempt id) |
Modifier and Type | Method and Description |
---|---|
void |
ITransactionalSpout.Emitter.emitBatch(TransactionAttempt tx,
X coordinatorMeta,
BatchOutputCollector collector)
Emit a batch for the specified transaction attempt and metadata for the transaction.
|
Modifier and Type | Method and Description |
---|---|
void |
OpaquePartitionedTransactionalSpoutExecutor.Emitter.emitBatch(TransactionAttempt tx,
Object coordinatorMeta,
BatchOutputCollector collector) |
void |
IPartitionedTransactionalSpout.Emitter.emitPartitionBatch(TransactionAttempt tx,
BatchOutputCollector collector,
int partition,
X partitionMeta)
Emit a batch of tuples for a partition/transaction that has been emitted before, using the metadata created when it was first emitted.
|
X |
IOpaquePartitionedTransactionalSpout.Emitter.emitPartitionBatch(TransactionAttempt tx,
BatchOutputCollector collector,
int partition,
X lastPartitionMeta)
Emit a batch of tuples for a partition/transaction.
|
X |
IPartitionedTransactionalSpout.Emitter.emitPartitionBatchNew(TransactionAttempt tx,
BatchOutputCollector collector,
int partition,
X lastPartitionMeta)
Emit a batch of tuples for a partition/transaction that’s never been emitted before.
|
Modifier and Type | Method and Description |
---|---|
void |
SubtopologyBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector batchCollector) |
Constructor and Description |
---|
BridgeReceiver(BatchOutputCollector collector) |
Modifier and Type | Method and Description |
---|---|
BatchOutputCollector |
TridentContext.getDelegateCollector() |
Constructor and Description |
---|
TridentContext(Fields selfFields,
List<TridentTuple.Factory> parentFactories,
List<String> parentStreams,
List<TupleReceiver> receivers,
String outStreamId,
int stateIndex,
BatchOutputCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
TridentSpoutExecutor.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
ITridentBatchBolt.prepare(Map conf,
TopologyContext context,
BatchOutputCollector collector) |
Modifier and Type | Field and Description |
---|---|
protected BatchOutputCollector |
AbstractTridentWindowManager.delegateCollector |
Constructor and Description |
---|
AbstractTridentWindowManager(WindowConfig windowConfig,
String windowTaskId,
WindowsStore windowStore,
Aggregator aggregator,
BatchOutputCollector delegateCollector) |
InMemoryTridentWindowManager(WindowConfig windowConfig,
String windowTaskId,
WindowsStore windowStore,
Aggregator aggregator,
BatchOutputCollector delegateCollector) |
StoreBasedTridentWindowManager(WindowConfig windowConfig,
String windowTaskId,
WindowsStore windowStore,
Aggregator aggregator,
BatchOutputCollector delegateCollector,
Long maxTuplesCacheSize,
Fields inputFields) |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.