Uses of Class
org.apache.storm.generated.Grouping
Package
Description
-
Uses of Grouping in org.apache.storm
Modifier and TypeMethodDescriptionstatic Grouping
Thrift.prepareAllGrouping()
static Grouping
Thrift.prepareCustomJavaObjectGrouping
(JavaObject obj) static Grouping
Thrift.prepareCustomStreamGrouping
(Object obj) static Grouping
Thrift.prepareDirectGrouping()
static Grouping
Thrift.prepareFieldsGrouping
(List<String> fields) static Grouping
Thrift.prepareGlobalGrouping()
static Grouping
Thrift.prepareLocalOrShuffleGrouping()
static Grouping
Thrift.prepareNoneGrouping()
static Grouping
Thrift.prepareShuffleGrouping()
Modifier and TypeMethodDescriptionThrift.fieldGrouping
(Grouping grouping) static Grouping._Fields
Thrift.groupingType
(Grouping grouping) static boolean
Thrift.isGlobalGrouping
(Grouping grouping) Modifier and TypeMethodDescriptionstatic Thrift.BoltDetails
Thrift.prepareBoltDetails
(Map<GlobalStreamId, Grouping> inputs, Object bolt) static Thrift.BoltDetails
Thrift.prepareBoltDetails
(Map<GlobalStreamId, Grouping> inputs, Object bolt, Integer parallelismHint) static Thrift.BoltDetails
Thrift.prepareBoltDetails
(Map<GlobalStreamId, Grouping> inputs, Object bolt, Integer parallelismHint, Map<String, Object> conf) static ComponentCommon
Thrift.prepareComponentCommon
(Map<GlobalStreamId, Grouping> inputs, Map<String, StreamInfo> outputs, Integer parallelismHint) static ComponentCommon
Thrift.prepareComponentCommon
(Map<GlobalStreamId, Grouping> inputs, Map<String, StreamInfo> outputs, Integer parallelismHint, Map<String, Object> conf) static Bolt
Thrift.prepareSerializedBoltDetails
(Map<GlobalStreamId, Grouping> inputs, IBolt bolt, Map<String, StreamInfo> outputs, Integer parallelismHint, Map<String, Object> conf) -
Uses of Grouping in org.apache.storm.daemon
Modifier and TypeMethodDescriptionstatic Map<GlobalStreamId,
Grouping> StormCommon.ackerInputs
(StormTopology topology) static Map<GlobalStreamId,
Grouping> StormCommon.eventLoggerInputs
(StormTopology topology) -
Uses of Grouping in org.apache.storm.daemon.ui
Modifier and TypeMethodDescriptionUIHelpers.getInputMap
(Map.Entry<GlobalStreamId, Grouping> entryInput) getInputMap. -
Uses of Grouping in org.apache.storm.generated
Modifier and TypeMethodDescriptionstatic 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.deepCopy()
static Grouping
Grouping.direct
(NullStruct value) static Grouping
static Grouping
Grouping.local_or_shuffle
(NullStruct value) static Grouping
Grouping.none
(NullStruct value) static Grouping
Grouping.shuffle
(NullStruct value) Modifier and TypeMethodDescriptionint
boolean
void
ComponentCommon.put_to_inputs
(GlobalStreamId key, Grouping val) Modifier and TypeMethodDescriptionvoid
ComponentCommon.set_inputs
(Map<GlobalStreamId, Grouping> inputs) ModifierConstructorDescriptionComponentCommon
(Map<GlobalStreamId, Grouping> inputs, Map<String, StreamInfo> streams) -
Uses of Grouping in org.apache.storm.loadgen
Modifier and TypeMethodDescriptionInputStream.Builder.withGroupingType
(Grouping grouping) Add the grouping type based off of the thrift Grouping class. -
Uses of Grouping in org.apache.storm.scheduler
ModifierConstructorDescriptionComponent
(ComponentType type, String compId, List<ExecutorDetails> execs, Map<GlobalStreamId, Grouping> inputs) Create a new component. -
Uses of Grouping in org.apache.storm.task
Modifier and TypeMethodDescriptionGeneralTopologyContext.getSources
(String componentId) Gets the declared inputs to the specified component.GeneralTopologyContext.getTargets
(String componentId) Gets information about who is consuming the outputs of the specified component, and how.TopologyContext.getThisSources()
Gets the declared inputs to this component.TopologyContext.getThisTargets()
Gets information about who is consuming the outputs of this component, and how. -
Uses of Grouping in org.apache.storm.topology
Modifier and TypeMethodDescriptionInputDeclarer.grouping
(GlobalStreamId id, Grouping grouping) TopologyBuilder.BoltGetter.grouping
(GlobalStreamId id, Grouping grouping) -
Uses of Grouping in org.apache.storm.trident
-
Uses of Grouping in org.apache.storm.trident.planner
ModifierConstructorDescriptionPartitionNode
(String streamId, String name, Fields allOutputFields, Grouping grouping)