Modifier and Type | Method and Description |
---|---|
void |
Murmur3StreamGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks)
Tells the stream grouping at runtime the tasks in the target bolt.
|
Modifier and Type | Method and Description |
---|---|
GlobalStreamId |
CoordinatedBolt.IdStreamSpec.getGlobalStreamId() |
Modifier and Type | Method and Description |
---|---|
GlobalStreamId |
GlobalStreamId.deepCopy() |
Modifier and Type | Method and Description |
---|---|
Map<String,Map<GlobalStreamId,Long>> |
BoltStats.get_acked() |
Map<String,Map<GlobalStreamId,Double>> |
BoltStats.get_execute_ms_avg() |
Map<String,Map<GlobalStreamId,Long>> |
BoltStats.get_executed() |
Map<String,Map<GlobalStreamId,Long>> |
BoltStats.get_failed() |
Map<GlobalStreamId,ComponentAggregateStats> |
ComponentPageInfo.get_gsid_to_input_stats() |
Map<GlobalStreamId,Grouping> |
ComponentCommon.get_inputs() |
Map<String,Map<GlobalStreamId,Double>> |
BoltStats.get_process_ms_avg() |
Modifier and Type | Method and Description |
---|---|
int |
GlobalStreamId.compareTo(GlobalStreamId other) |
boolean |
GlobalStreamId.equals(GlobalStreamId that) |
void |
ComponentPageInfo.put_to_gsid_to_input_stats(GlobalStreamId key,
ComponentAggregateStats val) |
void |
ComponentCommon.put_to_inputs(GlobalStreamId key,
Grouping val) |
Constructor and Description |
---|
GlobalStreamId(GlobalStreamId other)
Performs a deep copy on other.
|
Modifier and Type | Method and Description |
---|---|
void |
ShuffleGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks) |
void |
PartialKeyGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks) |
void |
LoadAwareShuffleGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks) |
void |
CustomStreamGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks)
Tells the stream grouping at runtime the tasks in the target bolt.
|
Modifier and Type | Method and Description |
---|---|
Map<GlobalStreamId,Grouping> |
GeneralTopologyContext.getSources(String componentId)
Gets the declared inputs to the specified component.
|
Map<GlobalStreamId,Grouping> |
TopologyContext.getThisSources()
Gets the declared inputs to this component.
|
Modifier and Type | Method and Description |
---|---|
Fields |
GeneralTopologyContext.getComponentOutputFields(GlobalStreamId id)
Gets the declared output fields for the specified global stream id.
|
Modifier and Type | Method and Description |
---|---|
void |
NGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks) |
Modifier and Type | Method and Description |
---|---|
BoltDeclarer |
TopologyBuilder.BoltGetter.grouping(GlobalStreamId id,
Grouping grouping) |
T |
InputDeclarer.grouping(GlobalStreamId id,
Grouping grouping) |
Modifier and Type | Method and Description |
---|---|
void |
IndexHashGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targetTasks) |
void |
IdentityGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> tasks) |
void |
GlobalGrouping.prepare(WorkerTopologyContext context,
GlobalStreamId stream,
List<Integer> targets) |
Modifier and Type | Field and Description |
---|---|
GlobalStreamId |
TridentBoltExecutor.CoordSpec.commitStream |
GlobalStreamId |
TridentBoltExecutor.CoordCondition.commitStream |
Constructor and Description |
---|
TridentBoltExecutor(ITridentBatchBolt bolt,
Map<GlobalStreamId,String> batchGroupIds,
Map<String,TridentBoltExecutor.CoordSpec> coordinationSpecs) |
Modifier and Type | Method and Description |
---|---|
GlobalStreamId |
TupleImpl.getSourceGlobalStreamid()
Deprecated.
|
GlobalStreamId |
Tuple.getSourceGlobalStreamid()
Deprecated.
replaced by
Tuple.getSourceGlobalStreamId() due to broken naming convention |
GlobalStreamId |
TupleImpl.getSourceGlobalStreamId() |
GlobalStreamId |
Tuple.getSourceGlobalStreamId()
Returns the global stream id (component + stream) of this tuple.
|
Modifier and Type | Method and Description |
---|---|
static GlobalStreamId |
Utils.getGlobalStreamId(String streamId,
String componentId) |
Modifier and Type | Method and Description |
---|---|
boolean |
WaterMarkEventGenerator.track(GlobalStreamId stream,
long ts)
Tracks the timestamp of the event in the stream, returns true if the event can be considered for processing or false if its a late event.
|
Constructor and Description |
---|
WaterMarkEventGenerator(WindowManager<T> windowManager,
int intervalMs,
int eventTsLagMs,
Set<GlobalStreamId> inputStreams)
Creates a new WatermarkEventGenerator.
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.