Uses of Class
org.apache.storm.generated.Grouping
Packages that use Grouping
Package
Description
-
Uses of Grouping in org.apache.storm
Methods in org.apache.storm that return GroupingModifier 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()
Methods in org.apache.storm that return types with arguments of type GroupingMethods in org.apache.storm with parameters of type GroupingModifier and TypeMethodDescriptionThrift.fieldGrouping
(Grouping grouping) static Grouping._Fields
Thrift.groupingType
(Grouping grouping) static boolean
Thrift.isGlobalGrouping
(Grouping grouping) Method parameters in org.apache.storm with type arguments of type GroupingModifier 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
Methods in org.apache.storm.daemon that return types with arguments of type GroupingModifier and TypeMethodDescriptionstatic Map<GlobalStreamId,
Grouping> StormCommon.ackerInputs
(StormTopology topology) static Map<GlobalStreamId,
Grouping> StormCommon.eventLoggerInputs
(StormTopology topology) Methods in org.apache.storm.daemon with parameters of type GroupingModifier and TypeMethodDescriptionGrouperFactory.mkGrouper
(WorkerTopologyContext context, String componentId, String streamId, Fields outFields, Grouping thriftGrouping, List<Integer> unsortedTargetTasks, Map<String, Object> topoConf) Constructors in org.apache.storm.daemon with parameters of type Grouping -
Uses of Grouping in org.apache.storm.daemon.ui
Method parameters in org.apache.storm.daemon.ui with type arguments of type GroupingModifier and TypeMethodDescriptionUIHelpers.getInputMap
(Map.Entry<GlobalStreamId, Grouping> entryInput) getInputMap. -
Uses of Grouping in org.apache.storm.generated
Methods in org.apache.storm.generated that return GroupingModifier 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) Methods in org.apache.storm.generated that return types with arguments of type GroupingMethods in org.apache.storm.generated with parameters of type GroupingModifier and TypeMethodDescriptionint
boolean
void
ComponentCommon.put_to_inputs
(GlobalStreamId key, Grouping val) Method parameters in org.apache.storm.generated with type arguments of type GroupingModifier and TypeMethodDescriptionvoid
ComponentCommon.set_inputs
(Map<GlobalStreamId, Grouping> inputs) Constructors in org.apache.storm.generated with parameters of type GroupingConstructor parameters in org.apache.storm.generated with type arguments of type GroupingModifierConstructorDescriptionComponentCommon
(Map<GlobalStreamId, Grouping> inputs, Map<String, StreamInfo> streams) -
Uses of Grouping in org.apache.storm.loadgen
Methods in org.apache.storm.loadgen with parameters of type GroupingModifier 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
Methods in org.apache.storm.scheduler that return types with arguments of type GroupingConstructor parameters in org.apache.storm.scheduler with type arguments of type GroupingModifierConstructorDescriptionComponent
(ComponentType type, String compId, List<ExecutorDetails> execs, Map<GlobalStreamId, Grouping> inputs) Create a new component. -
Uses of Grouping in org.apache.storm.task
Methods in org.apache.storm.task that return types with arguments of type GroupingModifier 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
Methods in org.apache.storm.topology with parameters of type GroupingModifier and TypeMethodDescriptionInputDeclarer.grouping
(GlobalStreamId id, Grouping grouping) TopologyBuilder.BoltGetter.grouping
(GlobalStreamId id, Grouping grouping) -
Uses of Grouping in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type Grouping -
Uses of Grouping in org.apache.storm.trident.planner
Fields in org.apache.storm.trident.planner declared as GroupingConstructors in org.apache.storm.trident.planner with parameters of type GroupingModifierConstructorDescriptionPartitionNode
(String streamId, String name, Fields allOutputFields, Grouping grouping)