Package | Description |
---|---|
org.apache.storm.generated | |
org.apache.storm.task | |
org.apache.storm.topology | |
org.apache.storm.trident | |
org.apache.storm.trident.planner |
Modifier and Type | Method and Description |
---|---|
static Grouping |
Grouping.all(NullStruct value) |
static Grouping |
Grouping.custom_object(JavaObject value) |
static Grouping |
Grouping.custom_serialized(byte[] value) |
static Grouping |
Grouping.custom_serialized(ByteBuffer value) |
Grouping |
Grouping.deepCopy() |
static Grouping |
Grouping.direct(NullStruct value) |
static Grouping |
Grouping.fields(List<String> value) |
static Grouping |
Grouping.local_or_shuffle(NullStruct value) |
static Grouping |
Grouping.none(NullStruct value) |
static Grouping |
Grouping.shuffle(NullStruct value) |
Modifier and Type | Method and Description |
---|---|
Map<GlobalStreamId,Grouping> |
ComponentCommon.get_inputs() |
Modifier and Type | Method and Description |
---|---|
int |
Grouping.compareTo(Grouping other) |
boolean |
Grouping.equals(Grouping other) |
void |
ComponentCommon.put_to_inputs(GlobalStreamId key,
Grouping val) |
Modifier and Type | Method and Description |
---|---|
void |
ComponentCommon.set_inputs(Map<GlobalStreamId,Grouping> inputs) |
Constructor and Description |
---|
Grouping(Grouping other) |
Constructor and Description |
---|
ComponentCommon(Map<GlobalStreamId,Grouping> inputs,
Map<String,StreamInfo> streams) |
Modifier and Type | Method and Description |
---|---|
Map<GlobalStreamId,Grouping> |
GeneralTopologyContext.getSources(String componentId)
Gets the declared inputs to the specified component.
|
Map<String,Map<String,Grouping>> |
GeneralTopologyContext.getTargets(String componentId)
Gets information about who is consuming the outputs of the specified component, and how.
|
Map<GlobalStreamId,Grouping> |
TopologyContext.getThisSources()
Gets the declared inputs to this component.
|
Map<String,Map<String,Grouping>> |
TopologyContext.getThisTargets()
Gets information about who is consuming the outputs of this component, and how.
|
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 |
---|---|
Stream |
Stream.partition(Grouping grouping)
Repartitioning Operation
|
Modifier and Type | Field and Description |
---|---|
Grouping |
PartitionNode.thriftGrouping |
Constructor and Description |
---|
PartitionNode(String streamId,
String name,
Fields allOutputFields,
Grouping grouping) |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.