Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- A - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- abort() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
- ABS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ABSOLUTE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- absoluteHealthCheckDir(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerConfigUtils
- absoluteStormBlobStoreDir(Map<String, Object>) - Static method in class org.apache.storm.utils.ConfigUtils
- absoluteStormLocalDir(Map<String, Object>) - Static method in class org.apache.storm.utils.ConfigUtils
- AbstractAvroSerializer - Class in org.apache.storm.hdfs.avro
-
This abstract class can be extended to implement concrete classes capable of (de)serializing generic avro objects across a Topology.
- AbstractAvroSerializer() - Constructor for class org.apache.storm.hdfs.avro.AbstractAvroSerializer
- AbstractDNSToSwitchMapping - Class in org.apache.storm.networktopography
-
This is a base class for DNS to Switch mappings.
- AbstractDNSToSwitchMapping() - Constructor for class org.apache.storm.networktopography.AbstractDNSToSwitchMapping
-
Create an unconfigured instance.
- AbstractHadoopAutoCreds - Class in org.apache.storm.common
-
The base class that for auto credential plugins that abstracts out some of the common functionality.
- AbstractHadoopAutoCreds() - Constructor for class org.apache.storm.common.AbstractHadoopAutoCreds
- AbstractHadoopNimbusPluginAutoCreds - Class in org.apache.storm.common
-
The base class that for auto credential plugins that abstracts out some of the common functionality.
- AbstractHadoopNimbusPluginAutoCreds() - Constructor for class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- AbstractHdfsBolt - Class in org.apache.storm.hdfs.bolt
- AbstractHdfsBolt() - Constructor for class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- AbstractHDFSWriter - Class in org.apache.storm.hdfs.common
- AbstractHDFSWriter(FileRotationPolicy, Path) - Constructor for class org.apache.storm.hdfs.common.AbstractHDFSWriter
- AbstractJdbcBolt - Class in org.apache.storm.jdbc.bolt
- AbstractJdbcBolt(ConnectionProvider) - Constructor for class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
-
Constructor.
- AbstractRankerBolt - Class in org.apache.storm.starter.bolt
-
This abstract bolt provides the basic behavior of bolts that rank objects according to their count.
- AbstractRankerBolt() - Constructor for class org.apache.storm.starter.bolt.AbstractRankerBolt
- AbstractRankerBolt(int) - Constructor for class org.apache.storm.starter.bolt.AbstractRankerBolt
- AbstractRankerBolt(int, int) - Constructor for class org.apache.storm.starter.bolt.AbstractRankerBolt
- AbstractRedisBolt - Class in org.apache.storm.redis.bolt
-
AbstractRedisBolt class is for users to implement custom bolts which makes interaction with Redis.
- AbstractRedisBolt(JedisClusterConfig) - Constructor for class org.apache.storm.redis.bolt.AbstractRedisBolt
-
Constructor for Redis Cluster environment (JedisCluster).
- AbstractRedisBolt(JedisPoolConfig) - Constructor for class org.apache.storm.redis.bolt.AbstractRedisBolt
-
Constructor for single Redis environment (JedisPool).
- AbstractRedisMapState<T> - Class in org.apache.storm.redis.trident.state
-
AbstractRedisMapState is base class of any RedisMapState, which implements IBackingMap.
- AbstractRedisMapState() - Constructor for class org.apache.storm.redis.trident.state.AbstractRedisMapState
- AbstractRedisStateQuerier<T extends State> - Class in org.apache.storm.redis.trident.state
-
AbstractRedisStateQuerier is base class of any RedisStateQuerier, which implements BaseQueryFunction.
- AbstractRedisStateQuerier(RedisLookupMapper) - Constructor for class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
-
Constructor.
- AbstractRedisStateUpdater<T extends State> - Class in org.apache.storm.redis.trident.state
-
AbstractRedisStateUpdater is base class of any RedisStateUpdater, which implements BaseStateUpdater.
- AbstractRedisStateUpdater(RedisStoreMapper) - Constructor for class org.apache.storm.redis.trident.state.AbstractRedisStateUpdater
-
Constructor.
- AbstractStreamsProcessor - Class in org.apache.storm.sql
- AbstractStreamsProcessor() - Constructor for class org.apache.storm.sql.AbstractStreamsProcessor
- AbstractTridentWindowManager<T> - Class in org.apache.storm.trident.windowing
-
Basic functionality to manage trident tuple events using
WindowManager
andWindowsStore
for storing tuples and triggers related information. - AbstractTridentWindowManager(WindowConfig, String, WindowsStore, Aggregator, BatchOutputCollector) - Constructor for class org.apache.storm.trident.windowing.AbstractTridentWindowManager
- AbstractUserTopology - Class in org.apache.storm.jdbc.topology
-
For topology-related code reusage.
- AbstractUserTopology() - Constructor for class org.apache.storm.jdbc.topology.AbstractUserTopology
- accept(Object) - Method in class org.apache.storm.daemon.worker.WorkerTransfer
- accept(Object) - Method in class org.apache.storm.executor.Executor
- accept(Object) - Method in interface org.apache.storm.utils.JCQueue.Consumer
- accept(TridentTuple) - Method in interface org.apache.storm.trident.operation.Consumer
-
Performs the operation on the input trident tuple.
- accept(T) - Method in interface org.apache.storm.streams.operations.Consumer
-
Performs an operation on the given argument.
- accept(T) - Method in class org.apache.storm.streams.operations.PrintConsumer
- acceptedValues() - Element in annotation interface org.apache.storm.validation.ConfigValidationAnnotations.IsString
- acceptTupleAction(int, TupleImpl) - Method in class org.apache.storm.executor.Executor
- acceptTupleAction(int, TupleImpl) - Method in class org.apache.storm.executor.spout.SpoutExecutor
- ACCESS - Enum constant in enum class org.apache.storm.generated.AccessControl._Fields
- AccessControl - Class in org.apache.storm.generated
- AccessControl() - Constructor for class org.apache.storm.generated.AccessControl
- AccessControl(AccessControl) - Constructor for class org.apache.storm.generated.AccessControl
-
Performs a deep copy on other.
- AccessControl(AccessControlType, int) - Constructor for class org.apache.storm.generated.AccessControl
- AccessControl._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- accessControlToString(AccessControl) - Static method in class org.apache.storm.blobstore.BlobStoreAclHandler
- AccessControlType - Enum Class in org.apache.storm.generated
- AccessLoggingFilter - Class in org.apache.storm.logging.filters
- AccessLoggingFilter() - Constructor for class org.apache.storm.logging.filters.AccessLoggingFilter
- ack() - Method in class org.apache.storm.utils.BatchHelper
- ack(long) - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
- ack(long) - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
- ack(long) - Method in interface org.apache.storm.trident.spout.IBatchSpout
- ack(long) - Method in class org.apache.storm.trident.testing.FixedBatchSpout
- ack(Object) - Method in class org.apache.storm.clojure.ClojureSpout
- ack(Object) - Method in class org.apache.storm.drpc.DRPCSpout
- ack(Object) - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.SentenceSpout
- ack(Object) - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.SentenceSpout
- ack(Object) - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- ack(Object) - Method in class org.apache.storm.jdbc.spout.UserSpout
- ack(Object) - Method in class org.apache.storm.jms.spout.JmsSpout
-
Ack a successfully handled message by the matching
JmsMessageID
. - ack(Object) - Method in class org.apache.storm.kafka.spout.KafkaSpout
- ack(Object) - Method in class org.apache.storm.loadgen.LoadSpout
- ack(Object) - Method in class org.apache.storm.perf.spout.ConstSpout
- ack(Object) - Method in class org.apache.storm.perf.spout.StringGenSpout
- ack(Object) - Method in class org.apache.storm.redis.topology.WordSpout
- ack(Object) - Method in class org.apache.storm.spout.CheckpointSpout
- ack(Object) - Method in interface org.apache.storm.spout.ISpout
-
Storm has determined that the tuple emitted by this spout with the msgId identifier has been fully processed.
- ack(Object) - Method in class org.apache.storm.spout.ShellSpout
- ack(Object) - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- ack(Object) - Method in class org.apache.storm.st.topology.window.IncrementingSpout
- ack(Object) - Method in class org.apache.storm.starter.AnchoredWordCount.RandomSentenceSpout
- ack(Object) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.RandomSentenceSpout
- ack(Object) - Method in class org.apache.storm.starter.FastWordCountTopology.FastRandomSentenceSpout
- ack(Object) - Method in class org.apache.storm.starter.InOrderDeliveryTest.InOrderSpout
- ack(Object) - Method in class org.apache.storm.starter.spout.RandomIntegerSpout
- ack(Object) - Method in class org.apache.storm.starter.spout.RandomSentenceSpout
- ack(Object) - Method in interface org.apache.storm.testing.AckFailDelegate
- ack(Object) - Method in class org.apache.storm.testing.AckFailMapTracker
- ack(Object) - Method in class org.apache.storm.testing.AckTracker
- ack(Object) - Method in class org.apache.storm.testing.FeederSpout
- ack(Object) - Method in class org.apache.storm.testing.FixedTupleSpout
- ack(Object) - Method in class org.apache.storm.testing.SpoutTracker
- ack(Object) - Method in class org.apache.storm.testing.TestEventLogSpout
- ack(Object) - Method in class org.apache.storm.testing.TestPlannerSpout
- ack(Object) - Method in class org.apache.storm.testing.TestWordSpout
- ack(Object) - Method in class org.apache.storm.topology.base.BaseRichSpout
- ack(Object) - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- ack(Object) - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- ack(Tuple) - Method in class org.apache.storm.coordination.BatchOutputCollectorImpl
- ack(Tuple) - Method in class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
- ack(Tuple) - Method in class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
- ack(Tuple) - Method in interface org.apache.storm.task.IOutputCollector
- ack(Tuple) - Method in class org.apache.storm.task.OutputCollector
- ACKED - Enum constant in enum class org.apache.storm.generated.BoltStats._Fields
- ACKED - Enum constant in enum class org.apache.storm.generated.CommonAggregateStats._Fields
- ACKED - Enum constant in enum class org.apache.storm.generated.SpoutStats._Fields
- Acker - Class in org.apache.storm.daemon
- Acker() - Constructor for class org.apache.storm.daemon.Acker
- ACKER_ACK_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
- ACKER_COMPONENT_ID - Static variable in class org.apache.storm.daemon.Acker
- ACKER_FAIL_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
- ACKER_INIT_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
- ACKER_RESET_TIMEOUT_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
- ackerInputs(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- AckFailDelegate - Interface in org.apache.storm.testing
- AckFailMapTracker - Class in org.apache.storm.testing
- AckFailMapTracker() - Constructor for class org.apache.storm.testing.AckFailMapTracker
- ackingEnabled - Variable in class org.apache.storm.executor.Executor
- ackingTaskId - Variable in class org.apache.storm.hooks.info.BoltAckInfo
- ackSpoutMsg(SpoutExecutor, Task, Long, TupleInfo) - Method in class org.apache.storm.executor.spout.SpoutExecutor
- AckTracker - Class in org.apache.storm.testing
- AckTracker() - Constructor for class org.apache.storm.testing.AckTracker
- ACL - Enum constant in enum class org.apache.storm.generated.SettableBlobMeta._Fields
- AclEnforcement - Class in org.apache.storm.zookeeper
-
This is code intended to enforce ZK ACLs.
- AclEnforcement() - Constructor for class org.apache.storm.zookeeper.AclEnforcement
- aclFileName - Variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
- AclFunctionEntry(Collection<String>, String) - Constructor for class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer.AclFunctionEntry
- aclHandler - Variable in class org.apache.storm.blobstore.LocalFsBlobStore
- acquireNewPort() - Static method in class org.apache.storm.utils.InprocMessaging
- acquireOldestExpiredLock(FileSystem, Path, int, String) - Static method in class org.apache.storm.hdfs.spout.FileLock
-
Finds a oldest expired lock file (using modification timestamp), then takes ownership of the lock file.
- ACTION - Enum constant in enum class org.apache.storm.generated.LogLevel._Fields
- ACTION - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
- ACTION - Enum constant in enum class org.apache.storm.generated.ProfileRequest._Fields
- ACTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- activate() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.activate
- activate() - Constructor for class org.apache.storm.generated.Nimbus.Processor.activate
- activate() - Method in class org.apache.storm.clojure.ClojureSpout
- activate() - Method in class org.apache.storm.jdbc.spout.UserSpout
- activate() - Method in class org.apache.storm.kafka.spout.KafkaSpout
- activate() - Method in class org.apache.storm.redis.topology.WordSpout
- activate() - Method in interface org.apache.storm.spout.ISpout
-
Called when a spout has been activated out of a deactivated mode.
- activate() - Method in class org.apache.storm.spout.ShellSpout
- activate() - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- activate() - Method in class org.apache.storm.testing.FixedTupleSpout
- activate() - Method in class org.apache.storm.topology.base.BaseRichSpout
- activate() - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- activate() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- activate(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- activate(String) - Method in class org.apache.storm.generated.Nimbus.Client
- activate(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- activate(String) - Method in interface org.apache.storm.ILocalCluster
-
Activate a topology.
- activate(String) - Method in class org.apache.storm.LocalCluster
- activate(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- activate(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- Activate - Class in org.apache.storm.command
- Activate() - Constructor for class org.apache.storm.command.Activate
- ACTIVATE - Enum constant in enum class org.apache.storm.daemon.nimbus.TopologyActions
- activate_args() - Constructor for class org.apache.storm.generated.Nimbus.activate_args
- activate_args(String) - Constructor for class org.apache.storm.generated.Nimbus.activate_args
- activate_args(Nimbus.activate_args) - Constructor for class org.apache.storm.generated.Nimbus.activate_args
-
Performs a deep copy on other.
- activate_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.activate_call
- activate_result() - Constructor for class org.apache.storm.generated.Nimbus.activate_result
- activate_result(Nimbus.activate_result) - Constructor for class org.apache.storm.generated.Nimbus.activate_result
-
Performs a deep copy on other.
- activate_result(NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.activate_result
- activateStorm(String, StormBase, Map<String, Object>) - Method in interface org.apache.storm.cluster.IStormClusterState
- activateStorm(String, StormBase, Map<String, Object>) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- activateWorkerWhenAllConnectionsReady() - Method in class org.apache.storm.daemon.worker.WorkerState
-
we will wait all connections to be ready and then activate the spout/bolt when the worker bootup.
- ACTIVE - Enum constant in enum class org.apache.storm.generated.TopologyInitialStatus
- ACTIVE - Enum constant in enum class org.apache.storm.generated.TopologyStatus
- activeAnonSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- activeFileSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- activeKeys() - Method in interface org.apache.storm.cluster.IStormClusterState
- activeKeys() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- activeStorms() - Method in interface org.apache.storm.cluster.IStormClusterState
- activeStorms() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- ADA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- add(int, Object) - Method in class org.apache.storm.trident.tuple.ConsList
- add(int, Object) - Method in class org.apache.storm.utils.ListDelegate
- add(int, Object, List<Object>) - Method in interface org.apache.storm.state.ISynchronizeOutputCollector
- add(int, Object, List<Object>) - Method in class org.apache.storm.state.SynchronizeOutputCollector
- add(Object) - Method in class org.apache.storm.utils.ListDelegate
- add(Object, V) - Method in class org.apache.storm.utils.KeyedRoundRobinQueue
- add(Runnable) - Method in interface org.apache.storm.event.EventManager
- add(Runnable) - Method in class org.apache.storm.event.EventManagerImp
- add(TopologyResources) - Method in class org.apache.storm.daemon.nimbus.TopologyResources
-
Add the values in other to this and return a combined resources object.
- add(WorkerResources) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
-
Add the resources from a worker to those in this.
- add(WorkerResources) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Add the resources from a worker to this.
- add(WorkerResources) - Method in class org.apache.storm.scheduler.SupervisorResources
- add(InputStream) - Method in class org.apache.storm.loadgen.LoadBolt
- add(LoadMetricsServer.Measurements) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
-
Add other to this.
- add(TaskMessage) - Method in class org.apache.storm.messaging.netty.MessageBuffer
- add(TaskMessage) - Method in class org.apache.storm.utils.TransferDrainer
- add(NormalizedResourceRequest) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
-
Add the resources in other to this.
- add(NormalizedResources) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
- add(NormalizedResourcesWithMemory) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- add(ObjectResourcesItem) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesItem
- add(StormTimer.QueueEntry) - Method in class org.apache.storm.StormTimer.StormTimerTask
- add(Event<T>) - Method in class org.apache.storm.windowing.persistence.WindowState
- add(Event<T>) - Method in class org.apache.storm.windowing.WindowManager
-
Tracks a window event.
- add(T) - Method in class org.apache.storm.security.auth.MultiThriftServer
- add(T) - Method in class org.apache.storm.windowing.WindowManager
-
Add an event into the window, with
System.currentTimeMillis()
as the tracking ts. - add(T, long) - Method in class org.apache.storm.windowing.WindowManager
-
Add an event into the window, with the given ts as the tracking ts.
- ADD - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- add_listener(ConnectionStateListener) - Method in interface org.apache.storm.cluster.IStateStorage
-
Add a StateStorageListener to the connection.
- add_listener(ConnectionStateListener) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- add_listener(ConnectionStateListener) - Method in class org.apache.storm.cluster.ZKStateStorage
- add_to_acl(AccessControl) - Method in class org.apache.storm.generated.SettableBlobMeta
- add_to_args_list(JavaObjectArg) - Method in class org.apache.storm.generated.JavaObject
- add_to_dependency_artifacts(String) - Method in class org.apache.storm.generated.StormTopology
- add_to_dependency_jars(String) - Method in class org.apache.storm.generated.StormTopology
- add_to_errors(ErrorInfo) - Method in class org.apache.storm.generated.ComponentPageInfo
- add_to_exec_stats(ExecutorAggregateStats) - Method in class org.apache.storm.generated.ComponentPageInfo
- add_to_executors(ExecutorInfo) - Method in class org.apache.storm.generated.LocalAssignment
- add_to_executors(ExecutorInfo) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- add_to_executors(ExecutorInfo) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- add_to_executors(ExecutorSummary) - Method in class org.apache.storm.generated.TopologyInfo
- add_to_groups(String) - Method in class org.apache.storm.generated.LSTopoHistory
- add_to_keys(String) - Method in class org.apache.storm.generated.ListBlobsResult
- add_to_meta(long) - Method in class org.apache.storm.generated.SupervisorInfo
- add_to_metrics(WorkerMetricPoint) - Method in class org.apache.storm.generated.WorkerMetricList
- add_to_nimbuses(NimbusSummary) - Method in class org.apache.storm.generated.ClusterSummary
- add_to_output_fields(String) - Method in class org.apache.storm.generated.StreamInfo
- add_to_port(long) - Method in class org.apache.storm.generated.NodeInfo
- add_to_pulseIds(String) - Method in class org.apache.storm.generated.HBNodes
- add_to_pulses(HBPulse) - Method in class org.apache.storm.generated.HBRecords
- add_to_success(OwnerResourceSummary) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- add_to_success(ProfileRequest) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- add_to_success(TopologySummary) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- add_to_supervisor_summaries(SupervisorSummary) - Method in class org.apache.storm.generated.SupervisorPageInfo
- add_to_supervisors(SupervisorSummary) - Method in class org.apache.storm.generated.ClusterSummary
- add_to_topo_history(LSTopoHistory) - Method in class org.apache.storm.generated.LSTopoHistoryList
- add_to_topo_ids(String) - Method in class org.apache.storm.generated.TopologyHistoryInfo
- add_to_topologies(TopologySummary) - Method in class org.apache.storm.generated.ClusterSummary
- add_to_used_ports(long) - Method in class org.apache.storm.generated.SupervisorInfo
- add_to_users(String) - Method in class org.apache.storm.generated.LSTopoHistory
- add_to_worker_heartbeats(SupervisorWorkerHeartbeat) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- add_to_worker_hooks(ByteBuffer) - Method in class org.apache.storm.generated.StormTopology
- add_to_worker_summaries(WorkerSummary) - Method in class org.apache.storm.generated.SupervisorPageInfo
- add_to_workers(WorkerSummary) - Method in class org.apache.storm.generated.TopologyPageInfo
- addAcker(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- addAggLevel(AggLevel) - Method in class org.apache.storm.metricstore.FilterOptions
-
Add an aggregation level to search for.
- addAll(int, Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
- addAll(Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
- addAllBolts(List<BoltDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
-
Adds a list of bolt definitions.
- addAllComponents(List<BeanDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
-
Adds a list of component definitions.
- addAllReadOnlyMountLocations(List<String>) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add all readonly locations.
- addAllReadOnlyMountLocations(List<String>, boolean) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add all readonly locations.
- addAllReadWriteMountLocations(List<String>) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add all the rw bind mount locations.
- addAllReadWriteMountLocations(List<String>, boolean) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add all the rw bind mount locations.
- addAllSpouts(List<SpoutDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
-
Adds a list of spout definitions.
- addAllStreams(List<StreamDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
-
Adds a list of stream definitions.
- addAllWorkerHooks(List<WorkerHookDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
-
Adds a list of worker hook definitions.
- addAnchor(String) - Method in class org.apache.storm.multilang.ShellMsg
- addAssignmentsForNode(String, String, Integer, SupervisorAssignments, StormMetricsRegistry) - Method in class org.apache.storm.nimbus.AssignmentDistributionService
-
Add an assignments for a node/supervisor for distribution.
- addAvroKryoSerializations(Config) - Static method in class org.apache.storm.hdfs.avro.AvroUtils
-
A helper method to extract avro serialization configurations from the topology configuration and register specific kryo serializers as necessary.
- addBatch(Tuple) - Method in class org.apache.storm.utils.BatchHelper
- addBolt(String, Object) - Method in class org.apache.storm.flux.model.ExecutionContext
- addBolt(IBatchBolt) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
- addBolt(IBatchBolt, Number) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
- addBolt(IBasicBolt) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
- addBolt(IBasicBolt, Number) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
- addBolt(IRichBolt) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
-
Deprecated.
- addBolt(IRichBolt, Number) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
-
Deprecated.
- addChild(Component) - Method in class org.apache.storm.scheduler.Component
-
Add a child link.
- addClassLoader(CompilingClassLoader) - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- addCommandArguments(String...) - Method in class org.apache.storm.container.docker.DockerCommand
-
Add command commandWithArguments.
- addCommandLineOptions(Options) - Static method in class org.apache.storm.loadgen.LoadMetricsServer
-
Add Command line options for configuring the output of this.
- addComponent(String, Object) - Method in class org.apache.storm.flux.model.ExecutionContext
- addComponentConfig(String, Object) - Method in class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
-
Add configuration for this bolt.
- addComponentConfig(String, Object) - Method in class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
-
Add configuration for this spout.
- addComponentConfig(String, List<Object>) - Method in class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
-
Add configuration for this bolt.
- addComponentConfig(String, List<Object>) - Method in class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
-
Add configuration for this spout.
- addConfiguration(String, Object) - Method in class org.apache.storm.topology.BaseConfigurationDeclarer
- addConfiguration(String, Object) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
-
Add in a single config.
- addConfigurations(Map<String, Object>) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
-
add in several configs to the component.
- addConfigurations(Map<String, Object>) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
- addCounter(String, Counter) - Method in class org.apache.storm.metrics2.TaskMetricRepo
- addCpuSetBindings(List<String>, String) - Method in class org.apache.storm.container.docker.DockerRunCommand
- addDevice(String, String) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Set --device option.
- addEmptyTopoForTests(String) - Method in class org.apache.storm.daemon.nimbus.HeartbeatCache
-
Add an empty topology to the cache for testing purposes.
- addEscapes(String) - Static method in error org.apache.storm.sql.parser.impl.TokenMgrError
-
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
- addEventLogger(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- addExecCommand(List<String>) - Method in class org.apache.storm.container.docker.DockerExecCommand
-
Add the command to run from inside container.
- addGauge(String, Gauge) - Method in class org.apache.storm.metrics2.TaskMetricRepo
- addGroup(Group) - Method in class org.apache.storm.trident.graph.GraphGrouper
- addHistogram(String, Histogram) - Method in class org.apache.storm.metrics2.TaskMetricRepo
- additionalKey - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
- additionalKey - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateUpdater
- addListener(CuratorFramework, ConnectionStateListener) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- addLocalSupervisor(Supervisor) - Method in class org.apache.storm.nimbus.AssignmentDistributionService
- addMem(Double) - Method in class org.apache.storm.scheduler.SupervisorResources
- addMeter(String, Meter) - Method in class org.apache.storm.metrics2.TaskMetricRepo
- addMetricComponents(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- addMetricStreams(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- addMockData(String, String, Values...) - Method in class org.apache.storm.testing.MockedSources
-
add mock data for the spout.
- addMockData(String, Values...) - Method in class org.apache.storm.testing.MockedSources
- addNimbusHost(String, NimbusSummary) - Method in interface org.apache.storm.cluster.IStormClusterState
- addNimbusHost(String, NimbusSummary) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- addNode(Node) - Method in class org.apache.storm.trident.TridentTopology
- addObjectResourcesItem(ObjectResourcesItem) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesSummary
- addOffHeap(double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- addOnHeap(double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- addPredicate(Predicate<? super T>, String) - Method in class org.apache.storm.streams.processors.BranchProcessor
- addPrivateWorkerKey(WorkerTokenServiceType, String, long, PrivateWorkerKey) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Store a new version of a private key.
- addPrivateWorkerKey(WorkerTokenServiceType, String, long, PrivateWorkerKey) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- addProcs(int) - Method in class org.apache.storm.container.cgroup.CgroupCommon
- addProcs(int) - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
add a process to cgroup.
- addProfilerActions(Set<Slot.TopoProfileAction>) - Method in class org.apache.storm.daemon.supervisor.Slot
- addReadOnlyMountLocation(String, String) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add readonly bind mout location.
- addReadOnlyMountLocation(String, String, boolean) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add readonly bind mount location.
- addReadWriteMountLocation(String, String) - Method in class org.apache.storm.container.docker.DockerRunCommand
- addReadWriteMountLocation(String, String, boolean) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add bind mount locations.
- addReceiver(TridentProcessor) - Method in class org.apache.storm.trident.planner.SubtopologyBolt.InitialReceiver
- addReference(PortAndAssignment, BlobChangingCallback) - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Mark that a given port and assignment are using this.
- addRequestContextFilter(ServletContextHandler, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.drpc.DRPCServer
-
Add a request context filter to the Servlet Context Handler.
- addRequestContextFilter(ServletContextHandler, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIServer
-
addRequestContextFilter.
- addResource(String, Number) - Method in class org.apache.storm.topology.BaseConfigurationDeclarer
- addResource(String, Number) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
-
Add generic resource for this component.
- addResource(String, Number) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
- addResourceMap(Map<String, Double>, Map<String, Double>) - Static method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- addResources(ConcurrentMap<String, ? extends LocallyCachedBlob>) - Method in class org.apache.storm.localizer.LocalizedResourceRetentionSet
-
Add blobs to be checked if they can be deleted.
- addResources(Map<String, Double>) - Method in class org.apache.storm.topology.BaseConfigurationDeclarer
-
Add generic resources for this component.
- addResources(Map<String, Double>) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
-
Add generic resources for this component.
- addResources(Map<String, Double>) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
- addResourcesForExec(ExecutorDetails, NormalizedResourceRequest) - Method in class org.apache.storm.scheduler.TopologyDetails
-
add resource requirements for a executor.
- AddressedTuple - Class in org.apache.storm.tuple
-
A Tuple that is addressed to a destination.
- AddressedTuple(int, Tuple) - Constructor for class org.apache.storm.tuple.AddressedTuple
- addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.bolt.AvroGenericRecordBolt
- addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.bolt.HdfsBolt
- addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.bolt.SequenceFileBolt
- addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
-
Deprecated.
- addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.trident.HdfsState.SequenceFileOptions
- addSharedMemory(SharedMemory) - Method in interface org.apache.storm.topology.ResourceDeclarer
-
Add in request for shared memory that this component will use.
- addSharedMemory(SharedMemory) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
- addSharedMemory(SharedMemory) - Method in class org.apache.storm.trident.operation.DefaultResourceDeclarer
- addSharedMemory(SharedMemory) - Method in class org.apache.storm.trident.Stream
- addSharedMemory(SharedMemory) - Method in class org.apache.storm.trident.TridentState
- addShutdownHooks(MyThread...) - Static method in class org.apache.storm.perf.queuetest.JCQueuePerfTest
- addShutdownHooks(MyThd...) - Static method in class org.apache.storm.perf.toolstest.JCToolsPerfTest
- addShutdownHookWithDelayedForceKill(Runnable, int) - Static method in class org.apache.storm.utils.Utils
-
Adds the user supplied function as a shutdown hook for cleanup.
- addShutdownHookWithForceKillIn1Sec(Runnable) - Static method in class org.apache.storm.utils.Utils
-
Adds the user supplied function as a shutdown hook for cleanup.
- addSourcedNode(List<Stream>, Node) - Method in class org.apache.storm.trident.TridentTopology
- addSourcedNode(Stream, Node) - Method in class org.apache.storm.trident.TridentTopology
- addSourcedStateNode(List<Stream>, Node) - Method in class org.apache.storm.trident.TridentTopology
- addSourcedStateNode(Stream, Node) - Method in class org.apache.storm.trident.TridentTopology
- addSpout(String, IRichSpout) - Method in class org.apache.storm.flux.model.ExecutionContext
- addStream(Stream<Values>) - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- addSupervisor() - Method in class org.apache.storm.LocalCluster
-
Add another supervisor to the topology.
- addSupervisor(Number) - Method in class org.apache.storm.LocalCluster
-
Add another supervisor to the topology.
- addSupervisor(Number, String) - Method in class org.apache.storm.LocalCluster
-
Add another supervisor to the topology.
- addSupervisor(Number, Map<String, Object>, String) - Method in class org.apache.storm.LocalCluster
-
Add another supervisor to the topology.
- addSupervisor(Supervisor) - Method in class org.apache.storm.daemon.nimbus.Nimbus
-
Used for local cluster.
- addSystemComponents(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- addSystemStreams(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- addTask(int) - Method in class org.apache.storm.container.cgroup.CgroupCommon
- addTask(int) - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
add task to cgroup.
- addTaskHook(ITaskHook) - Method in class org.apache.storm.task.TopologyContext
- addTimer(String, Timer) - Method in class org.apache.storm.metrics2.TaskMetricRepo
- addToAckMsgs(KafkaSpoutMessageId) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
- addToCache(String, String) - Static method in class org.apache.storm.starter.ResourceAwareExampleTopology.ExclamationBolt
- addToEmitMsgs(long) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
- addToLeaderLockQueue() - Method in interface org.apache.storm.nimbus.ILeaderElector
-
queue up for leadership lock.
- addToLeaderLockQueue() - Method in class org.apache.storm.testing.MockLeaderElector
- addToLeaderLockQueue() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
- addTopoConf(String, Subject, Map<String, Object>) - Method in class org.apache.storm.daemon.nimbus.TopoCache
-
Add a new topology config.
- addTopology(String, Subject, StormTopology) - Method in class org.apache.storm.daemon.nimbus.TopoCache
-
Add a new topology.
- addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.DefaultPool
- addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.FreePool
- addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.IsolatedPool
- addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.NodePool
-
Add a topology to the pool.
- addTopologyHistory(LSTopoHistory) - Method in class org.apache.storm.utils.LocalState
- addTuple(Object) - Method in class org.apache.storm.multilang.ShellMsg
- addTuplesBatch(Object, List<TridentTuple>) - Method in class org.apache.storm.trident.windowing.InMemoryTridentWindowManager
- addTuplesBatch(Object, List<TridentTuple>) - Method in interface org.apache.storm.trident.windowing.ITridentWindowManager
-
Add received batch of tuples to cache/store and add them to
WindowManager
. - addTuplesBatch(Object, List<TridentTuple>) - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
- addValue(double) - Method in class org.apache.storm.metrics2.RollingAverageGauge
- addValue(double) - Method in class org.apache.storm.metricstore.Metric
-
Adds an additional value to the metric.
- addVersions(StormTopology) - Static method in class org.apache.storm.utils.Utils
-
Add version information to the given topology.
- addWorkerHook(IWorkerHook) - Method in class org.apache.storm.topology.TopologyBuilder
-
Add a new worker lifecycle hook.
- adjustBeginLineColumn(int, int) - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Method to adjust line and column numbers for the start of a token.
- adjustImageConfigForTopo(Map<String, Object>, Map<String, Object>, String) - Static method in class org.apache.storm.container.oci.OciUtils
-
Adjust the image config for the topology.
- ADMIN - Static variable in class org.apache.storm.blobstore.BlobStoreAclHandler
- ADMIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AdminCommands - Class in org.apache.storm.command
- AdminCommands() - Constructor for class org.apache.storm.command.AdminCommands
- AdminCommands.AdminCommand - Interface in org.apache.storm.command
- admins - Variable in class org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
- admins - Variable in class org.apache.storm.security.auth.authorizer.SupervisorSimpleACLAuthorizer
- adminsGroups - Variable in class org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
- adminsGroups - Variable in class org.apache.storm.security.auth.authorizer.SupervisorSimpleACLAuthorizer
- advanceClusterTime(int) - Method in interface org.apache.storm.ILocalCluster
-
Advance the cluster time when the cluster is using SimulatedTime.
- advanceClusterTime(int) - Method in class org.apache.storm.LocalCluster
- advanceClusterTime(int, int) - Method in interface org.apache.storm.ILocalCluster
-
Advance the cluster time when the cluster is using SimulatedTime.
- advanceClusterTime(int, int) - Method in class org.apache.storm.LocalCluster
- advanceClusterTime(ILocalCluster, Integer) - Static method in class org.apache.storm.Testing
-
Simulated time wait for a cluster.
- advanceClusterTime(ILocalCluster, Integer, Integer) - Static method in class org.apache.storm.Testing
-
Simulated time wait for a cluster.
- AdvancedFSOps - Class in org.apache.storm.daemon.supervisor
- AdvancedFSOps(Map<String, Object>) - Constructor for class org.apache.storm.daemon.supervisor.AdvancedFSOps
- advanceTime(long) - Static method in class org.apache.storm.utils.Time
- advanceTimeNanos(long) - Static method in class org.apache.storm.utils.Time
- advanceTimeSecs(long) - Static method in class org.apache.storm.utils.Time
- AetherUtils - Class in org.apache.storm.submit.dependency
-
Utility class of Aether.
- AFTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- afterExecute(Runnable, Throwable) - Method in class org.apache.storm.utils.ExtendedThreadPoolExecutor
- AGG_LEVEL_1_MIN - Enum constant in enum class org.apache.storm.metricstore.AggLevel
- AGG_LEVEL_10_MIN - Enum constant in enum class org.apache.storm.metricstore.AggLevel
- AGG_LEVEL_60_MIN - Enum constant in enum class org.apache.storm.metricstore.AggLevel
- AGG_LEVEL_NONE - Enum constant in enum class org.apache.storm.metricstore.AggLevel
- aggBoltExecWinStats(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate windowed stats from a bolt executor stats with a Map of accumulated stats.
- aggBoltLatAndCount(Map<List<String>, Double>, Map<List<String>, Double>, Map<List<String>, Long>) - Static method in class org.apache.storm.stats.StatsUtil
-
Aggregates number executed, process latency, and execute latency across all streams.
- aggBoltStreamsLatAndCount(Map<K, Double>, Map<K, Double>, Map<K, Long>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate number executed and process & execute latencies.
- aggCompExecsStats(Map, Map, Map<List<Integer>, Map<String, Object>>, String, boolean, String, StormTopology, String) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate component executor stats.
- aggCompExecStats(String, boolean, Map<String, Object>, Map<String, Object>, String) - Static method in class org.apache.storm.stats.StatsUtil
-
Combines the aggregate stats of one executor with the given map, selecting the appropriate window and including system components as specified.
- AggLevel - Enum Class in org.apache.storm.metricstore
-
Specifies the available timeframes for Metric aggregation.
- aggPartition(GroupedStream) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggPartition(S) - Method in interface org.apache.storm.trident.fluent.GlobalAggregationScheme
- aggPreMergeCompPageBolt(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
pre-merge component page bolt stats from an executor heartbeat 1.
- aggPreMergeCompPageSpout(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
pre-merge component page spout stats from an executor heartbeat 1.
- aggPreMergeTopoPageBolt(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
pre-merge component stats of specified bolt id.
- aggPreMergeTopoPageSpout(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
pre-merge component stats of specified spout id and returns { comp id -> comp-stats }.
- aggregate(Object[], TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedAggregator
- aggregate(PriorityQueue, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNSortedAgg
- aggregate(CombinerAggregator<? super T, A, ? extends R>) - Method in class org.apache.storm.streams.Stream
-
Aggregates the values in this stream using the aggregator.
- aggregate(Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- aggregate(Aggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
- aggregate(Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggregate(Aggregator, Fields) - Method in class org.apache.storm.trident.Stream
- aggregate(ComparisonAggregator.State, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.ComparisonAggregator
- aggregate(FirstN.FirstNAgg.State, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg
- aggregate(CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- aggregate(CombinerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
- aggregate(CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggregate(CombinerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
- aggregate(ChainedResult, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
- aggregate(Result, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
- aggregate(Result, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ReducerAggregatorImpl
- aggregate(SingleEmitAggregator.SingleEmitState, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.SingleEmitAggregator
- aggregate(ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- aggregate(ReducerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
- aggregate(ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggregate(ReducerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
- aggregate(CountAsAggregator.State, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.testing.CountAsAggregator
- aggregate(Fields, Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- aggregate(Fields, Aggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
- aggregate(Fields, Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggregate(Fields, Aggregator, Fields) - Method in class org.apache.storm.trident.Stream
- aggregate(Fields, CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- aggregate(Fields, CombinerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
- aggregate(Fields, CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggregate(Fields, CombinerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
- aggregate(Fields, ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- aggregate(Fields, ReducerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
- aggregate(Fields, ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- aggregate(Fields, ReducerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
- aggregate(R, BiFunction<? super R, ? super T, ? extends R>, BiFunction<? super R, ? super R, ? extends R>) - Method in class org.apache.storm.streams.Stream
-
Aggregates the values in this stream using the given initial value, accumulator and combiner.
- aggregate(T, TridentTuple, TridentCollector) - Method in interface org.apache.storm.trident.operation.Aggregator
- aggregateAverages(List<Map<String, Map<K, Double>>>, List<Map<String, Map<K, Long>>>) - Static method in class org.apache.storm.stats.StatsUtil
-
compute an weighted average from a list of average maps and a corresponding count maps extracted from a list of ExecutorSummary.
- aggregateAvgStreams(Map<String, Map<K, Double>>, Map<String, Map<K, Long>>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate weighted average of all streams.
- aggregateBoltStats(List<ExecutorSummary>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate bolt stats.
- aggregateBoltStreams(Map<String, Map>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate all bolt streams.
- aggregateByKey(CombinerAggregator<? super V, A, ? extends R>) - Method in class org.apache.storm.streams.PairStream
-
Aggregates the values for each key of this stream using the given
CombinerAggregator
. - aggregateByKey(R, BiFunction<? super R, ? super V, ? extends R>, BiFunction<? super R, ? super R, ? extends R>) - Method in class org.apache.storm.streams.PairStream
-
Aggregates the values for each key of this stream using the given initial value, accumulator and combiner.
- AggregateByKeyProcessor<K,
V, A, R> - Class in org.apache.storm.streams.processors - AggregateByKeyProcessor(CombinerAggregator<V, A, R>) - Constructor for class org.apache.storm.streams.processors.AggregateByKeyProcessor
- AggregateByKeyProcessor(CombinerAggregator<V, A, R>, boolean) - Constructor for class org.apache.storm.streams.processors.AggregateByKeyProcessor
- aggregateCommonStats(List<ExecutorSummary>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate common stats from a spout/bolt, called in aggregateSpoutStats/aggregateBoltStats.
- aggregateCompStats(String, boolean, List<Map<String, Object>>, String) - Static method in class org.apache.storm.stats.StatsUtil
-
Aggregate the stats for a component over a given window of time.
- aggregateCounts(List<Map<String, Map<T, Long>>>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate a list of count maps into one map.
- aggregateCountStreams(Map<String, Map<K, V>>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate count streams by window.
- AggregateExample - Class in org.apache.storm.starter.streams
-
An example that illustrates the global aggregate.
- AggregateExample() - Constructor for class org.apache.storm.starter.streams.AggregateExample
- AggregateProcessor<T,
A, R> - Class in org.apache.storm.streams.processors - AggregateProcessor - Class in org.apache.storm.trident.planner.processor
- AggregateProcessor(CombinerAggregator<T, A, R>) - Constructor for class org.apache.storm.streams.processors.AggregateProcessor
- AggregateProcessor(CombinerAggregator<T, A, R>, boolean) - Constructor for class org.apache.storm.streams.processors.AggregateProcessor
- AggregateProcessor(Fields, Aggregator) - Constructor for class org.apache.storm.trident.planner.processor.AggregateProcessor
- aggregateSpoutStats(List<ExecutorSummary>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate spout stats.
- aggregateSpoutStreams(Map<String, Map>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate all spout streams.
- aggregator - Variable in class org.apache.storm.streams.processors.MergeAggregateByKeyProcessor
- aggregator - Variable in class org.apache.storm.trident.windowing.AbstractTridentWindowManager
- Aggregator<T> - Interface in org.apache.storm.trident.operation
- aggSpoutExecWinStats(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate windowed stats from a spout executor stats with a Map of accumulated stats.
- aggSpoutLatAndCount(Map<String, Double>, Map<String, Long>) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate number acked and complete latencies across all streams.
- aggSpoutStreamsLatAndCount(Map<K, Double>, Map<K, Long>) - Static method in class org.apache.storm.stats.StatsUtil
-
Aggregates number acked and complete latencies.
- aggTopoExecsStats(String, Map, Map, Map<List<Integer>, Map<String, Object>>, StormTopology, String, boolean, IStormClusterState) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate topo executors stats.
- aggTopoExecStats(String, boolean, Map<String, Object>, Map<String, Object>, String) - Static method in class org.apache.storm.stats.StatsUtil
-
A helper function that does the common work to aggregate stats of one executor with the given map for the topology page.
- aggWorkerStats(String, String, Map<Integer, String>, Map<List<Integer>, Map<String, Object>>, Map<List<Long>, List<Object>>, Map<String, String>, Map<WorkerSlot, WorkerResources>, boolean, boolean, String, String) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregate statistics per worker for a topology.
- all() - Static method in class org.apache.storm.coordination.CoordinatedBolt.SourceArgs
- all() - Static method in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordType
- all(NullStruct) - Static method in class org.apache.storm.generated.Grouping
- ALL - Enum constant in enum class org.apache.storm.flux.model.GroupingDef.Type
- ALL - Enum constant in enum class org.apache.storm.generated.Grouping._Fields
- ALL - Enum constant in enum class org.apache.storm.generated.NumErrorsChoice
- ALL - Enum constant in enum class org.apache.storm.loadgen.GroupingType
- ALL - Enum constant in enum class org.apache.storm.perf.utils.BasicMetricsCollector.MetricsItem
- ALL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- allComponents(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- AllGrouper() - Constructor for class org.apache.storm.daemon.GrouperFactory.AllGrouper
- allGrouping() - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- allGrouping(String) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- allGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
-
The stream is replicated across all the bolt's tasks.
- allGrouping(String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- allGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
-
The stream is replicated across all the bolt's tasks.
- allGrouping(String, String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- ALLOCATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- allocateBuffer(ChannelHandlerContext, INettySerializable, boolean) - Method in class org.apache.storm.messaging.netty.NettySerializableMessageEncoder
- allOutputFields - Variable in class org.apache.storm.trident.planner.Node
- ALLOW - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- allowRetry(int, long, RetrySleeper) - Method in class org.apache.storm.utils.StormBoundedExponentialBackoffRetry
- allSlotsAvailableForScheduling(Collection<SupervisorDetails>, Topologies, Set<String>) - Method in class org.apache.storm.daemon.nimbus.Nimbus.StandaloneINimbus
- allSlotsAvailableForScheduling(Collection<SupervisorDetails>, Topologies, Set<String>) - Method in interface org.apache.storm.scheduler.INimbus
-
Returns all slots that are available for the next round of scheduling.
- allSupervisorInfo() - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get all of the supervisors with the ID as the key.
- allSupervisorInfo(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get all supervisor info.
- AlreadyAliveException - Exception in org.apache.storm.generated
- AlreadyAliveException() - Constructor for exception org.apache.storm.generated.AlreadyAliveException
- AlreadyAliveException(String) - Constructor for exception org.apache.storm.generated.AlreadyAliveException
- AlreadyAliveException(AlreadyAliveException) - Constructor for exception org.apache.storm.generated.AlreadyAliveException
-
Performs a deep copy on other.
- AlreadyAliveException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ALTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AlternateRackDNSToSwitchMapping - Class in org.apache.storm.testing
-
This class implements the
DNSToSwitchMapping
interface It alternates bewteen RACK1 and RACK2 for the hosts. - AlternateRackDNSToSwitchMapping() - Constructor for class org.apache.storm.testing.AlternateRackDNSToSwitchMapping
- ALWAYS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AnchoredWordCount - Class in org.apache.storm.starter
- AnchoredWordCount() - Constructor for class org.apache.storm.starter.AnchoredWordCount
- AnchoredWordCount.RandomSentenceSpout - Class in org.apache.storm.starter
- AnchoredWordCount.SplitSentence - Class in org.apache.storm.starter
- AnchoredWordCount.WordCount - Class in org.apache.storm.starter
- AND - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- anonymize() - Method in class org.apache.storm.loadgen.TopologyLoadConf
-
Create a new version of this topology with identifiable information removed.
- ANOTHER_BOLT - Static variable in class org.apache.storm.jms.example.ExampleJmsTopology
- ANY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- anyNonCpuOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Are any of the non cpu resources positive.
- AppendCollector - Class in org.apache.storm.trident.planner.processor
- AppendCollector(TridentContext) - Constructor for class org.apache.storm.trident.planner.processor.AppendCollector
- apply(A, T) - Method in interface org.apache.storm.streams.operations.CombinerAggregator
-
Updates the accumulator by applying the current accumulator with the value.
- apply(Long, Number) - Method in class org.apache.storm.streams.operations.aggregators.LongSum
- apply(Long, T) - Method in class org.apache.storm.streams.operations.aggregators.Count
- apply(ConsumerRecord<ByteBuffer, ByteBuffer>) - Method in class org.apache.storm.sql.kafka.RecordTranslatorSchemeAdapter
- apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.flux.examples.OnlyValueRecordTranslator
- apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.kafka.spout.ByTopicRecordTranslator
- apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.kafka.spout.DefaultRecordTranslator
- apply(ConsumerRecord<K, V>) - Method in interface org.apache.storm.kafka.spout.RecordTranslator
-
Translate the ConsumerRecord into a list of objects that can be emitted.
- apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.kafka.spout.SimpleRecordTranslator
- apply(IMetricsConsumer.DataPoint) - Method in class org.apache.storm.metric.filter.FilterByMetricName
- apply(Stream) - Method in interface org.apache.storm.trident.operation.Assembly
-
Applies the `Assembly` to a given
Stream
. - apply(Stream) - Method in class org.apache.storm.trident.operation.builtin.FirstN
- apply(Tuple) - Method in class org.apache.storm.sql.runtime.streams.functions.StreamsScanTupleValueMapper
- apply(Tuple) - Method in class org.apache.storm.streams.operations.mappers.PairValueMapper
- apply(Tuple) - Method in class org.apache.storm.streams.operations.mappers.ValueMapper
- apply(Tuple) - Method in class org.apache.storm.streams.operations.mappers.ValuesMapper
- apply(Values) - Method in class org.apache.storm.sql.runtime.streams.functions.EvaluationCalc
- apply(Values) - Method in class org.apache.storm.sql.runtime.streams.functions.EvaluationFunction
- apply(Values) - Method in class org.apache.storm.sql.runtime.streams.functions.StreamInsertMapToPairFunction
- apply(S, T) - Method in interface org.apache.storm.streams.operations.StateUpdater
-
Returns a new state by applying the value on the current state.
- apply(T) - Method in interface org.apache.storm.localizer.IOFunction
- apply(T) - Method in interface org.apache.storm.streams.operations.Function
-
Applies this function to the given argument.
- apply(T) - Method in class org.apache.storm.streams.operations.IdentityFunction
- apply(T, T) - Method in interface org.apache.storm.streams.operations.Reducer
-
Applies this function to the given arguments.
- apply(T, U) - Method in interface org.apache.storm.streams.operations.BiFunction
-
Applies this function to the given arguments.
- apply(V) - Method in interface org.apache.storm.kafka.spout.Func
- apply(V1, V2) - Method in class org.apache.storm.streams.operations.PairValueJoiner
-
Joins two values and produces a
Pair
of the values as the result. - apply(V1, V2) - Method in interface org.apache.storm.streams.operations.ValueJoiner
-
Joins two values and produces a result.
- APPLY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- applyAssembly(Assembly) - Method in class org.apache.storm.trident.Stream
-
Applies an `Assembly` to this `Stream`.
- applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.BoltAckInfo
- applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.BoltExecuteInfo
- applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.BoltFailInfo
- applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.EmitInfo
- applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.SpoutAckInfo
- applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.SpoutFailInfo
- applyTo(ISeq) - Method in class org.apache.storm.clojure.ClojureTuple
- applyUUIDToFileName(String) - Static method in class org.apache.storm.dependency.DependencyBlobStoreUtils
- APPROVED_WORKERS - Enum constant in enum class org.apache.storm.generated.LSApprovedWorkers._Fields
- APPROX_NUMERIC_LITERAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ARCHIVE_DIR - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.
- ARE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- areAllConnectionsReady() - Method in class org.apache.storm.daemon.worker.WorkerState
- areAllExecsScheduled() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- areAllProcessesDead() - Method in class org.apache.storm.daemon.supervisor.Container
- areAllProcessesDead() - Method in interface org.apache.storm.daemon.supervisor.Killable
-
Check whether all processes are dead.
- areAllProcessesDead() - Method in class org.apache.storm.daemon.supervisor.LocalContainer
- areAllProcessesDead(String, String) - Method in class org.apache.storm.container.DefaultResourceIsolationManager
- areAllProcessesDead(String, String) - Method in class org.apache.storm.container.docker.DockerManager
-
Currently it only checks if the container is alive.
- areAllProcessesDead(String, String) - Method in class org.apache.storm.container.oci.RuncLibContainerManager
-
The container terminates if any process inside the container dies.
- areAllProcessesDead(String, String) - Method in interface org.apache.storm.container.ResourceIsolationInterface
-
Check if all the processes are dead.
- areAllProcessesDead(Map<String, Object>, String, String, Set<Long>) - Static method in class org.apache.storm.utils.ServerUtils
-
Find if all processes for the user on workId are dead.
- areAnyOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- areAnyOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- areAnyOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Are any of the resources positive.
- areAnyOverZero() - Method in interface org.apache.storm.scheduler.resource.normalization.NormalizedResourcesWithMemory
-
Return true if any of the resources are > 0.
- areKeysSkewed - Variable in class org.apache.storm.loadgen.OutputStream
- areLocalAssignmentsEquivalent(LocalAssignment, LocalAssignment) - Static method in class org.apache.storm.utils.EquivalenceUtils
-
Decide the equivalence of two local assignments, ignoring the order of executors This is different from #equal method.
- areSearchLimitsExceeded() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- areTaskIdsNeeded() - Method in class org.apache.storm.multilang.ShellMsg
- areWorkerTokensEnabledServer(MultiThriftServer<?>, Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Check if worker tokens should be enabled on the server side or not.
- areWorkerTokensEnabledServer(ThriftConnectionType, Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Check if worker tokens should be enabled on the server side or not (for a given server).
- areWorkerTokensSupported() - Method in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
- areWorkerTokensSupported() - Method in interface org.apache.storm.security.auth.ITransportPlugin
-
Check if worker tokens are supported by this transport.
- areWorkerTokensSupported() - Method in class org.apache.storm.security.auth.kerberos.KerberosSaslTransportPlugin
- areWorkerTokensSupported() - Method in class org.apache.storm.security.auth.tls.TlsTransportPlugin
- arg(String) - Static method in class org.apache.storm.command.CLI
-
Add a named argument.
- arg(String) - Method in class org.apache.storm.command.CLI.CLIBuilder
-
Add a named argument.
- arg(String, CLI.Assoc) - Static method in class org.apache.storm.command.CLI
-
Add a named argument.
- arg(String, CLI.Assoc) - Method in class org.apache.storm.command.CLI.CLIBuilder
-
Add a named argument.
- arg(String, CLI.Parse) - Static method in class org.apache.storm.command.CLI
-
Add a named argument.
- arg(String, CLI.Parse) - Method in class org.apache.storm.command.CLI.CLIBuilder
-
Add a named argument.
- arg(String, CLI.Parse, CLI.Assoc) - Static method in class org.apache.storm.command.CLI
-
Add a named argument.
- arg(String, CLI.Parse, CLI.Assoc) - Method in class org.apache.storm.command.CLI.CLIBuilder
-
Add a named argument.
- Arg(List, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- Arg0(List, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- ARGS_LIST - Enum constant in enum class org.apache.storm.generated.JavaObject._Fields
- ARGS_STREAM - Static variable in class org.apache.storm.drpc.PrepareRequest
- ARRAY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ARRAY_MAX_CARDINALITY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ArrayConstructor() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses an ARRAY constructor
- ArrayListSerializer - Class in org.apache.storm.serialization.types
- ArrayListSerializer() - Constructor for class org.apache.storm.serialization.types.ArrayListSerializer
- ArtifactoryConfigLoader - Class in org.apache.storm.scheduler.utils
-
A dynamic loader that can load scheduler configurations for user resource guarantees from Artifactory (an artifact repository manager).
- ArtifactoryConfigLoader(Map<String, Object>) - Constructor for class org.apache.storm.scheduler.utils.ArtifactoryConfigLoader
- ArtifactoryConfigLoaderFactory - Class in org.apache.storm.scheduler.utils
-
Factory class for ArtifactoryConfigLoader.
- ArtifactoryConfigLoaderFactory() - Constructor for class org.apache.storm.scheduler.utils.ArtifactoryConfigLoaderFactory
- artifactToString(Artifact) - Static method in class org.apache.storm.submit.dependency.AetherUtils
-
Convert
Artifact
object to String for printing. - AS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AS_INT - Static variable in class org.apache.storm.command.CLI
-
Parse function to return an Integer.
- AS_STRING - Static variable in class org.apache.storm.command.CLI
-
Noop parse function, returns the String.
- ASC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ASENSITIVE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- asMap() - Method in class org.apache.storm.windowing.persistence.SimpleWindowPartitionCache
- asMap() - Method in interface org.apache.storm.windowing.persistence.WindowPartitionCache
-
Return a
ConcurrentMap
view of the current entries in the cache. - Assembly - Interface in org.apache.storm.trident.operation
-
The `Assembly` interface provides a means to encapsulate logic applied to a
Stream
. - assertFull() - Method in enum class org.apache.storm.daemon.supervisor.Container.ContainerType
- ASSERTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- assertValidTopologyForModification(String) - Method in class org.apache.storm.scheduler.Cluster
-
Check if the given topology is allowed for modification right now.
- assertValidTopologyForModification(String) - Method in class org.apache.storm.scheduler.SingleTopologyCluster
- assign(String, Collection<ExecutorDetails>, Cluster) - Method in class org.apache.storm.scheduler.multitenant.Node
-
Assign a free slot on the node to the following topology and executors.
- assign(SchedulerAssignment, boolean) - Method in class org.apache.storm.scheduler.Cluster
-
Assign everything for the given topology.
- assign(WorkerSlot, String, Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.Cluster
-
Assign the slot to the executors for this topology.
- assign(WorkerSlot, Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
-
Deprecated.
- assign(WorkerSlot, Collection<ExecutorDetails>, WorkerResources) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
-
Assign the slot to executors.
- assign(WorkerSlot, TopologyDetails, Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.resource.RasNode
-
Assigns a worker to a node.
- assign(BoltDeclarer, InputStream) - Method in enum class org.apache.storm.loadgen.GroupingType
- AssignableMetric - Class in org.apache.storm.metric.api
- AssignableMetric(Object) - Constructor for class org.apache.storm.metric.api.AssignableMetric
- AssignableShellMetric - Class in org.apache.storm.metric.api.rpc
- AssignableShellMetric(Object) - Constructor for class org.apache.storm.metric.api.rpc.AssignableShellMetric
- assignBoundAckersForNewWorkerSlot(ExecutorDetails, RasNode, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
-
Determine how many bound ackers to put into the given workerSlot.
- assignCurrentExecutor(Map<ExecutorDetails, String>, RasNode, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Attempt to assign current executor (execIndex points to) to worker and node.
- assigned(Collection<Integer>) - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
- assigned(Collection<Integer>) - Method in interface org.apache.storm.scheduler.ISupervisor
- ASSIGNED_CPU - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- ASSIGNED_CPU - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_CPU - Enum constant in enum class org.apache.storm.generated.TopologySummary._Fields
- ASSIGNED_CPU - Enum constant in enum class org.apache.storm.generated.WorkerSummary._Fields
- ASSIGNED_GENERIC_RESOURCES - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_GENERIC_RESOURCES - Enum constant in enum class org.apache.storm.generated.TopologySummary._Fields
- ASSIGNED_MEMOFFHEAP - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- ASSIGNED_MEMOFFHEAP - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_MEMOFFHEAP - Enum constant in enum class org.apache.storm.generated.TopologySummary._Fields
- ASSIGNED_MEMOFFHEAP - Enum constant in enum class org.apache.storm.generated.WorkerSummary._Fields
- ASSIGNED_MEMONHEAP - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- ASSIGNED_MEMONHEAP - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_MEMONHEAP - Enum constant in enum class org.apache.storm.generated.TopologySummary._Fields
- ASSIGNED_MEMONHEAP - Enum constant in enum class org.apache.storm.generated.WorkerSummary._Fields
- ASSIGNED_OFF_HEAP_MEMORY - Enum constant in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- ASSIGNED_ON_HEAP_MEMORY - Enum constant in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- ASSIGNED_REGULAR_OFF_HEAP_MEMORY - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_REGULAR_ON_HEAP_MEMORY - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_SHARED_OFF_HEAP_MEMORY - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ASSIGNED_SHARED_ON_HEAP_MEMORY - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- assignedCpu - Variable in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
- assignedMemory - Variable in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
- assignment - Variable in class org.apache.storm.daemon.supervisor.Container
- Assignment - Class in org.apache.storm.generated
- Assignment() - Constructor for class org.apache.storm.generated.Assignment
- Assignment(String) - Constructor for class org.apache.storm.generated.Assignment
- Assignment(Assignment) - Constructor for class org.apache.storm.generated.Assignment
-
Performs a deep copy on other.
- ASSIGNMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ASSIGNMENT_ID - Enum constant in enum class org.apache.storm.generated.SupervisorInfo._Fields
- Assignment._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- AssignmentDistributionService - Class in org.apache.storm.nimbus
-
A service for distributing master assignments to supervisors, this service makes the assignments notification asynchronous.
- AssignmentDistributionService() - Constructor for class org.apache.storm.nimbus.AssignmentDistributionService
- assignmentInfo(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get the assignment based on storm id from local backend.
- assignmentInfo(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- assignmentInfoWithVersion(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
- assignmentInfoWithVersion(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- assignmentPath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
- assignments() - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
List all the storm runtime ids of local assignments.
- assignments() - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- assignments(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
- assignments(Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- ASSIGNMENTS - Enum constant in enum class org.apache.storm.generated.LSSupervisorAssignments._Fields
- ASSIGNMENTS - Enum constant in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args._Fields
- ASSIGNMENTS_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
- ASSIGNMENTS_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
- assignmentsInfo() - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
Get all the local assignments of local state.
- assignmentsInfo() - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- assignmentsInfo() - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get all the topologies assignments mapping stormId -> Assignment from local backend.
- assignmentsInfo() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- assignmentVersion(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
- assignmentVersion(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- assignPartitions(Consumer<K, V>, Set<TopicPartition>, ConsumerRebalanceListener) - Method in class org.apache.storm.kafka.spout.subscription.TopicAssigner
-
Assign partitions to the KafkaConsumer.
- assignSingleBoundAcker(RasNode, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Remove the head of unassigned ackers and attempt to assign it to a workerSlot as a bound acker.
- assignSingleExecutor(WorkerSlot, ExecutorDetails, TopologyDetails) - Method in class org.apache.storm.scheduler.resource.RasNode
-
Assign a single executor to a slot, even if other things are in the slot.
- assignSlots(Topologies, Map<String, Collection<WorkerSlot>>) - Method in class org.apache.storm.daemon.nimbus.Nimbus.StandaloneINimbus
- assignSlots(Topologies, Map<String, Collection<WorkerSlot>>) - Method in interface org.apache.storm.scheduler.INimbus
-
this is called after the assignment is changed in ZK.
- assignSlotTo(Node) - Method in class org.apache.storm.scheduler.multitenant.NodePool.RoundRobinSlotScheduler
-
Assign a slot to the given node.
- assoc(Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- assoc(Object, Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- assoc(Object, Object) - Method in interface org.apache.storm.command.CLI.Assoc
-
Associate a value into something else.
- assocEx(Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- assocEx(Object, Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- asUser(String) - Method in class org.apache.storm.utils.NimbusClient.Builder
- ASYMMETRIC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- async - Enum constant in enum class org.apache.storm.container.cgroup.core.BlkioCore.RecordType
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncClient
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Supervisor.AsyncClient
- AsyncLocalizer - Class in org.apache.storm.localizer
-
Downloads and caches blobs locally.
- AsyncLocalizer(Map<String, Object>, StormMetricsRegistry) - Constructor for class org.apache.storm.localizer.AsyncLocalizer
- asyncLoop(Callable) - Static method in class org.apache.storm.utils.Utils
-
Convenience method used when only the function is given.
- asyncLoop(Callable, boolean, Thread.UncaughtExceptionHandler, int, boolean, boolean, String) - Static method in class org.apache.storm.utils.Utils
-
Creates a thread that calls the given code repeatedly, sleeping for an interval of seconds equal to the return value of the previous call.
- asyncLoop(Callable, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.storm.utils.Utils
-
Convenience method used when only the function and name suffix are given.
- AsyncProcessor(I) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.storm.generated.Supervisor.AsyncProcessor
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncProcessor
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.Supervisor.AsyncProcessor
- AT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AT_LEAST_ONCE - Enum constant in enum class org.apache.storm.kafka.spout.KafkaSpoutConfig.ProcessingGuarantee
-
An offset is ready to commit only after the corresponding tuple has been processed and acked (at least once).
- AT_MOST_ONCE - Enum constant in enum class org.apache.storm.kafka.spout.KafkaSpoutConfig.ProcessingGuarantee
-
Every offset will be synchronously committed to Kafka right after being polled but before being emitted to the downstream components of the topology.
- ATOMIC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AtomicOutputStream - Class in org.apache.storm.blobstore
-
An output stream where all of the data is committed on close, or can be canceled with cancel.
- AtomicOutputStream() - Constructor for class org.apache.storm.blobstore.AtomicOutputStream
- AtomicRowExpression() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses an atomic row expression.
- ATTRIBUTE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ATTRIBUTES - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- authenticated(Channel) - Method in interface org.apache.storm.messaging.netty.ISaslServer
- AuthNimbusOp - Annotation Interface in org.apache.storm.daemon.ui.resources
- AUTHORIZATION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- AuthorizationException - Exception in org.apache.storm.generated
- AuthorizationException() - Constructor for exception org.apache.storm.generated.AuthorizationException
- AuthorizationException(String) - Constructor for exception org.apache.storm.generated.AuthorizationException
- AuthorizationException(AuthorizationException) - Constructor for exception org.apache.storm.generated.AuthorizationException
-
Performs a deep copy on other.
- AuthorizationException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- AuthorizationExceptionMapper - Class in org.apache.storm.daemon.common
- AuthorizationExceptionMapper - Class in org.apache.storm.daemon.ui.exceptionmappers
- AuthorizationExceptionMapper() - Constructor for class org.apache.storm.daemon.common.AuthorizationExceptionMapper
- AuthorizationExceptionMapper() - Constructor for class org.apache.storm.daemon.ui.exceptionmappers.AuthorizationExceptionMapper
- authorizedGroups - Variable in class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer.ImpersonationACL
- authorizedHosts - Variable in class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer.ImpersonationACL
- AuthorizedUserFilter - Class in org.apache.storm.daemon.ui.filters
- AuthorizedUserFilter() - Constructor for class org.apache.storm.daemon.ui.filters.AuthorizedUserFilter
- AutoHBase - Class in org.apache.storm.hbase.security
-
Auto credentials plugin for HBase implementation.
- AutoHBase() - Constructor for class org.apache.storm.hbase.security.AutoHBase
- AutoHBaseCommand - Class in org.apache.storm.hbase.security
-
Command tool of Hive credential renewer.
- AutoHBaseNimbus - Class in org.apache.storm.hbase.security
-
Auto credentials nimbus plugin for HBase implementation.
- AutoHBaseNimbus() - Constructor for class org.apache.storm.hbase.security.AutoHBaseNimbus
- AutoHDFS - Class in org.apache.storm.hdfs.security
-
Auto credentials plugin for HDFS implementation.
- AutoHDFS() - Constructor for class org.apache.storm.hdfs.security.AutoHDFS
- AutoHDFSCommand - Class in org.apache.storm.hdfs.security
-
Command tool of HDFS credential renewer.
- AutoHDFSNimbus - Class in org.apache.storm.hdfs.security
-
Auto credentials nimbus plugin for HDFS implementation.
- AutoHDFSNimbus() - Constructor for class org.apache.storm.hdfs.security.AutoHDFSNimbus
- AutoSSL - Class in org.apache.storm.security.auth
-
This plugin is intended to be used for user topologies to send SSL keystore/truststore files to the remote workers.
- AutoSSL() - Constructor for class org.apache.storm.security.auth.AutoSSL
- AutoTGT - Class in org.apache.storm.security.auth.kerberos
-
Automatically take a user's TGT, and push it, and renew it in Nimbus.
- AutoTGT() - Constructor for class org.apache.storm.security.auth.kerberos.AutoTGT
- AutoTGTKrb5LoginModule - Class in org.apache.storm.security.auth.kerberos
-
Custom LoginModule to enable Auto Login based on cached ticket.
- AutoTGTKrb5LoginModule() - Constructor for class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
- AutoTGTKrb5LoginModuleTest - Class in org.apache.storm.security.auth.kerberos
-
Custom LoginModule extended for testing.
- AutoTGTKrb5LoginModuleTest() - Constructor for class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModuleTest
- available() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
- available() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusDownloadInputStream
- availableResources - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesItem
- AVG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- avgResourcePercent - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesItem
-
Amongst all
ObjectResourcesItem.availableResources
, this is the average ratio of resource to the total available in group. - AvroGenericRecordBolt - Class in org.apache.storm.hdfs.bolt
- AvroGenericRecordBolt() - Constructor for class org.apache.storm.hdfs.bolt.AvroGenericRecordBolt
- AvroGenericRecordHDFSWriter - Class in org.apache.storm.hdfs.common
- AvroGenericRecordHDFSWriter(FileRotationPolicy, Path, FSDataOutputStream, Schema) - Constructor for class org.apache.storm.hdfs.common.AvroGenericRecordHDFSWriter
- AvroSchemaRegistry - Interface in org.apache.storm.hdfs.avro
- AvroScheme - Class in org.apache.storm.sql.runtime.serde.avro
-
AvroScheme uses generic(without code generation) instead of specific(with code generation) readers.
- AvroScheme(String, List<String>) - Constructor for class org.apache.storm.sql.runtime.serde.avro.AvroScheme
-
AvroScheme Constructor.
- AvroSerializer - Class in org.apache.storm.sql.runtime.serde.avro
-
AvroSerializer uses generic(without code generation) instead of specific(with code generation) writers.
- AvroSerializer(String, List<String>) - Constructor for class org.apache.storm.sql.runtime.serde.avro.AvroSerializer
-
AvroSerializer Constructor.
- AvroUtils - Class in org.apache.storm.hdfs.avro
- AvroUtils() - Constructor for class org.apache.storm.hdfs.avro.AvroUtils
- awaitLeadership(long, TimeUnit) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- awaitLeadership(long, TimeUnit) - Method in interface org.apache.storm.nimbus.ILeaderElector
-
Wait for the caller to gain leadership.
- awaitLeadership(long, TimeUnit) - Method in class org.apache.storm.testing.MockLeaderElector
- awaitLeadership(long, TimeUnit) - Method in class org.apache.storm.zookeeper.LeaderElectorImp
- AZE - Enum constant in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.result_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.beginFileUpload_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.downloadChunk_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.finishFileUpload_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getBlobMeta_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getBlobReplication_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getClusterInfo_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getLeader_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getNimbusConf_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.setBlobMeta_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadChunk_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result._Fields
- AZE - Enum constant in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result._Fields
B
- BACK_PRESSURE_WAIT - Enum constant in enum class org.apache.storm.policy.IWaitStrategy.WaitSituation
- BACK_QUOTED_IDENTIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BACKPRESSURE_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
- BACKPRESSURE_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
- backpressurePath(String, String) - Static method in class org.apache.storm.cluster.ClusterUtils
-
Get the backpressure znode full path.
- backpressurePath(String, String, Long) - Static method in class org.apache.storm.cluster.ClusterUtils
- BackPressureStatus - Class in org.apache.storm.messaging.netty
- BackPressureStatus() - Constructor for class org.apache.storm.messaging.netty.BackPressureStatus
- BackPressureStatus(String, Collection<Integer>, Collection<Integer>) - Constructor for class org.apache.storm.messaging.netty.BackPressureStatus
-
Constructor.
- BackPressureStatusEncoder - Class in org.apache.storm.messaging.netty
- BackPressureStatusEncoder(KryoValuesSerializer) - Constructor for class org.apache.storm.messaging.netty.BackPressureStatusEncoder
- backpressureStormRoot(String) - Static method in class org.apache.storm.cluster.ClusterUtils
- BackPressureTopo - Class in org.apache.storm.perf
- BackPressureTopo() - Constructor for class org.apache.storm.perf.BackPressureTopo
- backpressureTopologies() - Method in interface org.apache.storm.cluster.IStormClusterState
-
Deprecated, for removal: This API element is subject to removal in a future version.
- backpressureTopologies() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- BackPressureTracker - Class in org.apache.storm.daemon.worker
-
Tracks the BackPressure status.
- BackPressureTracker(String, Map<Integer, JCQueue>, StormMetricRegistry, Map<Integer, String>) - Constructor for class org.apache.storm.daemon.worker.BackPressureTracker
- BackPressureTracker.BackpressureState - Class in org.apache.storm.daemon.worker
- backtrack(Map<ExecutorDetails, String>, RasNode[], WorkerSlot[]) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Backtrack to prior executor that was directly assigned.
- backup(int) - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Backup a number of characters.
- BAD_DIR - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.please use
HdfsSpout.setBadFilesDir(String)
- badSupervisorsToleranceSlidingWindow - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- BalancedTargetSelector() - Constructor for class org.apache.storm.grouping.PartialKeyGrouping.BalancedTargetSelector
- BASE_BLOBS_DIR_NAME - Static variable in class org.apache.storm.blobstore.BlobStore
- Base64ToBinaryStateMigrationUtil - Class in org.apache.storm.redis.tools
- Base64ToBinaryStateMigrationUtil(JedisPoolConfig) - Constructor for class org.apache.storm.redis.tools.Base64ToBinaryStateMigrationUtil
- Base64ToBinaryStateMigrationUtil(RedisCommandsInstanceContainer) - Constructor for class org.apache.storm.redis.tools.Base64ToBinaryStateMigrationUtil
- BaseAggregator<T> - Class in org.apache.storm.trident.operation
- BaseAggregator() - Constructor for class org.apache.storm.trident.operation.BaseAggregator
- BaseBasicBolt - Class in org.apache.storm.topology.base
- BaseBasicBolt() - Constructor for class org.apache.storm.topology.base.BaseBasicBolt
- BaseBatchBolt<T> - Class in org.apache.storm.topology.base
- BaseBatchBolt() - Constructor for class org.apache.storm.topology.base.BaseBatchBolt
- BaseBinaryStateIterator<K,
V> - Class in org.apache.storm.state -
Base implementation of iterator over
KeyValueState
which encoded types of key and value are both binary type. - BaseBinaryStateIterator(Iterator<Map.Entry<byte[], byte[]>>, Iterator<Map.Entry<byte[], byte[]>>) - Constructor for class org.apache.storm.state.BaseBinaryStateIterator
-
Constructor.
- BaseComponent - Class in org.apache.storm.topology.base
- BaseComponent() - Constructor for class org.apache.storm.topology.base.BaseComponent
- BaseConfigurationDeclarer<T extends ComponentConfigurationDeclarer> - Class in org.apache.storm.topology
- BaseConfigurationDeclarer() - Constructor for class org.apache.storm.topology.BaseConfigurationDeclarer
- BaseFilter - Class in org.apache.storm.trident.operation
- BaseFilter() - Constructor for class org.apache.storm.trident.operation.BaseFilter
- BaseFunction - Class in org.apache.storm.trident.operation
- BaseFunction() - Constructor for class org.apache.storm.trident.operation.BaseFunction
- BaseMultiReducer<T> - Class in org.apache.storm.trident.operation
- BaseMultiReducer() - Constructor for class org.apache.storm.trident.operation.BaseMultiReducer
- BaseOperation - Class in org.apache.storm.trident.operation
-
Convenience implementation of the
Operation
interface. - BaseOperation() - Constructor for class org.apache.storm.trident.operation.BaseOperation
- BaseQueryFunction<S extends State,
T> - Class in org.apache.storm.trident.state - BaseQueryFunction() - Constructor for class org.apache.storm.trident.state.BaseQueryFunction
- BaseResourceAwareStrategy - Class in org.apache.storm.scheduler.resource.strategies.scheduling
- BaseResourceAwareStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- BaseResourceAwareStrategy(boolean, BaseResourceAwareStrategy.NodeSortType) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
-
Initialize for the default implementation of schedule().
- BaseResourceAwareStrategy.NodeSortType - Enum Class in org.apache.storm.scheduler.resource.strategies.scheduling
-
Different node sorting types available.
- BaseRichBolt - Class in org.apache.storm.topology.base
- BaseRichBolt() - Constructor for class org.apache.storm.topology.base.BaseRichBolt
- BaseRichSpout - Class in org.apache.storm.topology.base
- BaseRichSpout() - Constructor for class org.apache.storm.topology.base.BaseRichSpout
- BaseStatefulBolt<T extends State> - Class in org.apache.storm.topology.base
- BaseStatefulBolt() - Constructor for class org.apache.storm.topology.base.BaseStatefulBolt
- BaseStatefulBoltExecutor - Class in org.apache.storm.topology
-
Base class that abstracts the common logic for executing bolts in a stateful topology.
- BaseStatefulBoltExecutor() - Constructor for class org.apache.storm.topology.BaseStatefulBoltExecutor
- BaseStatefulBoltExecutor.AnchoringOutputCollector - Class in org.apache.storm.topology
- BaseStatefulWindowedBolt<T extends State> - Class in org.apache.storm.topology.base
- BaseStatefulWindowedBolt() - Constructor for class org.apache.storm.topology.base.BaseStatefulWindowedBolt
- BaseStateIterator<K,
V, KENCODEDT, VENCODEDT> - Class in org.apache.storm.state -
Base implementation of iterator over
KeyValueState
. - BaseStateIterator(Iterator<Map.Entry<KENCODEDT, VENCODEDT>>, Iterator<Map.Entry<KENCODEDT, VENCODEDT>>, Set<KENCODEDT>) - Constructor for class org.apache.storm.state.BaseStateIterator
-
Constructor.
- BaseStateUpdater<S extends State> - Class in org.apache.storm.trident.state
- BaseStateUpdater() - Constructor for class org.apache.storm.trident.state.BaseStateUpdater
- BaseTaskHook - Class in org.apache.storm.hooks
- BaseTaskHook() - Constructor for class org.apache.storm.hooks.BaseTaskHook
- BaseTickTupleAwareRichBolt - Class in org.apache.storm.topology.base
-
This class is based on BaseRichBolt, but is aware of tick tuple.
- BaseTickTupleAwareRichBolt() - Constructor for class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
- baseType() - Element in annotation interface org.apache.storm.validation.ConfigValidationAnnotations.IsDerivedFrom
- BaseWindow<L,
I> - Class in org.apache.storm.streams.windowing - BaseWindow() - Constructor for class org.apache.storm.streams.windowing.BaseWindow
- BaseWindowConfig - Class in org.apache.storm.trident.windowing.config
- BaseWindowConfig(int, int) - Constructor for class org.apache.storm.trident.windowing.config.BaseWindowConfig
- BaseWindowedBolt - Class in org.apache.storm.topology.base
- BaseWindowedBolt() - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt
- BaseWindowedBolt.Count - Class in org.apache.storm.topology.base
-
Holds a count value for count based windows and sliding intervals.
- BaseWindowedBolt.Duration - Class in org.apache.storm.topology.base
-
Holds a Time duration for time based windows and sliding intervals.
- BaseWindowStrategy<T> - Class in org.apache.storm.trident.windowing.strategy
- BaseWindowStrategy(WindowConfig) - Constructor for class org.apache.storm.trident.windowing.strategy.BaseWindowStrategy
- BaseWorkerHook - Class in org.apache.storm.hooks
-
A BaseWorkerHook is a noop implementation of IWorkerHook.
- BaseWorkerHook() - Constructor for class org.apache.storm.hooks.BaseWorkerHook
- BasicBoltExecutor - Class in org.apache.storm.topology
- BasicBoltExecutor(IBasicBolt) - Constructor for class org.apache.storm.topology.BasicBoltExecutor
- BasicContainer - Class in org.apache.storm.daemon.supervisor
-
A container that runs processes on the local box.
- BasicContainer(Container.ContainerType, Map<String, Object>, String, int, int, LocalAssignment, ResourceIsolationInterface, LocalState, String, StormMetricsRegistry, ContainerMemoryTracker) - Constructor for class org.apache.storm.daemon.supervisor.BasicContainer
-
Create a new BasicContainer.
- BasicContainerLauncher - Class in org.apache.storm.daemon.supervisor
-
Launch containers with no security using standard java commands.
- BasicContainerLauncher(Map<String, Object>, String, int, ResourceIsolationInterface, StormMetricsRegistry, ContainerMemoryTracker) - Constructor for class org.apache.storm.daemon.supervisor.BasicContainerLauncher
- BasicDrpcClient - Class in org.apache.storm.command
-
A simple client for connecting to DRPC.
- BasicDrpcClient() - Constructor for class org.apache.storm.command.BasicDrpcClient
- BasicDRPCTopology - Class in org.apache.storm.starter
-
This topology is a basic example of doing distributed RPC on top of Storm.
- BasicDRPCTopology() - Constructor for class org.apache.storm.starter.BasicDRPCTopology
- BasicDRPCTopology.ExclaimBolt - Class in org.apache.storm.starter
- BasicLoadAwareCustomStreamGrouping(CustomStreamGrouping) - Constructor for class org.apache.storm.daemon.GrouperFactory.BasicLoadAwareCustomStreamGrouping
- BasicMetricsCollector - Class in org.apache.storm.perf.utils
- BasicMetricsCollector(String, Map<String, Object>) - Constructor for class org.apache.storm.perf.utils.BasicMetricsCollector
- BasicMetricsCollector.MetricsCollectorConfig - Class in org.apache.storm.perf.utils
- BasicMetricsCollector.MetricsItem - Enum Class in org.apache.storm.perf.utils
- BasicOutputCollector - Class in org.apache.storm.topology
- BasicOutputCollector(OutputCollector) - Constructor for class org.apache.storm.topology.BasicOutputCollector
- BATCH - Enum constant in enum class org.apache.storm.trident.planner.SpoutNode.SpoutType
- BATCH_STREAM_ID - Static variable in class org.apache.storm.trident.topology.MasterBatchCoordinator
- BatchBoltExecutor - Class in org.apache.storm.coordination
- BatchBoltExecutor(IBatchBolt) - Constructor for class org.apache.storm.coordination.BatchBoltExecutor
- batchGlobal() - Method in class org.apache.storm.trident.Stream
-
## Repartitioning Operation.
- batchGroup - Variable in class org.apache.storm.trident.topology.BatchInfo
- BatchHelper - Class in org.apache.storm.utils
- BatchHelper(int, OutputCollector) - Constructor for class org.apache.storm.utils.BatchHelper
- batchId - Variable in class org.apache.storm.trident.planner.ProcessorContext
- batchId - Variable in class org.apache.storm.trident.topology.BatchInfo
- BatchInfo - Class in org.apache.storm.trident.topology
- BatchInfo(String, IBatchID, Object) - Constructor for class org.apache.storm.trident.topology.BatchInfo
- BatchOutputCollector - Class in org.apache.storm.coordination
- BatchOutputCollector() - Constructor for class org.apache.storm.coordination.BatchOutputCollector
- BatchOutputCollectorImpl - Class in org.apache.storm.coordination
- BatchOutputCollectorImpl(OutputCollector) - Constructor for class org.apache.storm.coordination.BatchOutputCollectorImpl
- BatchProcessor - Interface in org.apache.storm.streams.processors
-
Top level marker interface for processors that computes results for a batch of tuples like Aggregate, Join etc.
- batchRetrieve(List<TridentTuple>) - Method in class org.apache.storm.jdbc.trident.state.JdbcState
- batchRetrieve(JdbcState, List<TridentTuple>) - Method in class org.apache.storm.jdbc.trident.state.JdbcQuery
- batchRetrieve(ReadOnlyMapState, List<TridentTuple>) - Method in class org.apache.storm.trident.operation.builtin.MapGet
- batchRetrieve(ReadOnlySnapshottable, List<TridentTuple>) - Method in class org.apache.storm.trident.operation.builtin.SnapshotGet
- batchRetrieve(State, List<TridentTuple>) - Method in class org.apache.storm.trident.operation.builtin.TupleCollectionGet
- batchRetrieve(S, List<TridentTuple>) - Method in interface org.apache.storm.trident.state.QueryFunction
- batchRetrieve(T, List<TridentTuple>) - Method in class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
- BatchSpoutEmitter() - Constructor for class org.apache.storm.trident.spout.BatchSpoutExecutor.BatchSpoutEmitter
- BatchSpoutExecutor - Class in org.apache.storm.trident.spout
- BatchSpoutExecutor(IBatchSpout) - Constructor for class org.apache.storm.trident.spout.BatchSpoutExecutor
- BatchSpoutExecutor.BatchSpoutEmitter - Class in org.apache.storm.trident.spout
- BatchSpoutExecutor.EmptyCoordinator - Class in org.apache.storm.trident.spout
- BatchSubtopologyBuilder - Class in org.apache.storm.coordination
- BatchSubtopologyBuilder(String, IBasicBolt) - Constructor for class org.apache.storm.coordination.BatchSubtopologyBuilder
- BatchSubtopologyBuilder(String, IBasicBolt, Number) - Constructor for class org.apache.storm.coordination.BatchSubtopologyBuilder
- BeanDef - Class in org.apache.storm.flux.model
-
A representation of a Java object that is uniquely identifyable, and given a className, constructor arguments, and properties, can be instantiated.
- BeanDef() - Constructor for class org.apache.storm.flux.model.BeanDef
- BeanListReference - Class in org.apache.storm.flux.model
-
A bean list reference is a list of bean reference.
- BeanListReference() - Constructor for class org.apache.storm.flux.model.BeanListReference
- BeanListReference(List<String>) - Constructor for class org.apache.storm.flux.model.BeanListReference
- BeanReference - Class in org.apache.storm.flux.model
-
A bean reference is simply a string pointer to another id.
- BeanReference() - Constructor for class org.apache.storm.flux.model.BeanReference
- BeanReference(String) - Constructor for class org.apache.storm.flux.model.BeanReference
- BEFORE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BEGIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BEGIN_FRAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BEGIN_PARTITION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- beginBlobDownload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginBlobDownload
- beginBlobDownload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginBlobDownload
- beginBlobDownload(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- beginBlobDownload(String) - Method in class org.apache.storm.generated.Nimbus.Client
- beginBlobDownload(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- beginBlobDownload(String) - Method in class org.apache.storm.LocalCluster
- beginBlobDownload(String, AsyncMethodCallback<BeginDownloadResult>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- beginBlobDownload(String, AsyncMethodCallback<BeginDownloadResult>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- beginBlobDownload_args() - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- beginBlobDownload_args(String) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- beginBlobDownload_args(Nimbus.beginBlobDownload_args) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_args
-
Performs a deep copy on other.
- beginBlobDownload_call(String, AsyncMethodCallback<BeginDownloadResult>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginBlobDownload_call
- beginBlobDownload_result() - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- beginBlobDownload_result(BeginDownloadResult, AuthorizationException, KeyNotFoundException) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- beginBlobDownload_result(Nimbus.beginBlobDownload_result) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_result
-
Performs a deep copy on other.
- beginColumn - Variable in class org.apache.storm.sql.parser.impl.Token
-
The column number of the first character of this Token.
- beginCommit(Long) - Method in class org.apache.storm.hdfs.trident.HdfsState
- beginCommit(Long) - Method in class org.apache.storm.jdbc.trident.state.JdbcState
- beginCommit(Long) - Method in class org.apache.storm.jms.trident.JmsState
- beginCommit(Long) - Method in class org.apache.storm.kafka.trident.TridentKafkaState
- beginCommit(Long) - Method in class org.apache.storm.redis.trident.state.RedisClusterState
- beginCommit(Long) - Method in class org.apache.storm.redis.trident.state.RedisState
- beginCommit(Long) - Method in class org.apache.storm.trident.state.map.NonTransactionalMap
- beginCommit(Long) - Method in class org.apache.storm.trident.state.map.OpaqueMap
- beginCommit(Long) - Method in class org.apache.storm.trident.state.map.SnapshottableMap
- beginCommit(Long) - Method in class org.apache.storm.trident.state.map.TransactionalMap
- beginCommit(Long) - Method in class org.apache.storm.trident.state.ReadOnlyState
- beginCommit(Long) - Method in interface org.apache.storm.trident.state.State
- beginCommit(Long) - Method in class org.apache.storm.trident.testing.LRUMemoryMapState
- beginCommit(Long) - Method in class org.apache.storm.trident.testing.MemoryMapState
- beginCommit(Long) - Method in class org.apache.storm.trident.windowing.WindowsState
- beginCreateBlob() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginCreateBlob
- beginCreateBlob() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginCreateBlob
- beginCreateBlob(String, SettableBlobMeta) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- beginCreateBlob(String, SettableBlobMeta) - Method in class org.apache.storm.generated.Nimbus.Client
- beginCreateBlob(String, SettableBlobMeta) - Method in interface org.apache.storm.generated.Nimbus.Iface
- beginCreateBlob(String, SettableBlobMeta) - Method in class org.apache.storm.LocalCluster
- beginCreateBlob(String, SettableBlobMeta, AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- beginCreateBlob(String, SettableBlobMeta, AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- beginCreateBlob_args() - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- beginCreateBlob_args(String, SettableBlobMeta) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- beginCreateBlob_args(Nimbus.beginCreateBlob_args) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_args
-
Performs a deep copy on other.
- beginCreateBlob_call(String, SettableBlobMeta, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginCreateBlob_call
- beginCreateBlob_result() - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- beginCreateBlob_result(String, AuthorizationException, KeyAlreadyExistsException) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- beginCreateBlob_result(Nimbus.beginCreateBlob_result) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_result
-
Performs a deep copy on other.
- BeginDownloadResult - Class in org.apache.storm.generated
- BeginDownloadResult() - Constructor for class org.apache.storm.generated.BeginDownloadResult
- BeginDownloadResult(long, String) - Constructor for class org.apache.storm.generated.BeginDownloadResult
- BeginDownloadResult(BeginDownloadResult) - Constructor for class org.apache.storm.generated.BeginDownloadResult
-
Performs a deep copy on other.
- BeginDownloadResult._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- beginFileUpload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginFileUpload
- beginFileUpload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginFileUpload
- beginFileUpload() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- beginFileUpload() - Method in class org.apache.storm.generated.Nimbus.Client
- beginFileUpload() - Method in interface org.apache.storm.generated.Nimbus.Iface
- beginFileUpload() - Method in class org.apache.storm.LocalCluster
- beginFileUpload(AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- beginFileUpload(AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- beginFileUpload_args() - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_args
- beginFileUpload_args(Nimbus.beginFileUpload_args) - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_args
-
Performs a deep copy on other.
- beginFileUpload_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginFileUpload_call
- beginFileUpload_result() - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_result
- beginFileUpload_result(String, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_result
- beginFileUpload_result(Nimbus.beginFileUpload_result) - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_result
-
Performs a deep copy on other.
- beginLine - Variable in class org.apache.storm.sql.parser.impl.Token
-
The line number of the first character of this Token.
- BeginToken() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Start.
- beginUpdateBlob() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginUpdateBlob
- beginUpdateBlob() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginUpdateBlob
- beginUpdateBlob(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- beginUpdateBlob(String) - Method in class org.apache.storm.generated.Nimbus.Client
- beginUpdateBlob(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- beginUpdateBlob(String) - Method in class org.apache.storm.LocalCluster
- beginUpdateBlob(String, AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- beginUpdateBlob(String, AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- beginUpdateBlob_args() - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- beginUpdateBlob_args(String) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- beginUpdateBlob_args(Nimbus.beginUpdateBlob_args) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
-
Performs a deep copy on other.
- beginUpdateBlob_call(String, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginUpdateBlob_call
- beginUpdateBlob_result() - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- beginUpdateBlob_result(String, AuthorizationException, KeyNotFoundException) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- beginUpdateBlob_result(Nimbus.beginUpdateBlob_result) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
-
Performs a deep copy on other.
- BEL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BERNOULLI - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BETWEEN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BiFunction<T,
U, R> - Interface in org.apache.storm.streams.operations -
a function that accepts two arguments and produces a result.
- BIGINT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BINARY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- binary_arg(byte[]) - Static method in class org.apache.storm.generated.JavaObjectArg
- binary_arg(ByteBuffer) - Static method in class org.apache.storm.generated.JavaObjectArg
- BINARY_ARG - Enum constant in enum class org.apache.storm.generated.JavaObjectArg._Fields
- BINARY_STRING_LITERAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BinaryMultisetOperator() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a binary multiset operator.
- BinaryQueryOperator() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a binary query operator like UNION.
- BinaryRowOperator() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a binary row operator like AND.
- bind(String, int, IConnectionCallback, Supplier<Object>) - Method in interface org.apache.storm.messaging.IContext
-
This method establishes a server side connection.
- bind(String, int, IConnectionCallback, Supplier<Object>) - Method in class org.apache.storm.messaging.local.Context
- bind(String, int, IConnectionCallback, Supplier<Object>) - Method in class org.apache.storm.messaging.netty.Context
-
establish a server with a binding port.
- BIT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BITS - Enum constant in enum class org.apache.storm.generated.ThriftSerializedObject._Fields
- bitXor(Long, Long) - Static method in class org.apache.storm.utils.Utils
- bitXorVals(List<Long>) - Static method in class org.apache.storm.utils.Utils
- BLACKLIST_SCHEDULER_ASSUME_SUPERVISOR_BAD_BASED_ON_BAD_SLOT - Static variable in class org.apache.storm.DaemonConfig
-
Whether
BlacklistScheduler
will assume the supervisor is bad based on bad slots or not. - BLACKLIST_SCHEDULER_ENABLE_SEND_ASSIGNMENT_FAILURES - Static variable in class org.apache.storm.DaemonConfig
-
Enables blacklisting support for supervisors with failed send assignment calls.
- BLACKLIST_SCHEDULER_REPORTER - Static variable in class org.apache.storm.DaemonConfig
-
The class that the blacklist scheduler will report the blacklist.
- BLACKLIST_SCHEDULER_RESUME_TIME - Static variable in class org.apache.storm.DaemonConfig
-
The number of seconds that the blacklisted slots or supervisor will be resumed.
- BLACKLIST_SCHEDULER_STRATEGY - Static variable in class org.apache.storm.DaemonConfig
-
The class that specifies the eviction strategy to use in blacklist scheduler.
- BLACKLIST_SCHEDULER_TOLERANCE_COUNT - Static variable in class org.apache.storm.DaemonConfig
-
The number of hit count that will trigger blacklist in tolerance time.
- BLACKLIST_SCHEDULER_TOLERANCE_TIME - Static variable in class org.apache.storm.DaemonConfig
-
The number of seconds that the blacklist scheduler will concern of bad slots or supervisors.
- BLACKLISTED - Enum constant in enum class org.apache.storm.generated.SupervisorSummary._Fields
- blacklistedSupervisorIds - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- blacklistHost(String) - Method in class org.apache.storm.scheduler.Cluster
- BlacklistScheduler - Class in org.apache.storm.scheduler.blacklist
- BlacklistScheduler(IScheduler) - Constructor for class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- blacklistStrategy - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- blkio - Enum constant in enum class org.apache.storm.container.cgroup.SubSystemType
- BLKIO_IO_MERGED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_IO_QUEUED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_IO_SERVICE_BYTES - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_IO_SERVICE_TIME - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_IO_SERVICED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_IO_WAIT_TIME - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_RESET_STATS - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_SECTORS - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_THROTTLE_IO_SERVICE_BYTES - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_THROTTLE_IO_SERVICED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_THROTTLE_READ_BPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_THROTTLE_READ_IOPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_THROTTLE_WRITE_BPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_THROTTLE_WRITE_IOPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_TIME - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_WEIGHT - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BLKIO_WEIGHT_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
- BlkioCore - Class in org.apache.storm.container.cgroup.core
- BlkioCore(String) - Constructor for class org.apache.storm.container.cgroup.core.BlkioCore
- BlkioCore.RecordType - Enum Class in org.apache.storm.container.cgroup.core
- BLOB - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BLOB_KEY - Enum constant in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args._Fields
- BLOB_KEY_PATTERN - Static variable in class org.apache.storm.utils.Utils
- blobChanging(LocalAssignment, int, LocallyCachedBlob, GoodToGo) - Method in class org.apache.storm.daemon.supervisor.Slot
- blobChanging(LocalAssignment, int, LocallyCachedBlob, GoodToGo) - Method in interface org.apache.storm.localizer.BlobChangingCallback
-
Informs the listener that a blob has changed and is ready to update and replace a localized blob that has been marked as tied to the life cycle of the worker process.
- BlobChangingCallback - Interface in org.apache.storm.localizer
-
Callback for when a localized blob is going to change.
- blobExists(String, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
-
Checks if a blob exists.
- BlobKeySequenceInfo - Class in org.apache.storm.blobstore
- BlobKeySequenceInfo() - Constructor for class org.apache.storm.blobstore.BlobKeySequenceInfo
- blobNeedsWorkerRestart(Map<String, Object>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
-
Given the blob information returns the value of the workerRestart field, handling it being a boolean value, or if it's not specified then returns false.
- blobstore(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
- blobstore(Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- Blobstore - Class in org.apache.storm.command
- Blobstore() - Constructor for class org.apache.storm.command.Blobstore
- BlobStore - Class in org.apache.storm.blobstore
-
Provides a way to store blobs that can be downloaded.
- BlobStore() - Constructor for class org.apache.storm.blobstore.BlobStore
- BLOBSTORE_CLEANUP_ENABLE - Static variable in class org.apache.storm.Config
-
Enable the blobstore cleaner.
- BLOBSTORE_DATA_FILE - Static variable in class org.apache.storm.blobstore.BlobStoreFile
- BLOBSTORE_DIR - Static variable in class org.apache.storm.Config
-
What directory to use for the blobstore.
- BLOBSTORE_DIR_PERMISSION - Static variable in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- BLOBSTORE_FILE_PERMISSION - Static variable in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- BLOBSTORE_HDFS_KEYTAB - Static variable in class org.apache.storm.Config
-
Deprecated.
- BLOBSTORE_HDFS_PRINCIPAL - Static variable in class org.apache.storm.Config
-
Deprecated, for removal: This API element is subject to removal in a future version.
- BLOBSTORE_MAX_KEY_SEQUENCE_NUMBER_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
- BLOBSTORE_MAX_KEY_SEQUENCE_NUMBER_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
- BLOBSTORE_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
- BLOBSTORE_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
- BlobStore.BlobStoreFileInputStream - Class in org.apache.storm.blobstore
-
Input stream implementation used for writing both the metadata containing the acl information and the blob data.
- BlobStore.BlobStoreFileOutputStream - Class in org.apache.storm.blobstore
-
Output stream implementation used for reading the metadata and data information.
- BlobStore.KeyTranslationIterator - Class in org.apache.storm.blobstore
-
Blob store implements its own version of iterator to list the blobs.
- BlobStoreAclHandler - Class in org.apache.storm.blobstore
-
Provides common handling of acls for Blobstores.
- BlobStoreAclHandler(Map<String, Object>) - Constructor for class org.apache.storm.blobstore.BlobStoreAclHandler
- BlobStoreAPIWordCountTopology - Class in org.apache.storm.starter
- BlobStoreAPIWordCountTopology() - Constructor for class org.apache.storm.starter.BlobStoreAPIWordCountTopology
- BlobStoreAPIWordCountTopology.FilterWords - Class in org.apache.storm.starter
- BlobStoreAPIWordCountTopology.RandomSentenceSpout - Class in org.apache.storm.starter
- BlobStoreAPIWordCountTopology.SplitSentence - Class in org.apache.storm.starter
- BlobStoreFile - Class in org.apache.storm.blobstore
-
Provides an base implementation for creating a blobstore based on file backed storage.
- BlobStoreFile() - Constructor for class org.apache.storm.blobstore.BlobStoreFile
- BlobStoreFileInputStream(BlobStoreFile) - Constructor for class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
- BlobStoreFileOutputStream(BlobStoreFile) - Constructor for class org.apache.storm.blobstore.BlobStore.BlobStoreFileOutputStream
- blobstoreInfo(String) - Method in interface org.apache.storm.cluster.IStormClusterState
- blobstoreInfo(String) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- blobstoreMapToLocalresources(Map<String, Map<String, Object>>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
-
Returns a list of LocalResources based on the blobstore-map passed in.
- blobstoreMaxKeySequenceNumberPath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
- blobstorePath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
- BlobStoreUtils - Class in org.apache.storm.blobstore
- BlobStoreUtils() - Constructor for class org.apache.storm.blobstore.BlobStoreUtils
- BlockingOutstandingRequest - Class in org.apache.storm.daemon.drpc
- BlockingOutstandingRequest(String, DRPCRequest) - Constructor for class org.apache.storm.daemon.drpc.BlockingOutstandingRequest
- BlowfishTupleSerializer - Class in org.apache.storm.security.serialization
-
Apply Blowfish encryption for tuple communication to bolts.
- BlowfishTupleSerializer(Kryo, Map<String, Object>) - Constructor for class org.apache.storm.security.serialization.BlowfishTupleSerializer
- bolt(BoltAggregateStats) - Static method in class org.apache.storm.generated.SpecificAggregateStats
- bolt(BoltStats) - Static method in class org.apache.storm.generated.ExecutorSpecificStats
- Bolt - Class in org.apache.storm.generated
- Bolt() - Constructor for class org.apache.storm.generated.Bolt
- Bolt(Bolt) - Constructor for class org.apache.storm.generated.Bolt
-
Performs a deep copy on other.
- Bolt(ComponentObject, ComponentCommon) - Constructor for class org.apache.storm.generated.Bolt
- BOLT - Enum constant in enum class org.apache.storm.generated.ComponentType
- BOLT - Enum constant in enum class org.apache.storm.generated.ExecutorSpecificStats._Fields
- BOLT - Enum constant in enum class org.apache.storm.generated.SpecificAggregateStats._Fields
- BOLT - Static variable in class org.apache.storm.stats.ClientStatsUtil
- BOLT_COUNT - Static variable in class org.apache.storm.perf.ConstSpoutNullBoltTopo
- BOLT_ID - Static variable in class org.apache.storm.hdfs.spout.HdfsSpoutTopology
- BOLT_ID - Static variable in class org.apache.storm.perf.ConstSpoutNullBoltTopo
- BOLT_ID - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- BOLT_ID - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
- BOLT_ID - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- BOLT_KEY - Static variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- BOLT_MESSAGE - Static variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- BOLT_NUM - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- BOLT_NUM - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
- BOLT_NUM - Static variable in class org.apache.storm.perf.SimplifiedWordCountTopo
- BOLT_NUM - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- BOLT_OBJECT - Enum constant in enum class org.apache.storm.generated.Bolt._Fields
- BOLT_WAIT - Enum constant in enum class org.apache.storm.policy.IWaitStrategy.WaitSituation
- Bolt._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- BOLT1_COUNT - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
- BOLT1_ID - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
- BOLT2_COUNT - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
- BOLT2_ID - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
- boltAck(BoltAckInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
- boltAck(BoltAckInfo) - Method in interface org.apache.storm.hooks.ITaskHook
- boltAckedTuple(String, String, long) - Method in class org.apache.storm.metrics2.TaskMetrics
- boltAckedTuple(String, String, long) - Method in class org.apache.storm.stats.BoltExecutorStats
- BoltAckInfo - Class in org.apache.storm.hooks.info
- BoltAckInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltAckInfo
- BoltAggregateStats - Class in org.apache.storm.generated
- BoltAggregateStats() - Constructor for class org.apache.storm.generated.BoltAggregateStats
- BoltAggregateStats(BoltAggregateStats) - Constructor for class org.apache.storm.generated.BoltAggregateStats
-
Performs a deep copy on other.
- BoltAggregateStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- BoltDeclarer - Interface in org.apache.storm.topology
-
BoltDeclarer includes grouping APIs for storm topology.
- BoltDef - Class in org.apache.storm.flux.model
-
Bean representation of a Storm bolt.
- BoltDef() - Constructor for class org.apache.storm.flux.model.BoltDef
- BoltDetails(Object, Map<String, Object>, Integer, Map<GlobalStreamId, Grouping>) - Constructor for class org.apache.storm.Thrift.BoltDetails
- boltExecute(Supplier<Iterator<Tuple>>, Supplier<Iterator<Tuple>>, Supplier<Iterator<Tuple>>, Long) - Method in class org.apache.storm.topology.WindowedBoltExecutor
- boltExecute(List<Tuple>, List<Tuple>, List<Tuple>, Long) - Method in class org.apache.storm.topology.WindowedBoltExecutor
- boltExecute(BoltExecuteInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
- boltExecute(BoltExecuteInfo) - Method in interface org.apache.storm.hooks.ITaskHook
- BoltExecuteInfo - Class in org.apache.storm.hooks.info
- BoltExecuteInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltExecuteInfo
- boltExecuteTuple(String, String, long) - Method in class org.apache.storm.metrics2.TaskMetrics
- boltExecuteTuple(String, String, long, long, Task) - Method in class org.apache.storm.stats.BoltExecutorStats
- BoltExecutor - Class in org.apache.storm.executor.bolt
- BoltExecutor(WorkerState, List<Long>, Map<String, String>) - Constructor for class org.apache.storm.executor.bolt.BoltExecutor
- BoltExecutorStats - Class in org.apache.storm.stats
- BoltExecutorStats(int, int) - Constructor for class org.apache.storm.stats.BoltExecutorStats
- boltFail(BoltFailInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
- boltFail(BoltFailInfo) - Method in interface org.apache.storm.hooks.ITaskHook
- boltFailedTuple(String, String) - Method in class org.apache.storm.metrics2.TaskMetrics
- boltFailedTuple(String, String) - Method in class org.apache.storm.stats.BoltExecutorStats
- BoltFailInfo - Class in org.apache.storm.hooks.info
- BoltFailInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltFailInfo
- BoltGetter(String) - Constructor for class org.apache.storm.topology.TopologyBuilder.BoltGetter
- boltKeyField - Variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- boltMessageField - Variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- BoltMsg - Class in org.apache.storm.multilang
-
BoltMsg is an object that represents the data sent from a shell component to a bolt process that implements a multi-language protocol.
- BoltMsg() - Constructor for class org.apache.storm.multilang.BoltMsg
- BoltOutputCollectorImpl - Class in org.apache.storm.executor.bolt
- BoltOutputCollectorImpl(BoltExecutor, Task, Random, boolean, boolean, boolean) - Constructor for class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
- bolts - Variable in class org.apache.storm.loadgen.TopologyLoadConf
- BOLTS - Enum constant in enum class org.apache.storm.generated.StormTopology._Fields
- BoltStats - Class in org.apache.storm.generated
- BoltStats() - Constructor for class org.apache.storm.generated.BoltStats
- BoltStats(Map<String, Map<GlobalStreamId, Long>>, Map<String, Map<GlobalStreamId, Long>>, Map<String, Map<GlobalStreamId, Double>>, Map<String, Map<GlobalStreamId, Long>>, Map<String, Map<GlobalStreamId, Double>>) - Constructor for class org.apache.storm.generated.BoltStats
- BoltStats(BoltStats) - Constructor for class org.apache.storm.generated.BoltStats
-
Performs a deep copy on other.
- BoltStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- boltStreamsStats(List<ExecutorSummary>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
-
aggregates bolt stream stats, returns a Map of {metric -> win -> aggregated value}.
- BoltTracker - Class in org.apache.storm.testing
- BoltTracker(IRichBolt, String) - Constructor for class org.apache.storm.testing.BoltTracker
- bool_arg(boolean) - Static method in class org.apache.storm.generated.JavaObjectArg
- BOOL_ARG - Enum constant in enum class org.apache.storm.generated.JavaObjectArg._Fields
- BOOLEAN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BooleanValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.BooleanValidator
- boolOpt(String, String) - Static method in class org.apache.storm.command.CLI
-
Add a boolean option that enables something.
- boolOpt(String, String) - Method in class org.apache.storm.command.CLI.CLIBuilder
-
Add a boolean option that enables something.
- boolval(boolean) - Static method in class org.apache.storm.generated.HBMessageData
- BOOLVAL - Enum constant in enum class org.apache.storm.generated.HBMessageData._Fields
- Booter - Class in org.apache.storm.submit.dependency
-
Manage mvn repository.
- Booter() - Constructor for class org.apache.storm.submit.dependency.Booter
- BOOTSTRAP_SERVERS - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
- BOTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- bpTasks - Variable in class org.apache.storm.messaging.netty.BackPressureStatus
- BRACKET_QUOTED_IDENTIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- branch(Predicate<? super Pair<K, V>>...) - Method in class org.apache.storm.streams.PairStream
-
Returns an array of streams by splitting the given stream into multiple branches based on the given predicates.
- branch(Predicate<? super T>...) - Method in class org.apache.storm.streams.Stream
-
Returns an array of streams by splitting the given stream into multiple branches based on the given predicates.
- BranchExample - Class in org.apache.storm.starter.streams
-
An example that demonstrates the usage of
Stream.branch(Predicate[])
to split a stream into multiple branches based on predicates. - BranchExample() - Constructor for class org.apache.storm.starter.streams.BranchExample
- BranchProcessor<T> - Class in org.apache.storm.streams.processors
- BranchProcessor() - Constructor for class org.apache.storm.streams.processors.BranchProcessor
- BREADTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- BridgeReceiver - Class in org.apache.storm.trident.planner
- BridgeReceiver(BatchOutputCollector) - Constructor for class org.apache.storm.trident.planner.BridgeReceiver
- broadcast() - Method in class org.apache.storm.trident.Stream
-
## Repartitioning Operation.
- BROADCAST_DEST - Static variable in class org.apache.storm.tuple.AddressedTuple
-
Destination used when broadcasting a tuple.
- BTID - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
Lexical state.
- bufcolumn - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
- buffer - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
- buffer(ByteBufAllocator, KryoValuesSerializer) - Method in class org.apache.storm.messaging.netty.BackPressureStatus
-
Encoded as -600 ...
- buffer_for_binary_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- buffer_for_bits() - Method in class org.apache.storm.generated.ThriftSerializedObject
- buffer_for_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- buffer_for_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- buffer_for_custom_serialized() - Method in class org.apache.storm.generated.Grouping
- buffer_for_details() - Method in class org.apache.storm.generated.HBPulse
- buffer_for_info() - Method in class org.apache.storm.generated.WorkerToken
- buffer_for_key() - Method in class org.apache.storm.generated.PrivateWorkerKey
- buffer_for_message_blob() - Method in class org.apache.storm.generated.HBMessageData
- buffer_for_serialized_java() - Method in class org.apache.storm.generated.ComponentObject
- buffer_for_signature() - Method in class org.apache.storm.generated.WorkerToken
- buffer_for_success() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- buffer_for_success() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- BUFFER_SIZE - Static variable in class org.apache.storm.hdfs.spout.SequenceFileReader
- BUFFER_SIZE - Static variable in class org.apache.storm.hdfs.spout.TextFileReader
- BufferFileInputStream - Class in org.apache.storm.utils
- BufferFileInputStream(String) - Constructor for class org.apache.storm.utils.BufferFileInputStream
- BufferFileInputStream(String, int) - Constructor for class org.apache.storm.utils.BufferFileInputStream
- BufferInputStream - Class in org.apache.storm.utils
- BufferInputStream(InputStream) - Constructor for class org.apache.storm.utils.BufferInputStream
- BufferInputStream(InputStream, int) - Constructor for class org.apache.storm.utils.BufferInputStream
- bufline - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
- bufpos - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Position in buffer.
- build() - Method in class org.apache.storm.daemon.common.JsonResponseBuilder
-
Build a Response based on given parameters.
- build() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
- build() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
- build() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
- build() - Method in class org.apache.storm.loadgen.InputStream.Builder
- build() - Method in class org.apache.storm.loadgen.LoadCompConf.Builder
- build() - Method in class org.apache.storm.loadgen.OutputStream.Builder
- build() - Method in class org.apache.storm.LocalCluster.Builder
-
Builds a new LocalCluster.
- build() - Method in class org.apache.storm.redis.common.config.JedisClusterConfig.Builder
-
Builds JedisClusterConfig.
- build() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig.Builder
-
Builds JedisPoolConfig.
- build() - Method in class org.apache.storm.sql.AbstractStreamsProcessor
-
Construct the Storm topology based on the SQL.
- build() - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
- build() - Method in class org.apache.storm.streams.StreamBuilder
-
Builds a new
StormTopology
for the computation expressed via the stream api. - build() - Method in class org.apache.storm.trident.TridentTopology
- build() - Method in class org.apache.storm.utils.NimbusClient.Builder
- build() - Method in class org.apache.storm.utils.SupervisorClient.Builder
- build(String, Map<String, Object>) - Static method in class org.apache.storm.daemon.utils.UrlBuilder
-
Build the URL.
- build(List<Object>) - Method in interface org.apache.storm.redis.trident.state.KeyFactory
-
Converts state key to Redis key.
- build(List<Object>) - Method in class org.apache.storm.redis.trident.state.KeyFactory.DefaultKeyFactory
-
Converts state key to Redis key.
- build(JedisClusterConfig) - Static method in class org.apache.storm.redis.common.container.JedisCommandsContainerBuilder
-
Builds container for Redis Cluster environment.
- build(JedisClusterConfig) - Static method in class org.apache.storm.redis.common.container.RedisCommandsContainerBuilder
-
Builds container for Redis Cluster environment.
- build(JedisPoolConfig) - Static method in class org.apache.storm.redis.common.container.JedisCommandsContainerBuilder
-
Builds container for single Redis environment.
- build(JedisPoolConfig) - Static method in class org.apache.storm.redis.common.container.RedisCommandsContainerBuilder
-
Builds container for single Redis environment.
- build(IBackingMap<OpaqueValue>) - Static method in class org.apache.storm.trident.state.map.OpaqueMap
- build(IBackingMap<TransactionalValue>) - Static method in class org.apache.storm.trident.state.map.TransactionalMap
- build(IBackingMap<T>) - Static method in class org.apache.storm.trident.state.map.NonTransactionalMap
- build(WindowPartitionCache.CacheLoader<K, V>) - Method in class org.apache.storm.windowing.persistence.SimpleWindowPartitionCache.SimpleWindowPartitionCacheBuilder
- build(WindowPartitionCache.CacheLoader<K, V>) - Method in interface org.apache.storm.windowing.persistence.WindowPartitionCache.Builder
-
Build the cache.
- buildAndLaunchWordCountTopology(String[]) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology
- buildConfig(TopologyDef) - Static method in class org.apache.storm.flux.FluxBuilder
-
Given a topology definition, return a populated `org.apache.storm.Config` instance.
- buildDevicesTopology() - Static method in class org.apache.storm.starter.trident.TridentMinMaxOfDevicesTopology
-
Creates a topology with device-id and count (which are whole numbers) as tuple fields in a stream and it finally generates result stream based on min amd max with device-id and count values.
- buildDownloadFile(String, File, Meter) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing download a file.
- builder(String, String...) - Static method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
-
Factory method that creates a Builder with String key/value deserializers.
- builder(String, String...) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig
-
Factory method that creates a Builder with String key/value deserializers.
- builder(String, Pattern) - Static method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
-
Factory method that creates a Builder with String key/value deserializers.
- builder(String, Pattern) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig
-
Factory method that creates a Builder with String key/value deserializers.
- builder(String, Set<String>) - Static method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
-
Factory method that creates a Builder with String key/value deserializers.
- builder(String, Set<String>) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig
-
Factory method that creates a Builder with String key/value deserializers.
- Builder() - Constructor for class org.apache.storm.loadgen.InputStream.Builder
- Builder() - Constructor for class org.apache.storm.loadgen.LoadCompConf.Builder
- Builder() - Constructor for class org.apache.storm.loadgen.OutputStream.Builder
- Builder() - Constructor for class org.apache.storm.LocalCluster.Builder
- Builder() - Constructor for class org.apache.storm.redis.common.config.JedisClusterConfig.Builder
- Builder() - Constructor for class org.apache.storm.redis.common.config.JedisPoolConfig.Builder
- Builder(String, String...) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
- Builder(String, String...) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
- Builder(String, String...) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
- Builder(String, Pattern) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
- Builder(String, Pattern) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
- Builder(String, Pattern) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
- Builder(String, Set<String>) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
- Builder(String, Set<String>) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
- Builder(String, Set<String>) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
- Builder(String, TopicFilter, ManualPartitioner) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
-
Create a KafkaSpoutConfig builder with default property values and no key/value deserializers.
- Builder(String, TopicFilter, ManualPartitioner) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
-
Create a KafkaSpoutConfig builder with default property values and no key/value deserializers.
- Builder(String, TopicFilter, ManualPartitioner) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
- buildExceptionJsonResponse(Exception, String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing exception, with JSON response.
- buildFieldIndex(ValuePointer[]) - Static method in class org.apache.storm.trident.tuple.ValuePointer
- buildFrameWorkConfig() - Method in class org.apache.storm.sql.StormSqlContext
- buildIndex(Fields, Map<String, ValuePointer>) - Static method in class org.apache.storm.trident.tuple.ValuePointer
- buildLogMessage(IEventLogger.EventInfo) - Method in class org.apache.storm.metric.FileBasedEventLogger
- buildResponsePageNotFound() - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing page not found.
- buildResponseUnauthorizedUser(String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing unauthorized user, with HTML response.
- buildSuccessHtmlResponse(String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing success response with HTML entity.
- buildSuccessJsonResponse(Object, String, String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing success response with JSON entity.
- buildTopology() - Static method in class org.apache.storm.starter.trident.TridentMapExample
- buildTopology() - Static method in class org.apache.storm.starter.trident.TridentReach
- buildTopology() - Static method in class org.apache.storm.starter.trident.TridentWordCount
- buildTopology(String) - Static method in class org.apache.storm.hdfs.trident.TridentFileTopology
- buildTopology(String) - Static method in class org.apache.storm.hdfs.trident.TridentSequenceTopology
- buildTopology(String) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedisCluster
- buildTopology(String) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedisClusterMap
- buildTopology(String, Integer) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedis
- buildTopology(String, Integer) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedisMap
- buildTopology(HashMap<String, Thrift.SpoutDetails>, HashMap<String, Thrift.BoltDetails>, HashMap<String, StateSpoutSpec>) - Static method in class org.apache.storm.Thrift
- buildTopology(Map<String, Number>) - Method in class org.apache.storm.trident.topology.TridentTopologyBuilder
- buildTopology(Map<String, Thrift.SpoutDetails>, Map<String, Thrift.BoltDetails>) - Static method in class org.apache.storm.Thrift
- buildTopology(ExecutionContext) - Static method in class org.apache.storm.flux.FluxBuilder
-
Given a topology definition, return a Storm topology that can be run either locally or remotely.
- buildTopology(WindowsStoreFactory, WindowConfig) - Static method in class org.apache.storm.starter.trident.TridentWindowingInmemoryStoreTopology
- buildUnauthorizedUserJsonResponse(String, String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
-
Build a Response object representing unauthorized user, with JSON response.
- buildVehiclesTopology() - Static method in class org.apache.storm.starter.trident.TridentMinMaxOfDevicesTopology
-
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with values
TridentMinMaxOfDevicesTopology.Vehicle
andTridentMinMaxOfDevicesTopology.Driver
respectively. - buildVehiclesTopology() - Static method in class org.apache.storm.starter.trident.TridentMinMaxOfVehiclesTopology
-
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with values
TridentMinMaxOfVehiclesTopology.Vehicle
andTridentMinMaxOfVehiclesTopology.Driver
respectively. - buildWithNimbusHostPort(String, Integer) - Method in class org.apache.storm.utils.NimbusClient.Builder
- BuiltinFunctionCall() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a call to a builtin function with special syntax.
- BuiltinMetricsUtil - Class in org.apache.storm.daemon.metrics
- BuiltinMetricsUtil() - Constructor for class org.apache.storm.daemon.metrics.BuiltinMetricsUtil
- BY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ByTopicRecordTranslator<K,
V> - Class in org.apache.storm.kafka.spout -
Based off of a given Kafka topic a ConsumerRecord came from it will be translated to a Storm tuple and emitted to a given stream.
- ByTopicRecordTranslator(Func<ConsumerRecord<K, V>, List<Object>>, Fields) - Constructor for class org.apache.storm.kafka.spout.ByTopicRecordTranslator
-
Create a simple record translator that will use func to extract the fields of the tuple, named by fields, and emit them to the default stream.
- ByTopicRecordTranslator(Func<ConsumerRecord<K, V>, List<Object>>, Fields, String) - Constructor for class org.apache.storm.kafka.spout.ByTopicRecordTranslator
-
Create a simple record translator that will use func to extract the fields of the tuple, named by fields, and emit them to stream.
- ByTopicRecordTranslator(RecordTranslator<K, V>) - Constructor for class org.apache.storm.kafka.spout.ByTopicRecordTranslator
-
Create a record translator with the given default translator.
C
- C - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- cached - Variable in class org.apache.storm.trident.state.map.CachedBatchReadsMap.RetVal
- CachedBatchReadsMap<T> - Class in org.apache.storm.trident.state.map
- CachedBatchReadsMap(IBackingMap<T>) - Constructor for class org.apache.storm.trident.state.map.CachedBatchReadsMap
- CachedBatchReadsMap.RetVal<T> - Class in org.apache.storm.trident.state.map
- cachedGroups - Variable in class org.apache.storm.security.auth.FixedGroupsMapping
- cachedGroups - Variable in class org.apache.storm.security.auth.ShellBasedGroupsMapping
- CachedMap<T> - Class in org.apache.storm.trident.state.map
-
Useful to layer over a map that communicates with a database.
- CachedMap(IBackingMap<T>, int) - Constructor for class org.apache.storm.trident.state.map.CachedMap
- CachedSchemas - Class in org.apache.storm.sql.runtime.serde.avro
- CachedSchemas() - Constructor for class org.apache.storm.sql.runtime.serde.avro.CachedSchemas
- cachedSupervisors - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- cacheSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- cacheTargetSize - Variable in class org.apache.storm.localizer.AsyncLocalizer
- calculateAveragePercentageUsedBy(NormalizedResourceOffer) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
-
Calculate the average percentage used.
- calculateAveragePercentageUsedBy(NormalizedResources, double, double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Calculate the average resource usage percentage with this being the total resources and used being the amounts used.
- calculateMinPercentageUsedBy(NormalizedResourceOffer) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
-
Calculate the min percentage used of the resource.
- calculateMinPercentageUsedBy(NormalizedResources, double, double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Calculate the minimum resource usage percentage with this being the total resources and used being the amounts used.
- call() - Method in class org.apache.storm.clojure.ClojureTuple
- call() - Method in class org.apache.storm.executor.bolt.BoltExecutor
- call() - Method in class org.apache.storm.executor.spout.SpoutExecutor
- call(int) - Method in interface org.apache.storm.daemon.supervisor.ExitCodeCallback
-
The process finished.
- call(T) - Method in interface org.apache.storm.daemon.supervisor.UniFunc
- CALL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- callbackHandler - Variable in class org.apache.storm.messaging.netty.Login
- callbackParameterName - Static variable in class org.apache.storm.daemon.ui.resources.StormApiResource
- CALLED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.DefaultPool
- canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.FreePool
- canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.IsolatedPool
- canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.NodePool
-
Check if this topology can be added to this pool.
- cancel() - Method in class org.apache.storm.blobstore.AtomicOutputStream
-
Cancel all of the writes associated with this stream and close it.
- cancel() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileOutputStream
- cancel() - Method in class org.apache.storm.blobstore.BlobStoreFile
- cancel() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- cancel() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusUploadAtomicOutputStream
- cancel() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- cancelBlobUpload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.cancelBlobUpload
- cancelBlobUpload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.cancelBlobUpload
- cancelBlobUpload(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- cancelBlobUpload(String) - Method in class org.apache.storm.generated.Nimbus.Client
- cancelBlobUpload(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- cancelBlobUpload(String) - Method in class org.apache.storm.LocalCluster
- cancelBlobUpload(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- cancelBlobUpload(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- cancelBlobUpload_args() - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- cancelBlobUpload_args(String) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- cancelBlobUpload_args(Nimbus.cancelBlobUpload_args) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
-
Performs a deep copy on other.
- cancelBlobUpload_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.cancelBlobUpload_call
- cancelBlobUpload_result() - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- cancelBlobUpload_result(AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- cancelBlobUpload_result(Nimbus.cancelBlobUpload_result) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
-
Performs a deep copy on other.
- canConvertConvention(Convention) - Method in enum class org.apache.storm.sql.planner.streams.rel.StreamsLogicalConvention
- canTransformResource(String) - Method in class org.apache.storm.maven.shade.clojure.ClojureTransformer
- canUserReadBlob(ReadableBlobMeta, String, Map<String, Object>) - Static method in class org.apache.storm.utils.ServerUtils
- CAPACITY - Enum constant in enum class org.apache.storm.generated.BoltAggregateStats._Fields
- CaptureCollector - Class in org.apache.storm.trident.operation.impl
- CaptureCollector() - Constructor for class org.apache.storm.trident.operation.impl.CaptureCollector
- captured - Variable in class org.apache.storm.trident.operation.impl.CaptureCollector
- CapturedTopology(T, TupleCaptureBolt) - Constructor for class org.apache.storm.Testing.CapturedTopology
- CaptureLoad - Class in org.apache.storm.loadgen
-
Capture running topologies for load gen later on.
- CaptureLoad() - Constructor for class org.apache.storm.loadgen.CaptureLoad
- capturer - Variable in class org.apache.storm.Testing.CapturedTopology
-
a Bolt that will hold all of the captured data.
- captureTopology(StormTopology) - Static method in class org.apache.storm.Testing
-
Rewrites a topology so that all the tuples flowing through it are captured.
- CARDINALITY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CARET - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CASCADE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CASCADED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CASE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CaseExpression() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- CAST - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CATALOG_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- cb(Metric) - Method in interface org.apache.storm.metricstore.MetricStore.ScanCallback
- ceil(ZonedDateTime, int) - Static method in class org.apache.storm.st.utils.TimeUtil
- CEIL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CEILING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CENTURY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CGROUP_CLONE_CHILDREN - Static variable in class org.apache.storm.container.cgroup.CgroupCommon
- CGROUP_EVENT_CONTROL - Static variable in class org.apache.storm.container.cgroup.CgroupCommon
- CGROUP_PROCS - Static variable in class org.apache.storm.container.cgroup.CgroupCommon
- CGROUP_STATUS_FILE - Static variable in class org.apache.storm.container.cgroup.CgroupUtils
- CgroupCenter - Class in org.apache.storm.container.cgroup
- CgroupCommon - Class in org.apache.storm.container.cgroup
- CgroupCommon(String, Hierarchy, CgroupCommon) - Constructor for class org.apache.storm.container.cgroup.CgroupCommon
- CgroupCommon(Hierarchy, String) - Constructor for class org.apache.storm.container.cgroup.CgroupCommon
- CgroupCommonOperation - Interface in org.apache.storm.container.cgroup
- CgroupCore - Interface in org.apache.storm.container.cgroup.core
- CgroupCoreFactory - Class in org.apache.storm.container.cgroup
- CgroupCoreFactory() - Constructor for class org.apache.storm.container.cgroup.CgroupCoreFactory
- CGroupCpu - Class in org.apache.storm.metric.cgroup
-
Deprecated.
- CGroupCpu - Class in org.apache.storm.metrics2.cgroup
-
Report CPU used in the cgroup.
- CGroupCpu(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupCpu
-
Deprecated.
- CGroupCpu(Map<String, Object>) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupCpu
- CGroupCpuGuarantee - Class in org.apache.storm.metric.cgroup
-
Deprecated.
- CGroupCpuGuarantee - Class in org.apache.storm.metrics2.cgroup
-
Report the guaranteed number of cpu percentage this worker has requested.
- CGroupCpuGuarantee(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupCpuGuarantee
-
Deprecated.
- CGroupCpuGuarantee(Map<String, Object>) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupCpuGuarantee
- CGroupCpuGuaranteeByCfsQuota - Class in org.apache.storm.metric.cgroup
-
Deprecated.
- CGroupCpuGuaranteeByCfsQuota - Class in org.apache.storm.metrics2.cgroup
-
Report the percentage of the cpu guaranteed for the worker.
- CGroupCpuGuaranteeByCfsQuota(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupCpuGuaranteeByCfsQuota
-
Deprecated.
- CGroupCpuGuaranteeByCfsQuota(Map<String, Object>) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupCpuGuaranteeByCfsQuota
- CGroupCpuStat - Class in org.apache.storm.metrics2.cgroup
- CGroupCpuStat(Map<String, Object>) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupCpuStat
- CgroupManager - Class in org.apache.storm.container.cgroup
-
Class that implements ResourceIsolationInterface that manages cgroups.
- CgroupManager() - Constructor for class org.apache.storm.container.cgroup.CgroupManager
- CGroupMemoryLimit - Class in org.apache.storm.metric.cgroup
-
Deprecated.
- CGroupMemoryLimit - Class in org.apache.storm.metrics2.cgroup
-
Reports the current memory limit of the cgroup for this worker.
- CGroupMemoryLimit(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupMemoryLimit
-
Deprecated.
- CGroupMemoryLimit(Map<String, Object>) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupMemoryLimit
- CGroupMemoryUsage - Class in org.apache.storm.metric.cgroup
-
Deprecated.
- CGroupMemoryUsage - Class in org.apache.storm.metrics2.cgroup
-
Reports the current memory usage of the cgroup for this worker.
- CGroupMemoryUsage(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupMemoryUsage
-
Deprecated.
- CGroupMemoryUsage(Map<String, Object>) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupMemoryUsage
- CGroupMetricsBase<T> - Class in org.apache.storm.metric.cgroup
-
Deprecated.
- CGroupMetricsBase - Class in org.apache.storm.metrics2.cgroup
-
Base class for checking if CGroups are enabled, etc.
- CGroupMetricsBase(Map<String, Object>, SubSystemType) - Constructor for class org.apache.storm.metric.cgroup.CGroupMetricsBase
-
Deprecated.
- CGroupMetricsBase(Map<String, Object>, SubSystemType) - Constructor for class org.apache.storm.metrics2.cgroup.CGroupMetricsBase
- CgroupOperation - Interface in org.apache.storm.container.cgroup
-
An interface to implement the basic functions to manage cgroups such as mount and mounting a hiearchy and creating cgroups.
- cgroupParent - Variable in class org.apache.storm.container.oci.OciContainerManager
- cgroupRootPath - Variable in class org.apache.storm.container.oci.OciContainerManager
- CgroupUtils - Class in org.apache.storm.container.cgroup
- CgroupUtils() - Constructor for class org.apache.storm.container.cgroup.CgroupUtils
- CHAIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- chainedAgg() - Method in class org.apache.storm.trident.fluent.GroupedStream
- chainedAgg() - Method in class org.apache.storm.trident.Stream
- ChainedAggregatorDeclarer - Class in org.apache.storm.trident.fluent
- ChainedAggregatorDeclarer(IAggregatableStream, GlobalAggregationScheme) - Constructor for class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- ChainedAggregatorDeclarer.AggregationPartition - Interface in org.apache.storm.trident.fluent
- ChainedAggregatorImpl - Class in org.apache.storm.trident.operation.impl
- ChainedAggregatorImpl(Aggregator[], Fields[], ComboList.Factory) - Constructor for class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
- ChainedFullAggregatorDeclarer - Interface in org.apache.storm.trident.fluent
- ChainedPartitionAggregatorDeclarer - Interface in org.apache.storm.trident.fluent
- ChainedProcessorContext<T> - Class in org.apache.storm.streams.processors
-
A composite context that holds a chain of
ProcessorContext
. - ChainedProcessorContext(ProcessorNode, List<? extends ProcessorContext>) - Constructor for class org.apache.storm.streams.processors.ChainedProcessorContext
- ChainedProcessorContext(ProcessorNode, ProcessorContext...) - Constructor for class org.apache.storm.streams.processors.ChainedProcessorContext
- ChainedResult - Class in org.apache.storm.trident.operation.impl
- ChainedResult(TridentCollector, int) - Constructor for class org.apache.storm.trident.operation.impl.ChainedResult
- chainEnd() - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
- chainEnd() - Method in interface org.apache.storm.trident.fluent.IChainedAggregatorDeclarer
- changeChildCWD(boolean) - Method in class org.apache.storm.spout.ShellSpout
- changeChildCWD(boolean) - Method in class org.apache.storm.task.ShellBolt
-
Set if the current working directory of the child process should change to the resources dir from extracted from the jar, or if it should stay the same as the worker process to access things from the blob store.
- changed(Watcher.Event.EventType, String) - Method in interface org.apache.storm.callback.ZKStateChangedCallback
- channelActive(Channel) - Method in interface org.apache.storm.messaging.netty.IServer
- channelActive(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
- channelActive(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.SaslStormClientHandler
- channelActive(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.StormServerHandler
- channelActive(ChannelHandlerContext) - Method in class org.apache.storm.pacemaker.PacemakerClientHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.KerberosSaslServerHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.SaslStormClientHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.SaslStormServerAuthorizeHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.SaslStormServerHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.StormClientHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.StormServerHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.pacemaker.PacemakerClientHandler
- channelReady(Channel) - Method in class org.apache.storm.messaging.netty.Client
- channelReady(Channel) - Method in interface org.apache.storm.messaging.netty.ISaslClient
- channelReady(Channel) - Method in class org.apache.storm.pacemaker.PacemakerClient
- channelRegistered(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
- channelUnregistered(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
- CHAR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHAR_LENGTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTER_LENGTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTER_SET_CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTER_SET_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTER_SET_SCHEMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTERISTICS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARACTERS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CHARSET - Static variable in class org.apache.storm.hdfs.spout.TextFileReader
- CHARSETNAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- Check() - Constructor for class org.apache.storm.starter.InOrderDeliveryTest.Check
- CHECK - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- checkAuthorization(String) - Method in class org.apache.storm.daemon.supervisor.Supervisor
- checkAuthorization(String, Map<String, Object>, String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- checkAuthorization(String, Map<String, Object>, String) - Method in class org.apache.storm.daemon.supervisor.Supervisor
- checkAuthorization(String, Map<String, Object>, String, ReqContext) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- checkAuthorization(String, Map<String, Object>, String, ReqContext) - Method in class org.apache.storm.daemon.supervisor.Supervisor
- checkClientTrusted(X509Certificate[], String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- checkCredentialsChanged() - Method in class org.apache.storm.daemon.worker.Worker
- checkDirExists(String) - Static method in class org.apache.storm.utils.Utils
- checkFileExists(String) - Static method in class org.apache.storm.utils.Utils
- checkForBlobOrDownload(String) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- checkForBlobUpdate(String) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- checkForValidUsers(Subject, int) - Method in class org.apache.storm.blobstore.BlobStoreAclHandler
- checkInitialization(Map<String, Double>, String, Map<String, Object>) - Static method in class org.apache.storm.loadgen.CaptureLoad
-
Checks if the topology's resource requirements are initialized.
- checkLogConfigChanged() - Method in class org.apache.storm.daemon.worker.Worker
- CHECKPOINT_COMPONENT_ID - Static variable in class org.apache.storm.spout.CheckpointSpout
- CHECKPOINT_FIELD_ACTION - Static variable in class org.apache.storm.spout.CheckpointSpout
- CHECKPOINT_FIELD_TXID - Static variable in class org.apache.storm.spout.CheckpointSpout
- CHECKPOINT_STREAM_ID - Static variable in class org.apache.storm.spout.CheckpointSpout
- CheckpointSpout - Class in org.apache.storm.spout
-
Emits checkpoint tuples which is used to save the state of the
IStatefulComponent
across the topology. - CheckpointSpout() - Constructor for class org.apache.storm.spout.CheckpointSpout
- CheckPointState - Class in org.apache.storm.spout
-
Captures the current state of the transaction in
CheckpointSpout
. - CheckPointState() - Constructor for class org.apache.storm.spout.CheckPointState
- CheckPointState(long, CheckPointState.State) - Constructor for class org.apache.storm.spout.CheckPointState
- CheckPointState.Action - Enum Class in org.apache.storm.spout
- CheckPointState.State - Enum Class in org.apache.storm.spout
- CheckpointTupleForwarder - Class in org.apache.storm.topology
-
Wraps
IRichBolt
and forwards checkpoint tuples in a stateful topology. - CheckpointTupleForwarder(IRichBolt) - Constructor for class org.apache.storm.topology.CheckpointTupleForwarder
- checkSchedulingFeasibility() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
-
Check scheduling feasibility for a quick failure as the second step in
BaseResourceAwareStrategy.schedule(Cluster, TopologyDetails)
. - checkSchedulingFeasibility() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy
- checkSerialize(KryoTupleSerializer, AddressedTuple) - Method in class org.apache.storm.daemon.worker.WorkerState
- checkServerTrusted(X509Certificate[], String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- checkType(ComponentObject._Fields, Object) - Method in class org.apache.storm.generated.ComponentObject
- checkType(ExecutorSpecificStats._Fields, Object) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- checkType(Grouping._Fields, Object) - Method in class org.apache.storm.generated.Grouping
- checkType(HBMessageData._Fields, Object) - Method in class org.apache.storm.generated.HBMessageData
- checkType(JavaObjectArg._Fields, Object) - Method in class org.apache.storm.generated.JavaObjectArg
- checkType(SpecificAggregateStats._Fields, Object) - Method in class org.apache.storm.generated.SpecificAggregateStats
- checkType(TopologyActionOptions._Fields, Object) - Method in class org.apache.storm.generated.TopologyActionOptions
- chooseClientAlias(String[], Principal[], Socket) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- chooseServerAlias(String, Principal[], Socket) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- chooseTask(int[]) - Method in class org.apache.storm.grouping.PartialKeyGrouping.BalancedTargetSelector
-
Chooses one of the incoming tasks and selects the one that has been selected the fewest times so far.
- chooseTask(int[]) - Method in interface org.apache.storm.grouping.PartialKeyGrouping.TargetSelector
- chooseTaskIndex(List<T>, int) - Static method in class org.apache.storm.utils.TupleUtils
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.AllGrouper
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.BasicLoadAwareCustomStreamGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.FieldsGrouper
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.GlobalGrouper
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.NoneGrouper
- chooseTasks(int, List<Object>) - Method in interface org.apache.storm.grouping.CustomStreamGrouping
-
This function implements a custom stream grouping.
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.grouping.LoadAwareShuffleGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.grouping.PartialKeyGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.grouping.ShuffleGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.testing.NGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.trident.partition.GlobalGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.trident.partition.IdentityGrouping
- chooseTasks(int, List<Object>) - Method in class org.apache.storm.trident.partition.IndexHashGrouping
- CHUNK - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_args._Fields
- CHUNK - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadChunk_args._Fields
- CLASS_ORIGIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CLASSIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- classLoaders - Variable in class org.apache.storm.sql.AbstractStreamsProcessor
- className() - Method in class org.apache.storm.sql.parser.SqlCreateFunction
- clean() - Method in interface org.apache.storm.testing.CompletableSpout
-
Cleanup any global state kept.
- cleanInbox(String, int) - Static method in class org.apache.storm.daemon.nimbus.Nimbus
-
Deletes jar files in dirLoc older than seconds.
- cleanup() - Method in class org.apache.storm.clojure.ClojureBolt
- cleanup() - Method in class org.apache.storm.coordination.BatchBoltExecutor
- cleanup() - Method in class org.apache.storm.coordination.CoordinatedBolt
- cleanup() - Method in class org.apache.storm.daemon.Acker
- cleanup() - Method in class org.apache.storm.drpc.KeyedFairBolt
- cleanup() - Method in class org.apache.storm.drpc.ReturnResults
- cleanup() - Method in class org.apache.storm.flux.examples.WordCounter
- cleanup() - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- cleanup() - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.MyBolt
- cleanup() - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.MyBolt
- cleanup() - Method in class org.apache.storm.hooks.BaseTaskHook
- cleanup() - Method in interface org.apache.storm.hooks.ITaskHook
- cleanup() - Method in class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
-
Cleanup.
- cleanup() - Method in interface org.apache.storm.jdbc.common.ConnectionProvider
-
called once when the system is shutting down, should be idempotent.
- cleanup() - Method in class org.apache.storm.jdbc.common.HikariCPConnectionProvider
- cleanup() - Method in class org.apache.storm.jms.bolt.JmsBolt
-
Releases JMS resources.
- cleanup() - Method in class org.apache.storm.jms.example.GenericBolt
- cleanup() - Method in class org.apache.storm.kafka.bolt.KafkaBolt
- cleanup() - Method in class org.apache.storm.loadgen.HttpForwardingMetricsConsumer
- cleanup() - Method in interface org.apache.storm.metric.api.IClusterMetricsConsumer
- cleanup() - Method in interface org.apache.storm.metric.api.IMetricsConsumer
- cleanup() - Method in class org.apache.storm.metric.ClusterMetricsConsumerExecutor
- cleanup() - Method in class org.apache.storm.metric.EventLoggerBolt
- cleanup() - Method in class org.apache.storm.metric.LoggingClusterMetricsConsumer
- cleanup() - Method in class org.apache.storm.metric.LoggingMetricsConsumer
- cleanup() - Method in class org.apache.storm.metric.MetricsConsumerBolt
- cleanup() - Method in class org.apache.storm.metric.SystemBolt
- cleanup() - Method in interface org.apache.storm.nimbus.ITopologyActionNotifierPlugin
-
Called during shutdown.
- cleanup() - Method in class org.apache.storm.redis.bolt.AbstractRedisBolt
- cleanup() - Method in class org.apache.storm.redis.topology.WordCounter
- cleanup() - Method in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- cleanup() - Method in interface org.apache.storm.scheduler.IScheduler
-
called once when the system is shutting down, should be idempotent.
- cleanup() - Method in class org.apache.storm.scheduler.resource.ResourceAwareScheduler
- cleanup() - Method in class org.apache.storm.sql.runtime.datasource.socket.bolt.SocketBolt
- cleanup() - Method in class org.apache.storm.starter.MultiThreadWordCountTopology.MultiThreadedSplitSentence
- cleanup() - Method in interface org.apache.storm.task.IBolt
-
Called when an IBolt is going to be shutdown.
- cleanup() - Method in class org.apache.storm.task.ShellBolt
- cleanup() - Method in class org.apache.storm.testing.FixedTupleSpout
- cleanup() - Method in class org.apache.storm.testing.ForwardingMetricsConsumer
- cleanup() - Method in class org.apache.storm.testing.NonRichBoltTracker
- cleanup() - Method in class org.apache.storm.testing.TestAggregatesCounter
- cleanup() - Method in class org.apache.storm.testing.TestEventLogSpout
- cleanup() - Method in class org.apache.storm.testing.TestEventOrderCheckBolt
- cleanup() - Method in class org.apache.storm.testing.TestGlobalCount
- cleanup() - Method in class org.apache.storm.testing.TestWordCounter
- cleanup() - Method in class org.apache.storm.testing.TupleCaptureBolt
- cleanup() - Method in class org.apache.storm.topology.base.BaseBasicBolt
- cleanup() - Method in class org.apache.storm.topology.base.BaseRichBolt
- cleanup() - Method in class org.apache.storm.topology.base.BaseStatefulBolt
- cleanup() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
- cleanup() - Method in class org.apache.storm.topology.BasicBoltExecutor
- cleanup() - Method in class org.apache.storm.topology.CheckpointTupleForwarder
- cleanup() - Method in interface org.apache.storm.topology.IBasicBolt
- cleanup() - Method in interface org.apache.storm.topology.IStatefulBolt
-
Analogue to bolt function.
- cleanup() - Method in interface org.apache.storm.topology.IWindowedBolt
- cleanup() - Method in class org.apache.storm.topology.StatefulBoltExecutor
- cleanup() - Method in class org.apache.storm.topology.WindowedBoltExecutor
- cleanup() - Method in class org.apache.storm.trident.drpc.ReturnResultsReducer
- cleanup() - Method in class org.apache.storm.trident.operation.BaseMultiReducer
- cleanup() - Method in class org.apache.storm.trident.operation.BaseOperation
-
No-op implemnation.
- cleanup() - Method in class org.apache.storm.trident.operation.builtin.Negate
- cleanup() - Method in interface org.apache.storm.trident.operation.GroupedMultiReducer
- cleanup() - Method in class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
- cleanup() - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
- cleanup() - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorInitImpl
- cleanup() - Method in class org.apache.storm.trident.operation.impl.CombinerAggStateUpdater
- cleanup() - Method in class org.apache.storm.trident.operation.impl.FilterExecutor
- cleanup() - Method in class org.apache.storm.trident.operation.impl.FlatMapFunctionExecutor
- cleanup() - Method in class org.apache.storm.trident.operation.impl.GroupedAggregator
- cleanup() - Method in class org.apache.storm.trident.operation.impl.GroupedMultiReducerExecutor
- cleanup() - Method in class org.apache.storm.trident.operation.impl.IdentityMultiReducer
- cleanup() - Method in class org.apache.storm.trident.operation.impl.JoinerMultiReducer
- cleanup() - Method in class org.apache.storm.trident.operation.impl.MapFunctionExecutor
- cleanup() - Method in class org.apache.storm.trident.operation.impl.PreservingFieldsOrderJoinerMultiReducer
- cleanup() - Method in class org.apache.storm.trident.operation.impl.ReducerAggregatorImpl
- cleanup() - Method in class org.apache.storm.trident.operation.impl.ReducerAggStateUpdater
- cleanup() - Method in class org.apache.storm.trident.operation.impl.SingleEmitAggregator
- cleanup() - Method in class org.apache.storm.trident.operation.impl.TrueFilter
- cleanup() - Method in interface org.apache.storm.trident.operation.MultiReducer
- cleanup() - Method in interface org.apache.storm.trident.operation.Operation
-
When running in local mode, called when the local cluster is being shut down.
- cleanup() - Method in class org.apache.storm.trident.planner.processor.AggregateProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.processor.EachProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.processor.MapProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.processor.MultiReducerProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.processor.PartitionPersistProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.processor.ProjectedProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.processor.StateQueryProcessor
- cleanup() - Method in class org.apache.storm.trident.planner.SubtopologyBolt
- cleanup() - Method in interface org.apache.storm.trident.planner.TridentProcessor
- cleanup() - Method in class org.apache.storm.trident.spout.TridentSpoutCoordinator
- cleanup() - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
- cleanup() - Method in class org.apache.storm.trident.state.map.MapCombinerAggStateUpdater
- cleanup() - Method in class org.apache.storm.trident.state.map.MapReducerAggStateUpdater
- cleanup() - Method in interface org.apache.storm.trident.topology.ITridentBatchBolt
- cleanup() - Method in class org.apache.storm.trident.topology.TridentBoltExecutor
- cleanup() - Method in class org.apache.storm.trident.windowing.WindowsStateUpdater
- cleanup() - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- cleanup() - Method in class org.apache.storm.utils.TimeCacheMap
-
Deprecated.
- cleanup() - Method in class org.apache.storm.utils.VersionedStore
- cleanup(int) - Method in class org.apache.storm.utils.LocalState
- cleanup(int) - Method in class org.apache.storm.utils.VersionedStore
- cleanup(String, String, int) - Method in class org.apache.storm.container.cgroup.CgroupManager
- cleanup(String, String, int) - Method in class org.apache.storm.container.DefaultResourceIsolationManager
- cleanup(String, String, int) - Method in class org.apache.storm.container.docker.DockerManager
- cleanup(String, String, int) - Method in class org.apache.storm.container.oci.OciContainerManager
- cleanup(String, String, int) - Method in class org.apache.storm.container.oci.RuncLibContainerManager
- cleanup(String, String, int) - Method in interface org.apache.storm.container.ResourceIsolationInterface
-
This function will be called when the worker needs to shutdown.
- cleanup(ClientBlobStore) - Method in class org.apache.storm.localizer.LocalizedResourceRetentionSet
-
Actually cleanup the blobs to try and get below the target cache size.
- cleanUp() - Method in class org.apache.storm.daemon.supervisor.Container
- cleanUp() - Method in interface org.apache.storm.daemon.supervisor.Killable
-
Clean up the container.
- cleanupBefore(long) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
- cleanUpForRestart() - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- cleanUpForRestart() - Method in class org.apache.storm.daemon.supervisor.Container
-
Clean up the container partly preparing for restart.
- cleanupOrphanedData() - Method in class org.apache.storm.localizer.LocalizedResource
- cleanupOrphanedData() - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Clean up any temporary files.
- cleanupOrphanedData() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- cleanupStats() - Method in class org.apache.storm.stats.BoltExecutorStats
- cleanupStats() - Method in class org.apache.storm.stats.CommonStats
- cleanupStats() - Method in class org.apache.storm.stats.SpoutExecutorStats
- clear() - Method in class org.apache.storm.clojure.ClojureTuple
- clear() - Method in class org.apache.storm.clojure.IndifferentAccessMap
- clear() - Method in class org.apache.storm.daemon.nimbus.TopoCache
-
Clear all entries from the Cache.
- clear() - Method in class org.apache.storm.executor.TupleInfo
- clear() - Method in class org.apache.storm.generated.AccessControl
- clear() - Method in exception org.apache.storm.generated.AlreadyAliveException
- clear() - Method in class org.apache.storm.generated.Assignment
- clear() - Method in exception org.apache.storm.generated.AuthorizationException
- clear() - Method in class org.apache.storm.generated.BeginDownloadResult
- clear() - Method in class org.apache.storm.generated.Bolt
- clear() - Method in class org.apache.storm.generated.BoltAggregateStats
- clear() - Method in class org.apache.storm.generated.BoltStats
- clear() - Method in class org.apache.storm.generated.ClusterSummary
- clear() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- clear() - Method in class org.apache.storm.generated.CommonAggregateStats
- clear() - Method in class org.apache.storm.generated.ComponentAggregateStats
- clear() - Method in class org.apache.storm.generated.ComponentCommon
- clear() - Method in class org.apache.storm.generated.ComponentPageInfo
- clear() - Method in class org.apache.storm.generated.Credentials
- clear() - Method in class org.apache.storm.generated.DebugOptions
- clear() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- clear() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- clear() - Method in exception org.apache.storm.generated.DRPCExecutionException
- clear() - Method in class org.apache.storm.generated.DRPCRequest
- clear() - Method in class org.apache.storm.generated.ErrorInfo
- clear() - Method in class org.apache.storm.generated.ExecutorAggregateStats
- clear() - Method in class org.apache.storm.generated.ExecutorInfo
- clear() - Method in class org.apache.storm.generated.ExecutorStats
- clear() - Method in class org.apache.storm.generated.ExecutorSummary
- clear() - Method in class org.apache.storm.generated.GetInfoOptions
- clear() - Method in class org.apache.storm.generated.GlobalStreamId
- clear() - Method in exception org.apache.storm.generated.HBAuthorizationException
- clear() - Method in exception org.apache.storm.generated.HBExecutionException
- clear() - Method in class org.apache.storm.generated.HBMessage
- clear() - Method in class org.apache.storm.generated.HBNodes
- clear() - Method in class org.apache.storm.generated.HBPulse
- clear() - Method in class org.apache.storm.generated.HBRecords
- clear() - Method in exception org.apache.storm.generated.IllegalStateException
- clear() - Method in exception org.apache.storm.generated.InvalidTopologyException
- clear() - Method in class org.apache.storm.generated.JavaObject
- clear() - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- clear() - Method in exception org.apache.storm.generated.KeyNotFoundException
- clear() - Method in class org.apache.storm.generated.KillOptions
- clear() - Method in class org.apache.storm.generated.ListBlobsResult
- clear() - Method in class org.apache.storm.generated.LocalAssignment
- clear() - Method in class org.apache.storm.generated.LocalStateData
- clear() - Method in class org.apache.storm.generated.LogConfig
- clear() - Method in class org.apache.storm.generated.LogLevel
- clear() - Method in class org.apache.storm.generated.LSApprovedWorkers
- clear() - Method in class org.apache.storm.generated.LSSupervisorAssignments
- clear() - Method in class org.apache.storm.generated.LSSupervisorId
- clear() - Method in class org.apache.storm.generated.LSTopoHistory
- clear() - Method in class org.apache.storm.generated.LSTopoHistoryList
- clear() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- clear() - Method in class org.apache.storm.generated.Nimbus.activate_args
- clear() - Method in class org.apache.storm.generated.Nimbus.activate_result
- clear() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- clear() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- clear() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- clear() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- clear() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- clear() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- clear() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- clear() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- clear() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- clear() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- clear() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- clear() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- clear() - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- clear() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- clear() - Method in class org.apache.storm.generated.Nimbus.debug_args
- clear() - Method in class org.apache.storm.generated.Nimbus.debug_result
- clear() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- clear() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- clear() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- clear() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- clear() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- clear() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- clear() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- clear() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- clear() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- clear() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- clear() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- clear() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- clear() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- clear() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- clear() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- clear() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- clear() - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- clear() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- clear() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- clear() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- clear() - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- clear() - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- clear() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- clear() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- clear() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- clear() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- clear() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- clear() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- clear() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- clear() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- clear() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- clear() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- clear() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- clear() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- clear() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- clear() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- clear() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- clear() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- clear() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- clear() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- clear() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- clear() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- clear() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- clear() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- clear() - Method in class org.apache.storm.generated.NimbusSummary
- clear() - Method in class org.apache.storm.generated.NodeInfo
- clear() - Method in exception org.apache.storm.generated.NotAliveException
- clear() - Method in class org.apache.storm.generated.NullStruct
- clear() - Method in class org.apache.storm.generated.OwnerResourceSummary
- clear() - Method in class org.apache.storm.generated.PrivateWorkerKey
- clear() - Method in class org.apache.storm.generated.ProfileRequest
- clear() - Method in class org.apache.storm.generated.ReadableBlobMeta
- clear() - Method in class org.apache.storm.generated.RebalanceOptions
- clear() - Method in class org.apache.storm.generated.SettableBlobMeta
- clear() - Method in class org.apache.storm.generated.SharedMemory
- clear() - Method in class org.apache.storm.generated.ShellComponent
- clear() - Method in class org.apache.storm.generated.SpoutAggregateStats
- clear() - Method in class org.apache.storm.generated.SpoutSpec
- clear() - Method in class org.apache.storm.generated.SpoutStats
- clear() - Method in class org.apache.storm.generated.StateSpoutSpec
- clear() - Method in class org.apache.storm.generated.StormBase
- clear() - Method in class org.apache.storm.generated.StormTopology
- clear() - Method in class org.apache.storm.generated.StreamInfo
- clear() - Method in class org.apache.storm.generated.SubmitOptions
- clear() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- clear() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- clear() - Method in class org.apache.storm.generated.SupervisorAssignments
- clear() - Method in class org.apache.storm.generated.SupervisorInfo
- clear() - Method in class org.apache.storm.generated.SupervisorPageInfo
- clear() - Method in class org.apache.storm.generated.SupervisorSummary
- clear() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- clear() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- clear() - Method in class org.apache.storm.generated.ThriftSerializedObject
- clear() - Method in class org.apache.storm.generated.TopologyHistoryInfo
- clear() - Method in class org.apache.storm.generated.TopologyInfo
- clear() - Method in class org.apache.storm.generated.TopologyPageInfo
- clear() - Method in class org.apache.storm.generated.TopologyStats
- clear() - Method in class org.apache.storm.generated.TopologySummary
- clear() - Method in class org.apache.storm.generated.WorkerMetricList
- clear() - Method in class org.apache.storm.generated.WorkerMetricPoint
- clear() - Method in class org.apache.storm.generated.WorkerMetrics
- clear() - Method in class org.apache.storm.generated.WorkerResources
- clear() - Method in class org.apache.storm.generated.WorkerSummary
- clear() - Method in class org.apache.storm.generated.WorkerToken
- clear() - Method in class org.apache.storm.generated.WorkerTokenInfo
- clear() - Method in class org.apache.storm.loadgen.ScopedTopologySet
- clear() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- clear() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- clear() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Set all resources to 0.
- clear() - Method in interface org.apache.storm.scheduler.resource.normalization.NormalizedResourcesWithMemory
-
Set all resources to 0.
- clear() - Method in class org.apache.storm.utils.ListDelegate
- clear() - Method in class org.apache.storm.utils.TransferDrainer
- clear(String) - Static method in class org.apache.storm.testing.FixedTupleSpout
- clearCredentials(Subject, KerberosTicket) - Static method in class org.apache.storm.security.auth.kerberos.AutoTGT
- clearForceEmpty() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- clearIteratorPins() - Method in class org.apache.storm.windowing.persistence.WindowState
- clearState(String) - Static method in class org.apache.storm.utils.RegisteredGlobalState
- clearStateForStorm(String) - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
Clear all the state for a storm.
- clearStateForStorm(String) - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- clearTrackId() - Static method in class org.apache.storm.executor.LocalExecutor
- CLI - Class in org.apache.storm.command
- CLI() - Constructor for class org.apache.storm.command.CLI
- CLI.Assoc - Interface in org.apache.storm.command
- CLI.CLIBuilder - Class in org.apache.storm.command
- CLI.Parse - Interface in org.apache.storm.command
- CLIBuilder() - Constructor for class org.apache.storm.command.CLI.CLIBuilder
- client - Variable in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModuleTest
- Client - Class in org.apache.storm.messaging.netty
-
A Netty client for sending task messages to a remote destination (Netty server).
- Client(TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPC.Client
- Client(TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Client
- Client(TProtocol) - Constructor for class org.apache.storm.generated.Nimbus.Client
- Client(TProtocol) - Constructor for class org.apache.storm.generated.Supervisor.Client
- Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPC.Client
- Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Client
- Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.Nimbus.Client
- Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.Supervisor.Client
- CLIENT_BLOBSTORE - Static variable in class org.apache.storm.Config
-
What blobstore implementation the storm client should use.
- CLIENT_CNXN - Static variable in class org.apache.storm.utils.CuratorUtils
- CLIENT_USERS_KEY - Static variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
- ClientAuthUtils - Class in org.apache.storm.security.auth
- ClientAuthUtils() - Constructor for class org.apache.storm.security.auth.ClientAuthUtils
- ClientBlobStore - Class in org.apache.storm.blobstore
-
The ClientBlobStore has two concrete implementations 1.
- ClientBlobStore() - Constructor for class org.apache.storm.blobstore.ClientBlobStore
- ClientBlobStore.WithBlobstore - Interface in org.apache.storm.blobstore
- ClientCallbackHandler - Class in org.apache.storm.security.auth.kerberos
-
SASL client side callback handler.
- ClientCallbackHandler(Map<String, Object>) - Constructor for class org.apache.storm.security.auth.kerberos.ClientCallbackHandler
-
Constructor based on a JAAS configuration.
- ClientFactory<K,
V> - Interface in org.apache.storm.kafka.spout.internal -
This is here to enable testing.
- ClientFactoryDefault<K,
V> - Class in org.apache.storm.kafka.spout.internal - ClientFactoryDefault() - Constructor for class org.apache.storm.kafka.spout.internal.ClientFactoryDefault
- ClientMetricsUtils - Class in org.apache.storm.daemon.metrics
- ClientMetricsUtils() - Constructor for class org.apache.storm.daemon.metrics.ClientMetricsUtils
- ClientStatsUtil - Class in org.apache.storm.stats
-
Stats calculations needed by storm client code.
- ClientStatsUtil() - Constructor for class org.apache.storm.stats.ClientStatsUtil
- ClientSupervisorUtils - Class in org.apache.storm.daemon.supervisor
- ClientSupervisorUtils() - Constructor for class org.apache.storm.daemon.supervisor.ClientSupervisorUtils
- clientUsers - Variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer.AclFunctionEntry
- ClientZookeeper - Class in org.apache.storm.zookeeper
- ClientZookeeper() - Constructor for class org.apache.storm.zookeeper.ClientZookeeper
- CLOB - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CLOCKS_INSYNC - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.please use
HdfsSpout.setClocksInSync(boolean)
- ClojureBolt - Class in org.apache.storm.clojure
- ClojureBolt(List, List, List<Object>, Map<String, StreamInfo>) - Constructor for class org.apache.storm.clojure.ClojureBolt
- ClojureSerializationRegister - Class in org.apache.storm.clojure
- ClojureSerializationRegister() - Constructor for class org.apache.storm.clojure.ClojureSerializationRegister
- ClojureSpout - Class in org.apache.storm.clojure
- ClojureSpout(List, List, List<Object>, Map<String, StreamInfo>) - Constructor for class org.apache.storm.clojure.ClojureSpout
- ClojureTransformer - Class in org.apache.storm.maven.shade.clojure
- ClojureTransformer() - Constructor for class org.apache.storm.maven.shade.clojure.ClojureTransformer
- ClojureTuple - Class in org.apache.storm.clojure
- ClojureTuple(Tuple) - Constructor for class org.apache.storm.clojure.ClojureTuple
- ClojureUtil - Class in org.apache.storm.clojure
- ClojureUtil() - Constructor for class org.apache.storm.clojure.ClojureUtil
- clone() - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
- clone() - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
- cloneKerberosTicket(KerberosTicket) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
- close() - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
Function to release resource.
- close() - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- close() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
- close() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileOutputStream
- close() - Method in class org.apache.storm.blobstore.BlobStore
- close() - Method in class org.apache.storm.blobstore.ClientBlobStore
- close() - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- close() - Method in class org.apache.storm.blobstore.NimbusBlobStore
- close() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusUploadAtomicOutputStream
- close() - Method in class org.apache.storm.clojure.ClojureSpout
- close() - Method in interface org.apache.storm.cluster.IStateStorage
-
Close the connection to the data store.
- close() - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- close() - Method in class org.apache.storm.cluster.ZKStateStorage
- close() - Method in class org.apache.storm.daemon.drpc.DRPC
- close() - Method in class org.apache.storm.daemon.drpc.DRPCServer
- close() - Method in class org.apache.storm.daemon.logviewer.LogviewerServer
- close() - Method in class org.apache.storm.daemon.logviewer.utils.LogCleaner
- close() - Method in class org.apache.storm.daemon.nimbus.TimedWritableByteChannel
- close() - Method in class org.apache.storm.daemon.supervisor.ReadClusterState
- close() - Method in class org.apache.storm.daemon.supervisor.Slot
- close() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- close() - Method in class org.apache.storm.drpc.DRPCSpout
- close() - Method in class org.apache.storm.event.EventManagerImp
- close() - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- close() - Method in interface org.apache.storm.hdfs.bolt.Writer
- close() - Method in class org.apache.storm.hdfs.common.AbstractHDFSWriter
- close() - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- close() - Method in class org.apache.storm.hdfs.spout.SequenceFileReader
- close() - Method in class org.apache.storm.hdfs.spout.TextFileReader
- close() - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
- close() - Method in class org.apache.storm.jdbc.spout.UserSpout
- close() - Method in class org.apache.storm.jms.spout.JmsSpout
-
Close the
JmsSpout.session
andJmsSpout.connection
. - close() - Method in class org.apache.storm.kafka.spout.KafkaSpout
- close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentOpaqueSpoutEmitter
- close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutCoordinator
- close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutEmitter
- close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentTransactionalSpoutEmitter
- close() - Method in class org.apache.storm.loadgen.ScopedTopologySet
- close() - Method in class org.apache.storm.LocalCluster
- close() - Method in class org.apache.storm.LocalCluster.LocalTopology
- close() - Method in class org.apache.storm.LocalDRPC
- close() - Method in class org.apache.storm.localizer.AsyncLocalizer
- close() - Method in class org.apache.storm.LogWriter
- close() - Method in interface org.apache.storm.messaging.IConnection
-
close this connection.
- close() - Method in class org.apache.storm.messaging.netty.Client
-
Gracefully close this client.
- close() - Method in class org.apache.storm.metric.FileBasedEventLogger
- close() - Method in interface org.apache.storm.metric.IEventLogger
- close() - Method in class org.apache.storm.metric.internal.CountStat
- close() - Method in class org.apache.storm.metric.internal.LatencyStat
- close() - Method in class org.apache.storm.metric.internal.MultiCountStat
- close() - Method in class org.apache.storm.metric.internal.MultiLatencyStat
- close() - Method in class org.apache.storm.metric.internal.RateTracker
- close() - Method in class org.apache.storm.metric.timed.TimedResource
- close() - Method in interface org.apache.storm.metric.timed.TimerDecorated
- close() - Method in class org.apache.storm.metrics2.reporters.ConsoleStormReporter
- close() - Method in class org.apache.storm.metrics2.reporters.CsvStormReporter
- close() - Method in class org.apache.storm.metrics2.reporters.GraphiteStormReporter
- close() - Method in class org.apache.storm.metrics2.reporters.JmxStormReporter
- close() - Method in class org.apache.storm.metrics2.reporters.ScheduledStormReporter
- close() - Method in interface org.apache.storm.metricstore.MetricStore
-
Close the metric store.
- close() - Method in class org.apache.storm.metricstore.NoOpMetricStore
- close() - Method in class org.apache.storm.metricstore.rocksdb.MetricsCleaner
- close() - Method in class org.apache.storm.metricstore.rocksdb.RocksDbMetricsWriter
- close() - Method in class org.apache.storm.metricstore.rocksdb.RocksDbStore
-
Shutdown the store.
- close() - Method in class org.apache.storm.nimbus.AssignmentDistributionService
- close() - Method in interface org.apache.storm.nimbus.ILeaderElector
-
Method called to allow for cleanup.
- close() - Method in class org.apache.storm.pacemaker.PacemakerClient
- close() - Method in class org.apache.storm.pacemaker.PacemakerClientPool
- close() - Method in class org.apache.storm.perf.utils.BasicMetricsCollector
- close() - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- close() - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- close() - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
-
Release Container.
- close() - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
-
Release Container.
- close() - Method in class org.apache.storm.redis.common.container.JedisContainer
-
Release Container.
- close() - Method in class org.apache.storm.redis.common.container.RedisClusterContainer
- close() - Method in class org.apache.storm.redis.common.container.RedisContainer
- close() - Method in class org.apache.storm.redis.topology.WordSpout
- close() - Method in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
- close() - Method in class org.apache.storm.security.auth.kerberos.KerberosSaslTransportPlugin
- close() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- close() - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin
- close() - Method in class org.apache.storm.security.auth.ThriftClient
- close() - Method in class org.apache.storm.security.auth.workertoken.WorkerTokenAuthorizer
- close() - Method in interface org.apache.storm.spout.ISpout
-
Called when an ISpout is going to be shutdown.
- close() - Method in class org.apache.storm.spout.ShellSpout
- close() - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- close() - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
- close() - Method in interface org.apache.storm.state.IStateSpout
- close() - Method in class org.apache.storm.StormTimer
-
cancel timer.
- close() - Method in class org.apache.storm.testing.FeederSpout
- close() - Method in class org.apache.storm.testing.FixedTupleSpout
- close() - Method in class org.apache.storm.testing.InProcessZookeeper
- close() - Method in class org.apache.storm.testing.MockLeaderElector
- close() - Method in class org.apache.storm.testing.SpoutTracker
- close() - Method in class org.apache.storm.testing.staticmocking.MockedClientZookeeper
- close() - Method in class org.apache.storm.testing.staticmocking.MockedCluster
- close() - Method in class org.apache.storm.testing.staticmocking.MockedSupervisorUtils
- close() - Method in class org.apache.storm.testing.staticmocking.MockedZookeeper
- close() - Method in class org.apache.storm.testing.TestEventLogSpout
- close() - Method in class org.apache.storm.testing.TestPlannerSpout
- close() - Method in class org.apache.storm.testing.TestWordSpout
- close() - Method in class org.apache.storm.testing.TmpPath
- close() - Method in class org.apache.storm.topology.base.BaseRichSpout
- close() - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.BatchSpoutEmitter
- close() - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.EmptyCoordinator
- close() - Method in interface org.apache.storm.trident.spout.IBatchSpout
- close() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Coordinator
- close() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Emitter
- close() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Coordinator
- close() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Emitter
- close() - Method in interface org.apache.storm.trident.spout.ITridentSpout.BatchCoordinator
-
Release any resources from this coordinator.
- close() - Method in interface org.apache.storm.trident.spout.ITridentSpout.Emitter
-
Release any resources held by this emitter.
- close() - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Coordinator
- close() - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Emitter
- close() - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- close() - Method in class org.apache.storm.trident.testing.FeederBatchSpout.FeederCoordinator
- close() - Method in class org.apache.storm.trident.testing.FixedBatchSpout
- close() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- close() - Method in class org.apache.storm.trident.topology.state.TransactionalState
- close() - Method in class org.apache.storm.utils.BufferFileInputStream
- close() - Method in class org.apache.storm.utils.BufferInputStream
- close() - Method in class org.apache.storm.utils.DRPCClient.LocalOverride
- close() - Method in class org.apache.storm.utils.JCQueue
- close() - Method in class org.apache.storm.utils.JCQueueMetrics
- close() - Method in class org.apache.storm.utils.NimbusClient.LocalOverride
- close() - Method in class org.apache.storm.utils.StormCommonInstaller
- close() - Method in interface org.apache.storm.utils.SupervisorIfaceFactory
- close() - Method in class org.apache.storm.utils.Time.SimulatedTime
- close() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
- CLOSE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CLOSE_MESSAGE - Enum constant in enum class org.apache.storm.messaging.netty.ControlMessage
- Closed - Enum constant in enum class org.apache.storm.messaging.ConnectionWithStatus.Status
-
The connection channel is closed or being closed.
- closeResources() - Method in class org.apache.storm.daemon.worker.WorkerState
- CLS - Static variable in class org.apache.storm.st.topology.window.data.TimeData
- cluster - Variable in class org.apache.storm.scheduler.multitenant.NodePool
- cluster - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- cluster - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorter
- cluster - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
- Cluster - Class in org.apache.storm.scheduler
-
The current state of the storm cluster.
- Cluster(Cluster) - Constructor for class org.apache.storm.scheduler.Cluster
-
Copy constructor.
- Cluster(Cluster, Topologies) - Constructor for class org.apache.storm.scheduler.Cluster
-
Testing Constructor that takes an existing cluster and replaces the topologies in it.
- Cluster(INimbus, ResourceMetrics, Map<String, SupervisorDetails>, Map<String, ? extends SchedulerAssignment>, Topologies, Map<String, Object>) - Constructor for class org.apache.storm.scheduler.Cluster
- ClusterInfo(long) - Constructor for class org.apache.storm.metric.api.IClusterMetricsConsumer.ClusterInfo
- ClusterMetricRegistryValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.ClusterMetricRegistryValidator
- ClusterMetricsConsumerExecutor - Class in org.apache.storm.metric
- ClusterMetricsConsumerExecutor(String, Object) - Constructor for class org.apache.storm.metric.ClusterMetricsConsumerExecutor
- ClusterStateContext - Class in org.apache.storm.cluster
-
This class is intended to provide runtime-context to StateStorageFactory implementors, giving information such as what daemon is creating it.
- ClusterStateContext() - Constructor for class org.apache.storm.cluster.ClusterStateContext
- ClusterStateContext(DaemonType, Map<String, Object>) - Constructor for class org.apache.storm.cluster.ClusterStateContext
- ClusterStateListener - Interface in org.apache.storm.cluster
- ClusterSummary - Class in org.apache.storm.generated
- ClusterSummary() - Constructor for class org.apache.storm.generated.ClusterSummary
- ClusterSummary(List<SupervisorSummary>, List<TopologySummary>, List<NimbusSummary>) - Constructor for class org.apache.storm.generated.ClusterSummary
- ClusterSummary(ClusterSummary) - Constructor for class org.apache.storm.generated.ClusterSummary
-
Performs a deep copy on other.
- ClusterSummary._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClusterUtils - Class in org.apache.storm.cluster
- ClusterUtils() - Constructor for class org.apache.storm.cluster.ClusterUtils
- ClusterWorkerHeartbeat - Class in org.apache.storm.generated
- ClusterWorkerHeartbeat() - Constructor for class org.apache.storm.generated.ClusterWorkerHeartbeat
- ClusterWorkerHeartbeat(String, Map<ExecutorInfo, ExecutorStats>, int, int) - Constructor for class org.apache.storm.generated.ClusterWorkerHeartbeat
- ClusterWorkerHeartbeat(ClusterWorkerHeartbeat) - Constructor for class org.apache.storm.generated.ClusterWorkerHeartbeat
-
Performs a deep copy on other.
- ClusterWorkerHeartbeat._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- COALESCE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COBOL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- coGroupByKey(PairStream<K, V1>) - Method in class org.apache.storm.streams.PairStream
-
Groups the values of this stream with the values having the same key from the other stream.
- CoGroupByKeyProcessor<K,
V1, V2> - Class in org.apache.storm.streams.processors -
co-group by key implementation.
- CoGroupByKeyProcessor(String, String) - Constructor for class org.apache.storm.streams.processors.CoGroupByKeyProcessor
- COLLATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CollateClause() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a COLLATE clause
- COLLATION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COLLATION_CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COLLATION_ID - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COLLATION_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COLLATION_SCHEMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- collect(Nimbus.Iface) - Method in class org.apache.storm.perf.utils.BasicMetricsCollector
- COLLECT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CollectionsTypeName() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- collectMetricsAndKill(String, Integer, int) - Static method in class org.apache.storm.perf.utils.Helper
- collector - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- collector - Variable in class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
- collector - Variable in class org.apache.storm.kafka.spout.KafkaSpout
- collector - Variable in class org.apache.storm.redis.bolt.AbstractRedisBolt
- collector - Variable in class org.apache.storm.topology.BaseStatefulBoltExecutor
- collectTridentTupleOrKey(TridentBatchTuple, List<String>) - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
- COLON - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- column - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
- Column<T> - Class in org.apache.storm.jdbc.common
-
A database table can be defined as a list of rows and each row can be defined as a list of columns where each column instance has a name, a value and a type.
- Column(String, int) - Constructor for class org.apache.storm.jdbc.common.Column
- Column(String, T, int) - Constructor for class org.apache.storm.jdbc.common.Column
- COLUMN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COLUMN_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ColumnConstraint - Class in org.apache.storm.sql.parser
- ColumnConstraint.PrimaryKey - Class in org.apache.storm.sql.parser
- ColumnDefinition - Class in org.apache.storm.sql.parser
- ColumnDefinition(SqlIdentifier, SqlDataTypeSpec, ColumnConstraint, SqlParserPos) - Constructor for class org.apache.storm.sql.parser.ColumnDefinition
- ColumnDefinitionList() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- ColumnType(List<SqlNode>) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- combine(Integer, Integer) - Method in class org.apache.storm.starter.trident.TridentReach.One
- combine(Long, Long) - Method in class org.apache.storm.trident.operation.builtin.Count
- combine(Number, Number) - Method in class org.apache.storm.trident.operation.builtin.Sum
- combine(T, T) - Method in interface org.apache.storm.metric.api.ICombiner
- combine(T, T) - Method in interface org.apache.storm.trident.operation.CombinerAggregator
- CombinedMetric - Class in org.apache.storm.metric.api
- CombinedMetric(ICombiner) - Constructor for class org.apache.storm.metric.api.CombinedMetric
- CombinedShellMetric - Class in org.apache.storm.metric.api.rpc
- CombinedShellMetric(ICombiner) - Constructor for class org.apache.storm.metric.api.rpc.CombinedShellMetric
- CombinerAggregator<T,
A, R> - Interface in org.apache.storm.streams.operations -
Interface for aggregating values.
- CombinerAggregator<T> - Interface in org.apache.storm.trident.operation
- CombinerAggregatorCombineImpl - Class in org.apache.storm.trident.operation.impl
- CombinerAggregatorCombineImpl(CombinerAggregator) - Constructor for class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
- CombinerAggregatorInitImpl - Class in org.apache.storm.trident.operation.impl
- CombinerAggregatorInitImpl(CombinerAggregator) - Constructor for class org.apache.storm.trident.operation.impl.CombinerAggregatorInitImpl
- CombinerAggStateUpdater - Class in org.apache.storm.trident.operation.impl
- CombinerAggStateUpdater(CombinerAggregator) - Constructor for class org.apache.storm.trident.operation.impl.CombinerAggStateUpdater
- CombinerValueUpdater - Class in org.apache.storm.trident.state
- CombinerValueUpdater(CombinerAggregator, Object) - Constructor for class org.apache.storm.trident.state.CombinerValueUpdater
- ComboList - Class in org.apache.storm.trident.tuple
- ComboList(List[], ComboList.Pointer[]) - Constructor for class org.apache.storm.trident.tuple.ComboList
- ComboList.Factory - Class in org.apache.storm.trident.tuple
- COMMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COMMAND_FUNCTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COMMAND_FUNCTION_CODE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CommandExec - Class in org.apache.storm.maven.plugin.util
- CommandExec(Mojo) - Constructor for class org.apache.storm.maven.plugin.util.CommandExec
- commandFilePath(String, String) - Method in class org.apache.storm.container.oci.OciContainerManager
- COMMANDS - Static variable in class org.apache.storm.command.AdminCommands
- commit() - Method in class org.apache.storm.blobstore.BlobStoreFile
- commit() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- commit() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- commit() - Method in class org.apache.storm.redis.state.RedisKeyValueState
- commit() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
- commit() - Method in class org.apache.storm.state.InMemoryKeyValueState
- commit() - Method in interface org.apache.storm.state.State
-
Persist the current state.
- commit(long) - Method in class org.apache.storm.redis.state.RedisKeyValueState
- commit(long) - Method in class org.apache.storm.state.InMemoryKeyValueState
- commit(long) - Method in interface org.apache.storm.state.State
-
Commit a previously prepared transaction.
- commit(long) - Method in class org.apache.storm.windowing.persistence.WindowState
-
Commits the
WindowState
. - commit(Long) - Method in class org.apache.storm.hdfs.trident.HdfsState
- commit(Long) - Method in class org.apache.storm.jdbc.trident.state.JdbcState
- commit(Long) - Method in class org.apache.storm.jms.trident.JmsState
- commit(Long) - Method in class org.apache.storm.kafka.trident.TridentKafkaState
- commit(Long) - Method in class org.apache.storm.redis.trident.state.RedisClusterState
- commit(Long) - Method in class org.apache.storm.redis.trident.state.RedisState
- commit(Long) - Method in class org.apache.storm.trident.state.map.NonTransactionalMap
- commit(Long) - Method in class org.apache.storm.trident.state.map.OpaqueMap
- commit(Long) - Method in class org.apache.storm.trident.state.map.SnapshottableMap
- commit(Long) - Method in class org.apache.storm.trident.state.map.TransactionalMap
- commit(Long) - Method in class org.apache.storm.trident.state.ReadOnlyState
- commit(Long) - Method in interface org.apache.storm.trident.state.State
- commit(Long) - Method in class org.apache.storm.trident.testing.LRUMemoryMapState
- commit(Long) - Method in class org.apache.storm.trident.testing.MemoryMapState
- commit(Long) - Method in class org.apache.storm.trident.windowing.WindowsState
- commit(OffsetAndMetadata) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
-
Marks an offset as committed.
- commit(TransactionAttempt) - Method in interface org.apache.storm.trident.spout.ICommitterTridentSpout.Emitter
- commit(TransactionAttempt) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Emitter
- COMMIT - Enum constant in enum class org.apache.storm.spout.CheckPointState.Action
-
commit the previously prepared transaction.
- COMMIT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COMMIT_FREQ_COUNT - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.please use
HdfsSpout.setCommitFrequencyCount(int)
- COMMIT_FREQ_SEC - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.please use
HdfsSpout.setCommitFrequencySec(int)
- COMMIT_STREAM_ID - Static variable in class org.apache.storm.trident.topology.MasterBatchCoordinator
- CommitMetadata - Class in org.apache.storm.kafka.spout.internal
-
Object representing metadata committed to Kafka.
- CommitMetadata(String, int, String) - Constructor for class org.apache.storm.kafka.spout.internal.CommitMetadata
-
Kafka metadata.
- CommitMetadataManager - Class in org.apache.storm.kafka.spout.internal
-
Generates and reads commit metadata.
- CommitMetadataManager(TopologyContext, KafkaSpoutConfig.ProcessingGuarantee) - Constructor for class org.apache.storm.kafka.spout.internal.CommitMetadataManager
-
Create a manager with the given context.
- commitNewVersion(long) - Method in class org.apache.storm.localizer.LocalizedResource
- commitNewVersion(long) - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Commit the new version and make it available for the end user.
- commitNewVersion(long) - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- commitStream - Variable in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordCondition
- commitStream - Variable in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordSpec
- COMMITTED - Enum constant in enum class org.apache.storm.spout.CheckPointState.State
-
The checkpoint spout has committed the transaction.
- COMMITTED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- committer - Variable in class org.apache.storm.trident.planner.ProcessorNode
- COMMITTING - Enum constant in enum class org.apache.storm.spout.CheckPointState.State
-
The checkpoint spout has started committing the transaction and the commit is in progress.
- COMMON - Enum constant in enum class org.apache.storm.generated.Bolt._Fields
- COMMON - Enum constant in enum class org.apache.storm.generated.SpoutSpec._Fields
- COMMON - Enum constant in enum class org.apache.storm.generated.StateSpoutSpec._Fields
- COMMON - Enum constant in enum class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.NodeSortType
-
New and only node sorting type going forward.
- COMMON_CPU_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
- COMMON_OFFHEAP_MEMORY_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
- COMMON_ONHEAP_MEMORY_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
- COMMON_STATS - Enum constant in enum class org.apache.storm.generated.ComponentAggregateStats._Fields
- COMMON_TOTAL_MEMORY_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
- CommonAggregateStats - Class in org.apache.storm.generated
- CommonAggregateStats() - Constructor for class org.apache.storm.generated.CommonAggregateStats
- CommonAggregateStats(CommonAggregateStats) - Constructor for class org.apache.storm.generated.CommonAggregateStats
-
Performs a deep copy on other.
- CommonAggregateStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CommonKafkaSpoutConfig<K,
V> - Class in org.apache.storm.kafka.spout.internal - CommonKafkaSpoutConfig(CommonKafkaSpoutConfig.Builder<K, V, ?>) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
-
Creates a new CommonKafkaSpoutConfig using a Builder.
- CommonKafkaSpoutConfig.Builder<K,
V, T extends CommonKafkaSpoutConfig.Builder<K, V, T>> - Class in org.apache.storm.kafka.spout.internal - CommonNonReservedKeyWord() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a non-reserved keyword for use as an identifier.
- CommonStats - Class in org.apache.storm.stats
- CommonStats(int, int) - Constructor for class org.apache.storm.stats.CommonStats
- comp() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a comparison operator inside a SOME / ALL predicate.
- COMPACT - Enum constant in enum class org.apache.storm.trident.JoinOutFieldsMode
- compactWindow() - Method in class org.apache.storm.windowing.StatefulWindowManager
- compactWindow() - Method in class org.apache.storm.windowing.WindowManager
-
expires events that fall out of the window every EXPIRE_EVENTS_THRESHOLD so that the window does not grow too big.
- compare(Comparable<Object>, Comparable<Object>) - Method in class org.apache.storm.trident.operation.builtin.Max
- compare(Comparable<Object>, Comparable<Object>) - Method in class org.apache.storm.trident.operation.builtin.Min
- compare(FileStatus, FileStatus) - Method in class org.apache.storm.hdfs.common.ModifTimeComparator
- compare(TopicPartition, TopicPartition) - Method in class org.apache.storm.kafka.spout.TopicPartitionComparator
- compare(T, T) - Method in class org.apache.storm.trident.operation.builtin.ComparisonAggregator
- compare(T, T) - Method in class org.apache.storm.trident.operation.builtin.MaxWithComparator
- compare(T, T) - Method in class org.apache.storm.trident.operation.builtin.MinWithComparator
- compareTo(Object) - Method in class org.apache.storm.trident.util.IndexedEdge
- compareTo(AccessControl) - Method in class org.apache.storm.generated.AccessControl
- compareTo(AlreadyAliveException) - Method in exception org.apache.storm.generated.AlreadyAliveException
- compareTo(Assignment) - Method in class org.apache.storm.generated.Assignment
- compareTo(AuthorizationException) - Method in exception org.apache.storm.generated.AuthorizationException
- compareTo(BeginDownloadResult) - Method in class org.apache.storm.generated.BeginDownloadResult
- compareTo(Bolt) - Method in class org.apache.storm.generated.Bolt
- compareTo(BoltAggregateStats) - Method in class org.apache.storm.generated.BoltAggregateStats
- compareTo(BoltStats) - Method in class org.apache.storm.generated.BoltStats
- compareTo(ClusterSummary) - Method in class org.apache.storm.generated.ClusterSummary
- compareTo(ClusterWorkerHeartbeat) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- compareTo(CommonAggregateStats) - Method in class org.apache.storm.generated.CommonAggregateStats
- compareTo(ComponentAggregateStats) - Method in class org.apache.storm.generated.ComponentAggregateStats
- compareTo(ComponentCommon) - Method in class org.apache.storm.generated.ComponentCommon
- compareTo(ComponentObject) - Method in class org.apache.storm.generated.ComponentObject
- compareTo(ComponentPageInfo) - Method in class org.apache.storm.generated.ComponentPageInfo
- compareTo(Credentials) - Method in class org.apache.storm.generated.Credentials
- compareTo(DebugOptions) - Method in class org.apache.storm.generated.DebugOptions
- compareTo(DistributedRPC.execute_args) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- compareTo(DistributedRPC.execute_result) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- compareTo(DistributedRPCInvocations.failRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- compareTo(DistributedRPCInvocations.failRequest_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- compareTo(DistributedRPCInvocations.failRequestV2_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- compareTo(DistributedRPCInvocations.failRequestV2_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- compareTo(DistributedRPCInvocations.fetchRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- compareTo(DistributedRPCInvocations.fetchRequest_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- compareTo(DistributedRPCInvocations.result_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- compareTo(DistributedRPCInvocations.result_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- compareTo(DRPCExecutionException) - Method in exception org.apache.storm.generated.DRPCExecutionException
- compareTo(DRPCRequest) - Method in class org.apache.storm.generated.DRPCRequest
- compareTo(ErrorInfo) - Method in class org.apache.storm.generated.ErrorInfo
- compareTo(ExecutorAggregateStats) - Method in class org.apache.storm.generated.ExecutorAggregateStats
- compareTo(ExecutorInfo) - Method in class org.apache.storm.generated.ExecutorInfo
- compareTo(ExecutorSpecificStats) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- compareTo(ExecutorStats) - Method in class org.apache.storm.generated.ExecutorStats
- compareTo(ExecutorSummary) - Method in class org.apache.storm.generated.ExecutorSummary
- compareTo(GetInfoOptions) - Method in class org.apache.storm.generated.GetInfoOptions
- compareTo(GlobalStreamId) - Method in class org.apache.storm.generated.GlobalStreamId
- compareTo(Grouping) - Method in class org.apache.storm.generated.Grouping
- compareTo(HBAuthorizationException) - Method in exception org.apache.storm.generated.HBAuthorizationException
- compareTo(HBExecutionException) - Method in exception org.apache.storm.generated.HBExecutionException
- compareTo(HBMessage) - Method in class org.apache.storm.generated.HBMessage
- compareTo(HBMessageData) - Method in class org.apache.storm.generated.HBMessageData
- compareTo(HBNodes) - Method in class org.apache.storm.generated.HBNodes
- compareTo(HBPulse) - Method in class org.apache.storm.generated.HBPulse
- compareTo(HBRecords) - Method in class org.apache.storm.generated.HBRecords
- compareTo(IllegalStateException) - Method in exception org.apache.storm.generated.IllegalStateException
- compareTo(InvalidTopologyException) - Method in exception org.apache.storm.generated.InvalidTopologyException
- compareTo(JavaObject) - Method in class org.apache.storm.generated.JavaObject
- compareTo(JavaObjectArg) - Method in class org.apache.storm.generated.JavaObjectArg
- compareTo(KeyAlreadyExistsException) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- compareTo(KeyNotFoundException) - Method in exception org.apache.storm.generated.KeyNotFoundException
- compareTo(KillOptions) - Method in class org.apache.storm.generated.KillOptions
- compareTo(ListBlobsResult) - Method in class org.apache.storm.generated.ListBlobsResult
- compareTo(LocalAssignment) - Method in class org.apache.storm.generated.LocalAssignment
- compareTo(LocalStateData) - Method in class org.apache.storm.generated.LocalStateData
- compareTo(LogConfig) - Method in class org.apache.storm.generated.LogConfig
- compareTo(LogLevel) - Method in class org.apache.storm.generated.LogLevel
- compareTo(LSApprovedWorkers) - Method in class org.apache.storm.generated.LSApprovedWorkers
- compareTo(LSSupervisorAssignments) - Method in class org.apache.storm.generated.LSSupervisorAssignments
- compareTo(LSSupervisorId) - Method in class org.apache.storm.generated.LSSupervisorId
- compareTo(LSTopoHistory) - Method in class org.apache.storm.generated.LSTopoHistory
- compareTo(LSTopoHistoryList) - Method in class org.apache.storm.generated.LSTopoHistoryList
- compareTo(LSWorkerHeartbeat) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- compareTo(Nimbus.activate_args) - Method in class org.apache.storm.generated.Nimbus.activate_args
- compareTo(Nimbus.activate_result) - Method in class org.apache.storm.generated.Nimbus.activate_result
- compareTo(Nimbus.beginBlobDownload_args) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- compareTo(Nimbus.beginBlobDownload_result) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- compareTo(Nimbus.beginCreateBlob_args) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- compareTo(Nimbus.beginCreateBlob_result) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- compareTo(Nimbus.beginFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- compareTo(Nimbus.beginFileUpload_result) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- compareTo(Nimbus.beginUpdateBlob_args) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- compareTo(Nimbus.beginUpdateBlob_result) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- compareTo(Nimbus.cancelBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- compareTo(Nimbus.cancelBlobUpload_result) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- compareTo(Nimbus.createStateInZookeeper_args) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- compareTo(Nimbus.createStateInZookeeper_result) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- compareTo(Nimbus.deactivate_args) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- compareTo(Nimbus.deactivate_result) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- compareTo(Nimbus.debug_args) - Method in class org.apache.storm.generated.Nimbus.debug_args
- compareTo(Nimbus.debug_result) - Method in class org.apache.storm.generated.Nimbus.debug_result
- compareTo(Nimbus.deleteBlob_args) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- compareTo(Nimbus.deleteBlob_result) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- compareTo(Nimbus.downloadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- compareTo(Nimbus.downloadBlobChunk_result) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- compareTo(Nimbus.downloadChunk_args) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- compareTo(Nimbus.downloadChunk_result) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- compareTo(Nimbus.finishBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- compareTo(Nimbus.finishBlobUpload_result) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- compareTo(Nimbus.finishFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- compareTo(Nimbus.finishFileUpload_result) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- compareTo(Nimbus.getBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- compareTo(Nimbus.getBlobMeta_result) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- compareTo(Nimbus.getBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- compareTo(Nimbus.getBlobReplication_result) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- compareTo(Nimbus.getClusterInfo_args) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- compareTo(Nimbus.getClusterInfo_result) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- compareTo(Nimbus.getComponentPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- compareTo(Nimbus.getComponentPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- compareTo(Nimbus.getComponentPendingProfileActions_args) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- compareTo(Nimbus.getComponentPendingProfileActions_result) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- compareTo(Nimbus.getLeader_args) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- compareTo(Nimbus.getLeader_result) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- compareTo(Nimbus.getLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- compareTo(Nimbus.getLogConfig_result) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- compareTo(Nimbus.getNimbusConf_args) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- compareTo(Nimbus.getNimbusConf_result) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- compareTo(Nimbus.getOwnerResourceSummaries_args) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- compareTo(Nimbus.getOwnerResourceSummaries_result) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- compareTo(Nimbus.getSupervisorAssignments_args) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- compareTo(Nimbus.getSupervisorAssignments_result) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- compareTo(Nimbus.getSupervisorPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- compareTo(Nimbus.getSupervisorPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- compareTo(Nimbus.getTopology_args) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- compareTo(Nimbus.getTopology_result) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- compareTo(Nimbus.getTopologyConf_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- compareTo(Nimbus.getTopologyConf_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- compareTo(Nimbus.getTopologyHistory_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- compareTo(Nimbus.getTopologyHistory_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- compareTo(Nimbus.getTopologyInfo_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- compareTo(Nimbus.getTopologyInfo_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- compareTo(Nimbus.getTopologyInfoByName_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- compareTo(Nimbus.getTopologyInfoByName_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- compareTo(Nimbus.getTopologyInfoByNameWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- compareTo(Nimbus.getTopologyInfoByNameWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- compareTo(Nimbus.getTopologyInfoWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- compareTo(Nimbus.getTopologyInfoWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- compareTo(Nimbus.getTopologyPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- compareTo(Nimbus.getTopologyPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- compareTo(Nimbus.getTopologySummaries_args) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- compareTo(Nimbus.getTopologySummaries_result) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- compareTo(Nimbus.getTopologySummary_args) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- compareTo(Nimbus.getTopologySummary_result) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- compareTo(Nimbus.getTopologySummaryByName_args) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- compareTo(Nimbus.getTopologySummaryByName_result) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- compareTo(Nimbus.getUserTopology_args) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- compareTo(Nimbus.getUserTopology_result) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- compareTo(Nimbus.isRemoteBlobExists_args) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- compareTo(Nimbus.isRemoteBlobExists_result) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- compareTo(Nimbus.isTopologyNameAllowed_args) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- compareTo(Nimbus.isTopologyNameAllowed_result) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- compareTo(Nimbus.killTopology_args) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- compareTo(Nimbus.killTopology_result) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- compareTo(Nimbus.killTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- compareTo(Nimbus.killTopologyWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- compareTo(Nimbus.listBlobs_args) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- compareTo(Nimbus.listBlobs_result) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- compareTo(Nimbus.processWorkerMetrics_args) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- compareTo(Nimbus.processWorkerMetrics_result) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- compareTo(Nimbus.rebalance_args) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- compareTo(Nimbus.rebalance_result) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- compareTo(Nimbus.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- compareTo(Nimbus.sendSupervisorWorkerHeartbeat_result) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- compareTo(Nimbus.sendSupervisorWorkerHeartbeats_args) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- compareTo(Nimbus.sendSupervisorWorkerHeartbeats_result) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- compareTo(Nimbus.setBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- compareTo(Nimbus.setBlobMeta_result) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- compareTo(Nimbus.setLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- compareTo(Nimbus.setLogConfig_result) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- compareTo(Nimbus.setWorkerProfiler_args) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- compareTo(Nimbus.setWorkerProfiler_result) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- compareTo(Nimbus.submitTopology_args) - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- compareTo(Nimbus.submitTopology_result) - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- compareTo(Nimbus.submitTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- compareTo(Nimbus.submitTopologyWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- compareTo(Nimbus.updateBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- compareTo(Nimbus.updateBlobReplication_result) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- compareTo(Nimbus.uploadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- compareTo(Nimbus.uploadBlobChunk_result) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- compareTo(Nimbus.uploadChunk_args) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- compareTo(Nimbus.uploadChunk_result) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- compareTo(Nimbus.uploadNewCredentials_args) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- compareTo(Nimbus.uploadNewCredentials_result) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- compareTo(NimbusSummary) - Method in class org.apache.storm.generated.NimbusSummary
- compareTo(NodeInfo) - Method in class org.apache.storm.generated.NodeInfo
- compareTo(NotAliveException) - Method in exception org.apache.storm.generated.NotAliveException
- compareTo(NullStruct) - Method in class org.apache.storm.generated.NullStruct
- compareTo(OwnerResourceSummary) - Method in class org.apache.storm.generated.OwnerResourceSummary
- compareTo(PrivateWorkerKey) - Method in class org.apache.storm.generated.PrivateWorkerKey
- compareTo(ProfileRequest) - Method in class org.apache.storm.generated.ProfileRequest
- compareTo(ReadableBlobMeta) - Method in class org.apache.storm.generated.ReadableBlobMeta
- compareTo(RebalanceOptions) - Method in class org.apache.storm.generated.RebalanceOptions
- compareTo(SettableBlobMeta) - Method in class org.apache.storm.generated.SettableBlobMeta
- compareTo(SharedMemory) - Method in class org.apache.storm.generated.SharedMemory
- compareTo(ShellComponent) - Method in class org.apache.storm.generated.ShellComponent
- compareTo(SpecificAggregateStats) - Method in class org.apache.storm.generated.SpecificAggregateStats
- compareTo(SpoutAggregateStats) - Method in class org.apache.storm.generated.SpoutAggregateStats
- compareTo(SpoutSpec) - Method in class org.apache.storm.generated.SpoutSpec
- compareTo(SpoutStats) - Method in class org.apache.storm.generated.SpoutStats
- compareTo(StateSpoutSpec) - Method in class org.apache.storm.generated.StateSpoutSpec
- compareTo(StormBase) - Method in class org.apache.storm.generated.StormBase
- compareTo(StormTopology) - Method in class org.apache.storm.generated.StormTopology
- compareTo(StreamInfo) - Method in class org.apache.storm.generated.StreamInfo
- compareTo(SubmitOptions) - Method in class org.apache.storm.generated.SubmitOptions
- compareTo(Supervisor.getLocalAssignmentForStorm_args) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- compareTo(Supervisor.getLocalAssignmentForStorm_result) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- compareTo(Supervisor.sendSupervisorAssignments_args) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- compareTo(Supervisor.sendSupervisorAssignments_result) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- compareTo(Supervisor.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- compareTo(Supervisor.sendSupervisorWorkerHeartbeat_result) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- compareTo(SupervisorAssignments) - Method in class org.apache.storm.generated.SupervisorAssignments
- compareTo(SupervisorInfo) - Method in class org.apache.storm.generated.SupervisorInfo
- compareTo(SupervisorPageInfo) - Method in class org.apache.storm.generated.SupervisorPageInfo
- compareTo(SupervisorSummary) - Method in class org.apache.storm.generated.SupervisorSummary
- compareTo(SupervisorWorkerHeartbeat) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- compareTo(SupervisorWorkerHeartbeats) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- compareTo(ThriftSerializedObject) - Method in class org.apache.storm.generated.ThriftSerializedObject
- compareTo(TopologyActionOptions) - Method in class org.apache.storm.generated.TopologyActionOptions
- compareTo(TopologyHistoryInfo) - Method in class org.apache.storm.generated.TopologyHistoryInfo
- compareTo(TopologyInfo) - Method in class org.apache.storm.generated.TopologyInfo
- compareTo(TopologyPageInfo) - Method in class org.apache.storm.generated.TopologyPageInfo
- compareTo(TopologyStats) - Method in class org.apache.storm.generated.TopologyStats
- compareTo(TopologySummary) - Method in class org.apache.storm.generated.TopologySummary
- compareTo(WorkerMetricList) - Method in class org.apache.storm.generated.WorkerMetricList
- compareTo(WorkerMetricPoint) - Method in class org.apache.storm.generated.WorkerMetricPoint
- compareTo(WorkerMetrics) - Method in class org.apache.storm.generated.WorkerMetrics
- compareTo(WorkerResources) - Method in class org.apache.storm.generated.WorkerResources
- compareTo(WorkerSummary) - Method in class org.apache.storm.generated.WorkerSummary
- compareTo(WorkerToken) - Method in class org.apache.storm.generated.WorkerToken
- compareTo(WorkerTokenInfo) - Method in class org.apache.storm.generated.WorkerTokenInfo
- compareTo(FileOffset) - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
- compareTo(FileOffset) - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
- compareTo(JmsMessageID) - Method in class org.apache.storm.jms.spout.JmsMessageID
- compareTo(Metric) - Method in class org.apache.storm.metricstore.Metric
- compareTo(RocksDbKey) - Method in class org.apache.storm.metricstore.rocksdb.RocksDbKey
-
compares to keys on a byte by byte basis.
- compareTo(RasNode) - Method in class org.apache.storm.scheduler.resource.RasNode
- compareTo(TimeData) - Method in class org.apache.storm.st.topology.window.data.TimeData
- compareTo(Rankable) - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
- compareTo(SimpleVersion) - Method in class org.apache.storm.utils.SimpleVersion
- ComparisonAggregator<T> - Class in org.apache.storm.trident.operation.builtin
-
Abstract
Aggregator
for comparing two values in a stream. - ComparisonAggregator(String) - Constructor for class org.apache.storm.trident.operation.builtin.ComparisonAggregator
- ComparisonAggregator.State - Class in org.apache.storm.trident.operation.builtin
- compile(List<RexNode>, RelDataType, String) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler
- compile(Map<String, ISqlStreamsDataSource>, String) - Method in class org.apache.storm.sql.planner.streams.QueryPlanner
- compile(RexProgram, String) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler
- CompilerUtil - Class in org.apache.storm.sql.compiler
- CompilerUtil() - Constructor for class org.apache.storm.sql.compiler.CompilerUtil
- CompilerUtil.TableBuilderInfo - Class in org.apache.storm.sql.compiler
- compileSql(String) - Method in class org.apache.storm.sql.StormSqlContext
- compileToBlock(List<RexNode>, RelDataType) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler
- compileToBlock(RexProgram) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler
- CompilingClassLoader - Class in org.apache.storm.sql.javac
-
This is a Java ClassLoader that will attempt to load a class from a string of source code.
- CompilingClassLoader(ClassLoader, String, String, DiagnosticListener<JavaFileObject>) - Constructor for class org.apache.storm.sql.javac.CompilingClassLoader
-
Constructor.
- CompilingClassLoader.CompilerException - Exception in org.apache.storm.sql.javac
-
Thrown when code cannot be compiled.
- CompletableSpout - Interface in org.apache.storm.testing
- complete() - Method in interface org.apache.storm.localizer.PortAndAssignment
- complete() - Method in class org.apache.storm.localizer.TimePortAndAssignment
- complete(Object[], TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedAggregator
- complete(Map<TridentTuple, Object>, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedMultiReducerExecutor
- complete(PriorityQueue, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNSortedAgg
- complete(ReturnResultsReducer.ReturnResultsState, TridentCollector) - Method in class org.apache.storm.trident.drpc.ReturnResultsReducer
- complete(ComparisonAggregator.State, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.ComparisonAggregator
- complete(FirstN.FirstNAgg.State, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg
- complete(ChainedResult, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
- complete(JoinState, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.JoinerMultiReducer
- complete(JoinState, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.PreservingFieldsOrderJoinerMultiReducer
- complete(Result, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
- complete(Result, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ReducerAggregatorImpl
- complete(SingleEmitAggregator.SingleEmitState, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.SingleEmitAggregator
- complete(CountAsAggregator.State, TridentCollector) - Method in class org.apache.storm.trident.testing.CountAsAggregator
- complete(T, TridentCollector) - Method in interface org.apache.storm.trident.operation.Aggregator
- complete(T, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.IdentityMultiReducer
- complete(T, TridentCollector) - Method in interface org.apache.storm.trident.operation.MultiReducer
- complete(T, TridentTuple, TridentCollector) - Method in interface org.apache.storm.trident.operation.GroupedMultiReducer
- COMPLETE_LATENCY_MS - Enum constant in enum class org.apache.storm.generated.SpoutAggregateStats._Fields
- COMPLETE_MS_AVG - Enum constant in enum class org.apache.storm.generated.SpoutStats._Fields
- completed() - Method in class org.apache.storm.testing.TestEventLogSpout
- completeLatencyMs - Variable in class org.apache.storm.hooks.info.SpoutAckInfo
- completelyRemove() - Method in class org.apache.storm.localizer.LocalizedResource
- completelyRemove() - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Completely remove anything that is cached locally for this blob and all tracking files also stored for it.
- completelyRemove() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- completeTopology(ILocalCluster, StormTopology) - Static method in class org.apache.storm.Testing
-
Run a topology to completion capturing all of the messages that are emitted.
- completeTopology(ILocalCluster, StormTopology, CompleteTopologyParam) - Static method in class org.apache.storm.Testing
-
Run a topology to completion capturing all of the messages that are emitted.
- CompleteTopologyParam - Class in org.apache.storm.testing
-
The param class for the `Testing.completeTopology`.
- CompleteTopologyParam() - Constructor for class org.apache.storm.testing.CompleteTopologyParam
- Component - Class in org.apache.storm.scheduler
- Component(ComponentType, String, List<ExecutorDetails>, Map<GlobalStreamId, Grouping>) - Constructor for class org.apache.storm.scheduler.Component
-
Create a new component.
- COMPONENT - Enum constant in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
- COMPONENT_DEBUG - Enum constant in enum class org.apache.storm.generated.StormBase._Fields
- COMPONENT_DEBUG - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- COMPONENT_EXECUTORS - Enum constant in enum class org.apache.storm.generated.StormBase._Fields
- COMPONENT_ID - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- COMPONENT_ID - Enum constant in enum class org.apache.storm.generated.ExecutorSummary._Fields
- COMPONENT_ID - Enum constant in enum class org.apache.storm.generated.GlobalStreamId._Fields
- COMPONENT_ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
- COMPONENT_ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
- COMPONENT_ID - Enum constant in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
- COMPONENT_STRING - Enum constant in enum class org.apache.storm.metricstore.rocksdb.KeyType
- COMPONENT_TO_DEBUG_ATOM - Static variable in class org.apache.storm.Constants
- COMPONENT_TO_NUM_TASKS - Enum constant in enum class org.apache.storm.generated.WorkerSummary._Fields
- COMPONENT_TO_SHARED_MEMORY - Enum constant in enum class org.apache.storm.generated.StormTopology._Fields
- COMPONENT_TO_SORTED_TASKS - Static variable in class org.apache.storm.Constants
- COMPONENT_TO_STREAM_TO_FIELDS - Static variable in class org.apache.storm.Constants
- COMPONENT_TYPE - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- ComponentAggregateStats - Class in org.apache.storm.generated
- ComponentAggregateStats() - Constructor for class org.apache.storm.generated.ComponentAggregateStats
- ComponentAggregateStats(ComponentAggregateStats) - Constructor for class org.apache.storm.generated.ComponentAggregateStats
-
Performs a deep copy on other.
- ComponentAggregateStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ComponentCommon - Class in org.apache.storm.generated
- ComponentCommon() - Constructor for class org.apache.storm.generated.ComponentCommon
- ComponentCommon(Map<GlobalStreamId, Grouping>, Map<String, StreamInfo>) - Constructor for class org.apache.storm.generated.ComponentCommon
- ComponentCommon(ComponentCommon) - Constructor for class org.apache.storm.generated.ComponentCommon
-
Performs a deep copy on other.
- ComponentCommon._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- componentConf(Object) - Static method in class org.apache.storm.daemon.StormCommon
- ComponentConfigurationDeclarer<T extends ComponentConfigurationDeclarer> - Interface in org.apache.storm.topology
- componentId - Variable in class org.apache.storm.executor.Executor
- componentId - Variable in class org.apache.storm.hdfs.spout.FileLock.LogEntry
- componentId - Variable in class org.apache.storm.planner.TaskBundle
- componentId - Variable in class org.apache.storm.streams.WindowNode
- componentName - Variable in class org.apache.storm.utils.ShellProcess
- ComponentObject - Class in org.apache.storm.generated
- ComponentObject() - Constructor for class org.apache.storm.generated.ComponentObject
- ComponentObject(ComponentObject) - Constructor for class org.apache.storm.generated.ComponentObject
- ComponentObject(ComponentObject._Fields, Object) - Constructor for class org.apache.storm.generated.ComponentObject
- ComponentObject._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ComponentPageInfo - Class in org.apache.storm.generated
- ComponentPageInfo() - Constructor for class org.apache.storm.generated.ComponentPageInfo
- ComponentPageInfo(String, ComponentType) - Constructor for class org.apache.storm.generated.ComponentPageInfo
- ComponentPageInfo(ComponentPageInfo) - Constructor for class org.apache.storm.generated.ComponentPageInfo
-
Performs a deep copy on other.
- ComponentPageInfo._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- componentType(StormTopology, String) - Static method in class org.apache.storm.stats.StatsUtil
-
Get the coponenet type for a give id.
- ComponentType - Enum Class in org.apache.storm.generated
- CompoundIdentifier() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a compound identifier.
- CompoundIdentifierType(List<SqlNode>, List<SqlNode>) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a compound identifier with optional type.
- CompoundIdentifierTypeCommaList(List<SqlNode>, List<SqlNode>) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a comma-separated list of compound identifiers.
- CompoundSpout - Class in org.apache.storm.planner
- CompoundSpout() - Constructor for class org.apache.storm.planner.CompoundSpout
- CompoundTask - Class in org.apache.storm.planner
- CompoundTask() - Constructor for class org.apache.storm.planner.CompoundTask
- compToExecs - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- computeBoltCapacity(List<ExecutorSummary>) - Static method in class org.apache.storm.stats.StatsUtil
-
computes max bolt capacity.
- computeExecutorCapacity(ExecutorSummary) - Static method in class org.apache.storm.stats.StatsUtil
-
Compute the capacity of a executor.
- CONCAT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- concatIfNotNull(String) - Static method in class org.apache.storm.utils.ConfigUtils
- CONDITION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONDITION_NUMBER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- conf - Variable in class org.apache.storm.container.DefaultResourceIsolationManager
- conf - Variable in class org.apache.storm.container.oci.OciContainerManager
- conf - Variable in class org.apache.storm.daemon.supervisor.Container
- conf - Static variable in class org.apache.storm.daemon.ui.filters.AuthorizedUserFilter
- conf - Variable in class org.apache.storm.executor.Executor
- conf - Variable in class org.apache.storm.security.auth.sasl.SaslTransportPlugin
- conf - Variable in class org.apache.storm.security.auth.tls.TlsTransportPlugin
- conf - Variable in class org.apache.storm.topology.ConfigurableTopology
- CONF - Static variable in class org.apache.storm.Constants
- config - Static variable in class org.apache.storm.daemon.ui.resources.StormApiResource
- config - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- config() - Method in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- config() - Method in class org.apache.storm.scheduler.DefaultScheduler
- config() - Method in class org.apache.storm.scheduler.EvenScheduler
- config() - Method in interface org.apache.storm.scheduler.IScheduler
-
This function returns the scheduler's configuration.
- config() - Method in class org.apache.storm.scheduler.IsolationScheduler
- config() - Method in class org.apache.storm.scheduler.multitenant.MultitenantScheduler
- config() - Method in class org.apache.storm.scheduler.resource.ResourceAwareScheduler
- Config - Class in org.apache.storm
-
Topology configs are specified as a plain old map.
- Config() - Constructor for class org.apache.storm.Config
- CONFIG - Enum constant in enum class org.apache.storm.generated.Nimbus.setLogConfig_args._Fields
- CONFIG_KEY_RESOURCES - Static variable in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- configFilter(Server, Servlet, List<FilterConfiguration>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
- configFilter(Server, Servlet, List<FilterConfiguration>, Map<String, String>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Config filter.
- configFilters(ServletContextHandler, List<FilterConfiguration>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Config filters.
- ConfigGetter(String) - Constructor for class org.apache.storm.topology.TopologyBuilder.ConfigGetter
- configKey - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- configKey - Variable in class org.apache.storm.hdfs.trident.HdfsState.Options
- configKey - Variable in class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
- configLoader - Variable in class org.apache.storm.scheduler.multitenant.MultitenantScheduler
- ConfigLoaderFactoryService - Class in org.apache.storm.scheduler.utils
-
The user interface to create a concrete IConfigLoader instance for use.
- ConfigLoaderFactoryService() - Constructor for class org.apache.storm.scheduler.utils.ConfigLoaderFactoryService
- ConfigMethodDef - Class in org.apache.storm.flux.model
- ConfigMethodDef() - Constructor for class org.apache.storm.flux.model.ConfigMethodDef
- Configs - Class in org.apache.storm.hdfs.spout
- Configs() - Constructor for class org.apache.storm.hdfs.spout.Configs
- Configs.ReaderTypeValidator - Class in org.apache.storm.hdfs.spout
- configSsl(Server, Integer, String, String, String, String, String, String, String, Boolean, Boolean, boolean) - Static method in class org.apache.storm.daemon.ui.UIHelpers
- configSsl(Server, Integer, String, String, String, String, String, String, String, Boolean, Boolean, Integer, boolean) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
configSsl.
- ConfigurableTopology - Class in org.apache.storm.topology
-
Extensions of this class takes a reference to one or more configuration files.
- ConfigurableTopology() - Constructor for class org.apache.storm.topology.ConfigurableTopology
- configure(Map<String, Object>, StormMetricsRegistry) - Static method in class org.apache.storm.metricstore.MetricStoreConfig
-
Configures metrics store (running on Nimbus) to use the class specified in the conf.
- configureMetricProcessor(Map) - Static method in class org.apache.storm.metricstore.MetricStoreConfig
-
Configures metric processor (running on supervisor) to use the class specified in the conf.
- ConfigUtils - Class in org.apache.storm.utils
- ConfigUtils() - Constructor for class org.apache.storm.utils.ConfigUtils
- ConfigValidation - Class in org.apache.storm.validation
-
Provides functionality for validating configuration fields.
- ConfigValidation() - Constructor for class org.apache.storm.validation.ConfigValidation
- ConfigValidation.BooleanValidator - Class in org.apache.storm.validation
- ConfigValidation.ClusterMetricRegistryValidator - Class in org.apache.storm.validation
- ConfigValidation.CustomIsExactlyOneOfValidators - Class in org.apache.storm.validation
- ConfigValidation.DerivedTypeValidator - Class in org.apache.storm.validation
-
Checks if the named type derives from the specified Class.
- ConfigValidation.DoubleValidator - Class in org.apache.storm.validation
- ConfigValidation.EventLoggerRegistryValidator - Class in org.apache.storm.validation
- ConfigValidation.ImpersonationAclUserEntryValidator - Class in org.apache.storm.validation
-
Validates an entry for ImpersonationAclUser.
- ConfigValidation.ImplementsClassValidator - Class in org.apache.storm.validation
- ConfigValidation.IntegerValidator - Class in org.apache.storm.validation
-
Validates a Integer.
- ConfigValidation.KryoRegValidator - Class in org.apache.storm.validation
-
Validates Kryo Registration.
- ConfigValidation.ListEntryCustomValidator - Class in org.apache.storm.validation
-
Validates each entry in a list against a list of custom Validators.
- ConfigValidation.ListEntryTypeValidator - Class in org.apache.storm.validation
-
Validates each entry in a list.
- ConfigValidation.ListOfListOfStringValidator - Class in org.apache.storm.validation
-
Validates a list of a list of Strings.
- ConfigValidation.LongValidator - Class in org.apache.storm.validation
-
Validates a Long.
- ConfigValidation.MapEntryCustomValidator - Class in org.apache.storm.validation
-
validates each key and each value against the respective arrays of validators.
- ConfigValidation.MapEntryTypeValidator - Class in org.apache.storm.validation
-
validates each key and value in a map of a certain type.
- ConfigValidation.MapOfStringToMapOfStringToObjectValidator - Class in org.apache.storm.validation
- ConfigValidation.MetricRegistryValidator - Class in org.apache.storm.validation
- ConfigValidation.MetricReportersValidator - Class in org.apache.storm.validation
- ConfigValidation.NoDuplicateInListValidator - Class in org.apache.storm.validation
-
validates a list of has no duplicates.
- ConfigValidation.NotNullValidator - Class in org.apache.storm.validation
-
Validates if an object is not null.
- ConfigValidation.NumberValidator - Class in org.apache.storm.validation
- ConfigValidation.PacemakerAuthTypeValidator - Class in org.apache.storm.validation
- ConfigValidation.PositiveNumberValidator - Class in org.apache.storm.validation
-
Validates a positive number.
- ConfigValidation.PowerOf2Validator - Class in org.apache.storm.validation
-
Validates if a number is a power of 2.
- ConfigValidation.RasConstraintsTypeValidator - Class in org.apache.storm.validation
- ConfigValidation.SimpleTypeValidator - Class in org.apache.storm.validation
-
Validates basic types.
- ConfigValidation.StringOrStringListValidator - Class in org.apache.storm.validation
-
Validates a String or a list of Strings.
- ConfigValidation.StringValidator - Class in org.apache.storm.validation
- ConfigValidation.UserResourcePoolEntryValidator - Class in org.apache.storm.validation
- ConfigValidation.Validator - Class in org.apache.storm.validation
- ConfigValidationAnnotations - Class in org.apache.storm.validation
-
Note: every annotation interface must have method `validatorClass()` For every annotation there must validator class to do the validation To add another annotation for config validation, add another annotation @interface class.
- ConfigValidationAnnotations() - Constructor for class org.apache.storm.validation.ConfigValidationAnnotations
- ConfigValidationAnnotations.CustomValidator - Annotation Interface in org.apache.storm.validation
-
For custom validators.
- ConfigValidationAnnotations.IsBoolean - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsDerivedFrom - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsExactlyOneOf - Annotation Interface in org.apache.storm.validation
-
Custom validator where exactly one of the validations must be successful.
- ConfigValidationAnnotations.IsImplementationOfClass - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsInteger - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsKryoReg - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsListEntryCustom - Annotation Interface in org.apache.storm.validation
-
Validates each entry in a list with a list of validators Validators with fields: validatorClass and entryValidatorClass.
- ConfigValidationAnnotations.IsListEntryType - Annotation Interface in org.apache.storm.validation
-
validates each entry in a list is of a certain type.
- ConfigValidationAnnotations.IsLong - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsMapEntryCustom - Annotation Interface in org.apache.storm.validation
-
Validates a each key and value in a Map with a list of validators Validator with fields: validatorClass, keyValidatorClasses, valueValidatorClasses.
- ConfigValidationAnnotations.IsMapEntryType - Annotation Interface in org.apache.storm.validation
-
Validates the type of each key and value in a map Validator with fields: validatorClass, keyValidatorClass, valueValidatorClass.
- ConfigValidationAnnotations.IsNoDuplicateInList - Annotation Interface in org.apache.storm.validation
-
Validates that there are no duplicates in a list.
- ConfigValidationAnnotations.IsNumber - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsPositiveNumber - Annotation Interface in org.apache.storm.validation
-
Checks if a number is positive and whether zero inclusive Validator with fields: validatorClass, includeZero.
- ConfigValidationAnnotations.IsPowerOf2 - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsString - Annotation Interface in org.apache.storm.validation
-
Validators with fields: validatorClass.
- ConfigValidationAnnotations.IsStringList - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.IsStringOrStringList - Annotation Interface in org.apache.storm.validation
-
Complex/custom type validators.
- ConfigValidationAnnotations.IsType - Annotation Interface in org.apache.storm.validation
-
Validators with fields: validatorClass and type.
- ConfigValidationAnnotations.NotNull - Annotation Interface in org.apache.storm.validation
-
Validates on object is not null.
- ConfigValidationAnnotations.Password - Annotation Interface in org.apache.storm.validation
- ConfigValidationAnnotations.ValidatorParams - Class in org.apache.storm.validation
-
Field names for annotations.
- ConfigValidationUtils - Class in org.apache.storm.validation
- ConfigValidationUtils() - Constructor for class org.apache.storm.validation.ConfigValidationUtils
- ConfigValidationUtils.FieldValidator - Interface in org.apache.storm.validation
-
Declares methods for validating configuration values.
- ConfigValidationUtils.NestableFieldValidator - Class in org.apache.storm.validation
-
Declares a method for validating configuration values that is nestable.
- ConfigValue - Class in org.apache.storm.command
-
Read a value from the topology config map.
- confirmAssigned(int) - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
- confirmAssigned(int) - Method in interface org.apache.storm.scheduler.ISupervisor
- connect(String, String, int, AtomicBoolean[]) - Method in interface org.apache.storm.messaging.IContext
-
This method establish a client side connection to a remote server implementation should return a new connection every call.
- connect(String, String, int, AtomicBoolean[]) - Method in class org.apache.storm.messaging.local.Context
- connect(String, String, int, AtomicBoolean[]) - Method in class org.apache.storm.messaging.netty.Context
-
establish a connection to a remote server.
- connect(Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.multilang.ISerializer
-
This method transmits the Storm config to the non-JVM process and receives its pid.
- connect(Map<String, Object>, TopologyContext) - Method in class org.apache.storm.multilang.JsonSerializer
- connect(TTransport, String, String) - Method in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
- connect(TTransport, String, String) - Method in interface org.apache.storm.security.auth.ITransportPlugin
-
Connect to the specified server via framed transport.
- connect(TTransport, String, String) - Method in class org.apache.storm.security.auth.kerberos.KerberosSaslTransportPlugin
- connect(TTransport, String, String) - Method in class org.apache.storm.security.auth.plain.PlainSaslTransportPlugin
-
Deprecated.
- connect(TTransport, String, String) - Method in class org.apache.storm.security.auth.SimpleTransportPlugin
-
Connect to the specified server via framed transport.
- connect(TTransport, String, String) - Method in class org.apache.storm.security.auth.tls.TlsTransportPlugin
- CONNECT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONNECTED - Enum constant in enum class org.apache.storm.cluster.ConnectionState
- Connecting - Enum constant in enum class org.apache.storm.messaging.ConnectionWithStatus.Status
-
we are establishing a active connection with target host.
- CONNECTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONNECTION_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- connectionFactory() - Method in class org.apache.storm.jms.example.SpringJmsProvider
- connectionFactory() - Method in interface org.apache.storm.jms.JmsProvider
-
Provides the JMS
ConnectionFactory
. - connectionProvider - Variable in class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
- connectionProvider - Variable in class org.apache.storm.jdbc.topology.AbstractUserTopology
- ConnectionProvider - Interface in org.apache.storm.jdbc.common
-
Provides a database connection.
- ConnectionState - Enum Class in org.apache.storm.cluster
- ConnectionWithStatus - Class in org.apache.storm.messaging
- ConnectionWithStatus() - Constructor for class org.apache.storm.messaging.ConnectionWithStatus
- ConnectionWithStatus.Status - Enum Class in org.apache.storm.messaging
- cons(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- cons(Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- ConsList - Class in org.apache.storm.trident.tuple
- ConsList(Object, List<Object>) - Constructor for class org.apache.storm.trident.tuple.ConsList
- ConsolePreparableReporter - Class in org.apache.storm.daemon.metrics.reporters
- ConsolePreparableReporter() - Constructor for class org.apache.storm.daemon.metrics.reporters.ConsolePreparableReporter
- ConsoleStormReporter - Class in org.apache.storm.metrics2.reporters
- ConsoleStormReporter() - Constructor for class org.apache.storm.metrics2.reporters.ConsoleStormReporter
- Constants - Class in org.apache.storm
- Constants() - Constructor for class org.apache.storm.Constants
- ConstBolt() - Constructor for class org.apache.storm.hdfs.spout.HdfsSpoutTopology.ConstBolt
- constraint() - Method in class org.apache.storm.sql.parser.ColumnDefinition
- CONSTRAINT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONSTRAINT_CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONSTRAINT_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONSTRAINT_SCHEMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONSTRAINT_TYPE_INCOMPATIBLE_COMPONENTS - Static variable in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverConfig
- CONSTRAINT_TYPE_INCOMPATIBLE_COMPONENTS - Static variable in class org.apache.storm.validation.ConfigValidation.RasConstraintsTypeValidator
- CONSTRAINT_TYPE_MAX_NODE_CO_LOCATION_CNT - Static variable in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverConfig
- CONSTRAINT_TYPE_MAX_NODE_CO_LOCATION_CNT - Static variable in class org.apache.storm.validation.ConfigValidation.RasConstraintsTypeValidator
- CONSTRAINTS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ConstraintSolverConfig - Class in org.apache.storm.scheduler.resource.strategies.scheduling
-
Component constraint as derived from configuration.
- ConstraintSolverConfig(String, Map<String, Object>, Set<String>) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverConfig
- ConstraintSolverConfig(TopologyDetails) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverConfig
- ConstraintSolverStrategy - Class in org.apache.storm.scheduler.resource.strategies.scheduling
- ConstraintSolverStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy
- construct() - Static method in class org.apache.storm.sql.StormSql
- construct() - Static method in class org.apache.storm.starter.ReachTopology
- CONSTRUCTOR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- constructStreams(URI, String, String, Properties, List<FieldInfo>) - Method in class org.apache.storm.sql.hdfs.HdfsDataSourcesProvider
- constructStreams(URI, String, String, Properties, List<FieldInfo>) - Method in class org.apache.storm.sql.kafka.KafkaDataSourcesProvider
- constructStreams(URI, String, String, Properties, List<FieldInfo>) - Method in class org.apache.storm.sql.redis.RedisDataSourcesProvider
- constructStreams(URI, String, String, Properties, List<FieldInfo>) - Method in class org.apache.storm.sql.runtime.datasource.socket.SocketDataSourcesProvider
- constructStreams(URI, String, String, Properties, List<FieldInfo>) - Method in interface org.apache.storm.sql.runtime.DataSourcesProvider
-
Construct a new data source for streams mode.
- constructStreamsDataSource(URI, String, String, Properties, List<FieldInfo>) - Static method in class org.apache.storm.sql.runtime.DataSourcesRegistry
-
Construct a streams data source.
- ConstSpout - Class in org.apache.storm.perf.spout
- ConstSpout(String) - Constructor for class org.apache.storm.perf.spout.ConstSpout
- ConstSpoutIdBoltNullBoltTopo - Class in org.apache.storm.perf
-
ConstSpout -> IdBolt -> DevNullBolt This topology measures speed of messaging between spouts->bolt and bolt->bolt ConstSpout : Continuously emits a constant string IdBolt : clones and emits input tuples DevNullBolt : discards incoming tuples.
- ConstSpoutIdBoltNullBoltTopo() - Constructor for class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
- ConstSpoutNullBoltTopo - Class in org.apache.storm.perf
-
This topo helps measure the messaging peak throughput between a spout and a bolt.
- ConstSpoutNullBoltTopo() - Constructor for class org.apache.storm.perf.ConstSpoutNullBoltTopo
- ConstSpoutOnlyTopo - Class in org.apache.storm.perf
-
This topo helps measure how fast a spout can produce data (so no bolts are attached).
- ConstSpoutOnlyTopo() - Constructor for class org.apache.storm.perf.ConstSpoutOnlyTopo
- consume(JCQueue.Consumer) - Method in class org.apache.storm.utils.JCQueue
-
Non blocking.
- consume(JCQueue.Consumer, JCQueue.ExitCondition) - Method in class org.apache.storm.utils.JCQueue
-
Non blocking.
- Consumer<T> - Interface in org.apache.storm.streams.operations
-
Represents an operation that accepts a single input argument and returns no result.
- Consumer - Interface in org.apache.storm.trident.operation
-
Represents an operation that accepts a single input argument and returns no result.
- ConsumerExecutor - Class in org.apache.storm.trident.operation.impl
- ConsumerExecutor(Consumer) - Constructor for class org.apache.storm.trident.operation.impl.ConsumerExecutor
- Container - Class in org.apache.storm.daemon.supervisor
-
Represents a container that a worker will run in.
- Container(Container.ContainerType, Map<String, Object>, String, int, int, LocalAssignment, ResourceIsolationInterface, String, Map<String, Object>, AdvancedFSOps, StormMetricsRegistry, ContainerMemoryTracker) - Constructor for class org.apache.storm.daemon.supervisor.Container
-
Create a new Container.
- Container.ContainerType - Enum Class in org.apache.storm.daemon.supervisor
- containerFilePath(String) - Static method in class org.apache.storm.utils.ServerUtils
- ContainerLauncher - Class in org.apache.storm.daemon.supervisor
-
Launches containers.
- ContainerLauncher() - Constructor for class org.apache.storm.daemon.supervisor.ContainerLauncher
- containerMemoryTracker - Variable in class org.apache.storm.daemon.supervisor.Container
- ContainerMemoryTracker - Class in org.apache.storm.daemon.supervisor
- ContainerMemoryTracker(StormMetricsRegistry) - Constructor for class org.apache.storm.daemon.supervisor.ContainerMemoryTracker
- ContainerRecoveryException - Exception in org.apache.storm.daemon.supervisor
-
Could not recover the container.
- ContainerRecoveryException(String) - Constructor for exception org.apache.storm.daemon.supervisor.ContainerRecoveryException
- contains(Integer) - Method in interface org.apache.storm.metricstore.rocksdb.ReadOnlyStringMetadataCache
-
Determines if a string Id is contained in the cache.
- contains(Integer) - Method in class org.apache.storm.metricstore.rocksdb.StringMetadataCache
-
Determines if a string Id is contained in the cache.
- contains(Object) - Method in class org.apache.storm.utils.ListDelegate
- contains(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- contains(String) - Method in class org.apache.storm.tuple.Fields
-
Check contains.
- contains(String) - Method in interface org.apache.storm.tuple.ITuple
-
Returns true if this tuple contains the specified name of the field.
- contains(String) - Method in class org.apache.storm.tuple.TupleImpl
- contains(KafkaSpoutMessageId) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
- CONTAINS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- containsAll(Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
- containsKey(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- containsKey(Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- containsKey(K) - Method in class org.apache.storm.utils.RotatingMap
- containsKey(K) - Method in class org.apache.storm.utils.TimeCacheMap
-
Deprecated.
- containsValue(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- containsValue(Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- context - Variable in class org.apache.storm.streams.processors.MapValuesProcessor
- context() - Static method in class org.apache.storm.security.auth.ReqContext
-
Get context.
- Context - Class in org.apache.storm.messaging.local
- Context - Class in org.apache.storm.messaging.netty
- Context() - Constructor for class org.apache.storm.messaging.local.Context
- Context() - Constructor for class org.apache.storm.messaging.netty.Context
- ContextVariable() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- CONTINUE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CONTROL_MESSAGE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- ControlMessage - Enum Class in org.apache.storm.messaging.netty
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsAggregateRule
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsCalcRule
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsFilterRule
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsJoinRule
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsModifyRule
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsProjectRule
- convert(RelNode) - Method in class org.apache.storm.sql.planner.streams.rules.StreamsScanRule
- CONVERT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- convertAvroUtf8(Object) - Static method in class org.apache.storm.sql.runtime.utils.SerdeUtils
-
Convert a Avro object to a Java object, changing the Avro Utf8 type to Java String.
- convertExecutor(List<Long>) - Static method in class org.apache.storm.stats.ClientStatsUtil
-
Convert a List<Long> executor to java List<Integer>.
- convertExecutorBeats(List<ExecutorInfo>, ClusterWorkerHeartbeat) - Static method in class org.apache.storm.cluster.ClusterUtils
-
Ensures that we only return heartbeats for executors assigned to this worker.
- convertExecutorBeats(Map<ExecutorInfo, ExecutorBeat>) - Static method in class org.apache.storm.stats.StatsUtil
-
convert thrift executor heartbeats into a java HashMap.
- convertExecutorsStats(Map<ExecutorInfo, ExecutorStats>) - Static method in class org.apache.storm.stats.StatsUtil
-
convert executors stats into a HashMap, note that ExecutorStats are remained unchanged.
- convertExecutorStats(ExecutorStats) - Static method in class org.apache.storm.stats.StatsUtil
-
convert thrift ExecutorStats structure into a java HashMap.
- convertExecutorZkHbs(Map<List<Long>, ExecutorStats>) - Static method in class org.apache.storm.stats.ClientStatsUtil
-
Convert Long Executor Ids in ZkHbs to Integer ones structure to java maps.
- convertFileSetToFiles(FileSet) - Static method in class org.apache.storm.maven.plugin.versioninfo.VersionInfoMojo
- convertToArray(Map<Integer, V>, int) - Static method in class org.apache.storm.utils.Utils
- convertWorkerBeats(SupervisorWorkerHeartbeat) - Static method in class org.apache.storm.stats.StatsUtil
-
convert
SupervisorWorkerHeartbeat
to nimbus local report executor heartbeats. - convertZkExecutorHb(ExecutorBeat) - Static method in class org.apache.storm.stats.StatsUtil
-
convert thrift ExecutorBeat into a java HashMap.
- convertZkWorkerHb(ClusterWorkerHeartbeat) - Static method in class org.apache.storm.stats.StatsUtil
-
convert a thrift worker heartbeat into a java HashMap.
- COORD_STREAM_PREFIX - Static variable in class org.apache.storm.trident.topology.TridentBoltExecutor
- CoordCondition() - Constructor for class org.apache.storm.trident.topology.TridentBoltExecutor.CoordCondition
- COORDINATED_STREAM_ID - Static variable in class org.apache.storm.Constants
- CoordinatedBolt - Class in org.apache.storm.coordination
-
Coordination requires the request ids to be globally unique for awhile.
- CoordinatedBolt(IRichBolt) - Constructor for class org.apache.storm.coordination.CoordinatedBolt
- CoordinatedBolt(IRichBolt, String, CoordinatedBolt.SourceArgs, CoordinatedBolt.IdStreamSpec) - Constructor for class org.apache.storm.coordination.CoordinatedBolt
- CoordinatedBolt(IRichBolt, Map<String, CoordinatedBolt.SourceArgs>, CoordinatedBolt.IdStreamSpec) - Constructor for class org.apache.storm.coordination.CoordinatedBolt
- CoordinatedBolt.CoordinatedOutputCollector - Class in org.apache.storm.coordination
- CoordinatedBolt.FinishedCallback - Interface in org.apache.storm.coordination
- CoordinatedBolt.IdStreamSpec - Class in org.apache.storm.coordination
- CoordinatedBolt.SourceArgs - Class in org.apache.storm.coordination
- CoordinatedBolt.TimeoutCallback - Interface in org.apache.storm.coordination
- CoordinatedBolt.TrackingInfo - Class in org.apache.storm.coordination
- CoordinatedOutputCollector(IOutputCollector) - Constructor for class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
- Coordinator(Map<String, Object>, TopologyContext) - Constructor for class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Coordinator
- coords - Variable in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordSpec
- CoordSpec() - Constructor for class org.apache.storm.trident.topology.TridentBoltExecutor.CoordSpec
- coordStream(String) - Static method in class org.apache.storm.trident.topology.TridentBoltExecutor
- CoordType(boolean) - Constructor for class org.apache.storm.trident.topology.TridentBoltExecutor.CoordType
- copy() - Method in interface org.apache.storm.hdfs.bolt.rotation.FileRotationPolicy
-
Must be able to copy the rotation policy.
- copy() - Method in class org.apache.storm.hdfs.bolt.rotation.FileSizeRotationPolicy
- copy() - Method in class org.apache.storm.hdfs.bolt.rotation.NoRotationPolicy
- copy() - Method in class org.apache.storm.hdfs.bolt.rotation.TimedRotationPolicy
- copy() - Method in interface org.apache.storm.starter.tools.Rankable
-
Note: We do not defensively copy the object wrapped by the Rankable.
- copy() - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
-
Note: We do not defensively copy the wrapped object and any accompanying fields.
- copy() - Method in class org.apache.storm.starter.tools.Rankings
-
Creates a (defensive) copy of itself.
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.storm.sql.planner.streams.rel.StreamsStreamInsertRel
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.storm.sql.planner.streams.rel.StreamsProjectRel
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.storm.sql.planner.streams.rel.StreamsFilterRel
- copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.storm.sql.planner.streams.rel.StreamsCalcRel
- copyBlobStoreKeys(BlobStore, Subject, BlobStore, Subject) - Static method in class org.apache.storm.blobstore.MigrateBlobs
- copyDirectory(File, File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Copy a directory.
- copyDirectory(File, File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Copy a directory.
- core - Variable in class org.apache.storm.metrics2.cgroup.CGroupMetricsBase
- CORR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CORRESPONDING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- corsFilterHandle() - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
corsFilterHandle.
- couldEverFit(ExecutorDetails, TopologyDetails) - Method in class org.apache.storm.scheduler.resource.RasNode
-
Is there any possibility that exec could ever fit on this node.
- couldFit(double, NormalizedResourceRequest) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
-
Is there any possibility that a resource request could ever fit on this.
- couldHoldIgnoringSharedMemory(NormalizedResources, double, double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
A simple sanity check to see if all of the resources in this would be large enough to hold the resources in other ignoring memory.
- couldHoldIgnoringSharedMemory(NormalizedResourcesWithMemory) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
-
Check if resources might be able to fit.
- couldHoldIgnoringSharedMemoryAndCpu(NormalizedResources, double, double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
A simple sanity check to see if all of the resources in this would be large enough to hold the resources in other ignoring memory.
- couldHoldIgnoringSharedMemoryAndCpu(NormalizedResourcesWithMemory) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- count - Variable in class org.apache.storm.loadgen.SlowExecutorPattern
- count() - Method in class org.apache.storm.clojure.ClojureTuple
- count() - Method in class org.apache.storm.clojure.IndifferentAccessMap
- count() - Method in class org.apache.storm.streams.Stream
-
Counts the number of values in this stream.
- Count<T> - Class in org.apache.storm.streams.operations.aggregators
-
Computes the count of values.
- Count - Class in org.apache.storm.trident.operation.builtin
- Count() - Constructor for class org.apache.storm.streams.operations.aggregators.Count
- Count() - Constructor for class org.apache.storm.trident.operation.builtin.Count
- Count(int) - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt.Count
- COUNT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COUNT_ID - Static variable in class org.apache.storm.perf.FileReadWordCountTopo
- COUNT_ID - Static variable in class org.apache.storm.perf.SimplifiedWordCountTopo
- COUNT_NUM - Static variable in class org.apache.storm.perf.FileReadWordCountTopo
- CountAggregator() - Constructor for class org.apache.storm.starter.ReachTopology.CountAggregator
- CountAsAggregator - Class in org.apache.storm.trident.testing
- CountAsAggregator() - Constructor for class org.apache.storm.trident.testing.CountAsAggregator
- CountBolt - Class in org.apache.storm.perf.bolt
- CountBolt() - Constructor for class org.apache.storm.perf.bolt.CountBolt
- countByKey() - Method in class org.apache.storm.streams.PairStream
-
Counts the values for each key of this stream.
- countDown() - Method in class org.apache.storm.localizer.GoodToGo.GoodToGoLatch
- counter(String, String, Integer) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- counter(String, String, String, Integer, Integer, String) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- counter(String, TopologyContext) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- counter(String, WorkerTopologyContext, String, Integer, String) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- CountEvictionPolicy<T> - Class in org.apache.storm.windowing
-
An eviction policy that tracks event counts and can evict based on a threshold count.
- CountEvictionPolicy(int) - Constructor for class org.apache.storm.windowing.CountEvictionPolicy
- countFreeSlotsAlive(Collection<Node>) - Static method in class org.apache.storm.scheduler.multitenant.Node
- CountMetric - Class in org.apache.storm.metric.api
- CountMetric() - Constructor for class org.apache.storm.metric.api.CountMetric
- CountShellMetric - Class in org.apache.storm.metric.api.rpc
- CountShellMetric() - Constructor for class org.apache.storm.metric.api.rpc.CountShellMetric
- countSlotsUsed(String, Collection<Node>) - Static method in class org.apache.storm.scheduler.multitenant.Node
- countSlotsUsed(Collection<Node>) - Static method in class org.apache.storm.scheduler.multitenant.Node
- CountStat - Class in org.apache.storm.metric.internal
-
Keeps track of approximate counts for the last 10 mins, 3 hours, 1 day, and all time.
- CountStat(int) - Constructor for class org.apache.storm.metric.internal.CountStat
-
Constructor.
- CountSyncPolicy - Class in org.apache.storm.hdfs.bolt.sync
-
SyncPolicy implementation that will trigger a file system sync after a certain number of tuples have been processed.
- CountSyncPolicy - Class in org.apache.storm.hdfs.trident.sync
-
SyncPolicy implementation that will trigger a file system sync after a certain number of tuples have been processed.
- CountSyncPolicy(int) - Constructor for class org.apache.storm.hdfs.bolt.sync.CountSyncPolicy
- CountSyncPolicy(int) - Constructor for class org.apache.storm.hdfs.trident.sync.CountSyncPolicy
- countTotalSlotsAlive(Collection<Node>) - Static method in class org.apache.storm.scheduler.multitenant.Node
- CountTriggerPolicy<T> - Class in org.apache.storm.windowing
-
A trigger that tracks event counts and calls back
TriggerHandler.onTrigger()
when the count threshold is hit. - CountTriggerPolicy(int, TriggerHandler, EvictionPolicy<T, ?>) - Constructor for class org.apache.storm.windowing.CountTriggerPolicy
- COVAR_POP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- COVAR_SAMP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- cpu - Enum constant in enum class org.apache.storm.container.cgroup.SubSystemType
- CPU - Enum constant in enum class org.apache.storm.generated.WorkerResources._Fields
- CPU_CFS_PERIOD_US - Static variable in class org.apache.storm.container.cgroup.core.CpuCore
- CPU_CFS_QUOTA_US - Static variable in class org.apache.storm.container.cgroup.core.CpuCore
- CPU_GUARANTEE - Enum constant in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- CPU_GUARANTEE_REMAINING - Enum constant in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- CPU_RT_PERIOD_US - Static variable in class org.apache.storm.container.cgroup.core.CpuCore
- CPU_RT_RUNTIME_US - Static variable in class org.apache.storm.container.cgroup.core.CpuCore
- CPU_SHARES - Static variable in class org.apache.storm.container.cgroup.core.CpuCore
- CPU_STAT - Static variable in class org.apache.storm.container.cgroup.core.CpuCore
- CPU_USAGE - Enum constant in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- cpuacct - Enum constant in enum class org.apache.storm.container.cgroup.SubSystemType
- CPUACCT_STAT - Static variable in class org.apache.storm.container.cgroup.core.CpuacctCore
- CPUACCT_USAGE - Static variable in class org.apache.storm.container.cgroup.core.CpuacctCore
- CPUACCT_USAGE_PERCPU - Static variable in class org.apache.storm.container.cgroup.core.CpuacctCore
- CpuacctCore - Class in org.apache.storm.container.cgroup.core
- CpuacctCore(String) - Constructor for class org.apache.storm.container.cgroup.core.CpuacctCore
- CpuacctCore.StatType - Enum Class in org.apache.storm.container.cgroup.core
- CpuCore - Class in org.apache.storm.container.cgroup.core
- CpuCore(String) - Constructor for class org.apache.storm.container.cgroup.core.CpuCore
- CpuCore.Stat - Class in org.apache.storm.container.cgroup.core
- cpuLoad - Variable in class org.apache.storm.loadgen.LoadCompConf
- CPUMetric - Class in org.apache.storm.metrics.sigar
-
A metric using Sigar to get User and System CPU utilization for a worker.
- CPUMetric() - Constructor for class org.apache.storm.metrics.sigar.CPUMetric
- cpuset - Enum constant in enum class org.apache.storm.container.cgroup.SubSystemType
- CPUSET_CPU_EXCLUSIVE - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_CPUS - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEM_EXCLUSIVE - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEM_HARDWALL - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEMORY_MIGRATE - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEMORY_PRESSURE - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEMORY_PRESSURE_ENABLED - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEMORY_SPREAD_PAGE - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEMORY_SPREAD_SLAB - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_MEMS - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_SCHED_LOAD_BALANCE - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CPUSET_SCHED_RELAX_DOMAIN_LEVEL - Static variable in class org.apache.storm.container.cgroup.core.CpusetCore
- CpusetCore - Class in org.apache.storm.container.cgroup.core
- CpusetCore(String) - Constructor for class org.apache.storm.container.cgroup.core.CpusetCore
- CRC32OutputStream - Class in org.apache.storm.utils
- CRC32OutputStream() - Constructor for class org.apache.storm.utils.CRC32OutputStream
- create(Kryo, Input, Class<? extends ArrayList>, int) - Method in class org.apache.storm.serialization.types.ArrayListSerializer
- create(Kryo, Input, Class<? extends HashMap>, int) - Method in class org.apache.storm.serialization.types.HashMapSerializer
- create(Kryo, Input, Class<? extends HashSet>, int) - Method in class org.apache.storm.serialization.types.HashSetSerializer
- create(Kryo, Input, Class<? extends ListDelegate>, int) - Method in class org.apache.storm.serialization.types.ListDelegateSerializer
- create(List[]) - Method in class org.apache.storm.trident.tuple.ComboList.Factory
- create(List<Object>) - Method in class org.apache.storm.trident.tuple.TridentTupleView.FreshOutputFactory
- create(Map<String, Object>) - Method in class org.apache.storm.trident.windowing.InMemoryWindowsStoreFactory
- create(Map<String, Object>) - Method in interface org.apache.storm.trident.windowing.WindowsStoreFactory
-
Creates a window store.
- create(ILeaderElector) - Method in class org.apache.storm.zookeeper.LeaderListenerCallbackFactory
- create(TridentTuple) - Method in class org.apache.storm.trident.tuple.TridentTupleView.ProjectionFactory
- create(TridentTupleView, List<Object>) - Method in class org.apache.storm.trident.tuple.TridentTupleView.OperationOutputFactory
- create(Tuple) - Method in class org.apache.storm.trident.tuple.TridentTupleView.RootFactory
- CREATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CREATE_PATH - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- CREATE_PATH_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- create_sequential(String, byte[], List<ACL>) - Method in interface org.apache.storm.cluster.IStateStorage
-
Path will be appended with a monotonically increasing integer, a new node will be created there, and data will be put at that node.
- create_sequential(String, byte[], List<ACL>) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- create_sequential(String, byte[], List<ACL>) - Method in class org.apache.storm.cluster.ZKStateStorage
- createAdmin(Map<String, Object>) - Method in interface org.apache.storm.kafka.spout.internal.ClientFactory
- createAdmin(Map<String, Object>) - Method in class org.apache.storm.kafka.spout.internal.ClientFactoryDefault
- createArtifactsLink() - Method in class org.apache.storm.daemon.supervisor.Container
-
Create symlink from the containers directory/artifacts to the artifacts directory.
- createArtifactsLink() - Method in class org.apache.storm.daemon.supervisor.LocalContainer
- createAssignment(List<Integer>, byte[]) - Method in interface org.apache.storm.grouping.PartialKeyGrouping.AssignmentCreator
- createAssignment(List<Integer>, byte[]) - Method in class org.apache.storm.grouping.PartialKeyGrouping.RandomTwoTaskAssignmentCreator
-
Creates a two task assignment by selecting random tasks.
- createBackPressureWaitStrategy(Map<String, Object>) - Static method in interface org.apache.storm.policy.IWaitStrategy
- createBlob(String, byte[], SettableBlobMeta, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Wrapper called to create the blob which contains the byte data.
- createBlob(String, InputStream, SettableBlobMeta, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Wrapper called to create the blob which contains the byte data.
- createBlob(String, SettableBlobMeta) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to create a blob.
- createBlob(String, SettableBlobMeta, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Creates the blob.
- createBlob(String, SettableBlobMeta, Subject) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- createBlob(String, SettableBlobMeta, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- createBlobstoreLinks() - Method in class org.apache.storm.daemon.supervisor.Container
-
Create symlinks for each of the blobs from the container's directory to corresponding links in the storm dist directory.
- createBlobstoreLinks() - Method in class org.apache.storm.daemon.supervisor.LocalContainer
- createBlobToExtend(String, SettableBlobMeta) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to create a blob.
- createBlobToExtend(String, SettableBlobMeta) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- createBlobToExtend(String, SettableBlobMeta) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- createBlobToExtend(String, SettableBlobMeta) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- createCgroup(CgroupCommon) - Method in class org.apache.storm.container.cgroup.CgroupCenter
- createCgroup(CgroupCommon) - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
create a cgroup.
- createConfigLoader(Map<String, Object>) - Static method in class org.apache.storm.scheduler.utils.ConfigLoaderFactoryService
-
The user interface to create an IConfigLoader instance.
- createConsumer(Map<String, Object>) - Method in interface org.apache.storm.kafka.spout.internal.ClientFactory
- createConsumer(Map<String, Object>) - Method in class org.apache.storm.kafka.spout.internal.ClientFactoryDefault
- createDefaultUncaughtExceptionHandler() - Static method in class org.apache.storm.utils.Utils
- createEdge(Object, Object) - Method in class org.apache.storm.trident.util.ErrorEdgeFactory
- createExclusion(String) - Static method in class org.apache.storm.submit.dependency.AetherUtils
-
Parses exclusion parameter and build
Exclusion
object. - createFile(String) - Static method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology
- createFlushTuple(GeneralTopologyContext) - Static method in class org.apache.storm.tuple.AddressedTuple
- createFreshTuple(Fields, Object...) - Static method in class org.apache.storm.trident.tuple.TridentTupleView
- createFreshTuple(Fields, List<Object>) - Static method in class org.apache.storm.trident.tuple.TridentTupleView
- createHostToSupervisorMap(List<String>, Cluster) - Method in class org.apache.storm.scheduler.blacklist.strategies.DefaultBlacklistStrategy
- createIfSupported(URI, Map<String, Object>) - Method in class org.apache.storm.scheduler.utils.ArtifactoryConfigLoaderFactory
-
Create a ArtifactoryConfigLoader if the scheme of the URI is "artifactory+http" or "artifactory+https"; otherwise return null.
- createIfSupported(URI, Map<String, Object>) - Method in class org.apache.storm.scheduler.utils.FileConfigLoaderFactory
-
Create a FileConfigLoader if the scheme of the URI is "file"; else return null.
- createIfSupported(URI, Map<String, Object>) - Method in interface org.apache.storm.scheduler.utils.IConfigLoaderFactory
-
Create an IConfigLoader implementation if the scheme of the URI is supported; otherwise returns null.
- createKeyManager(KeyStore, String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- createLocalTopology(ILocalDRPC) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
- createNewWorkerId() - Method in class org.apache.storm.daemon.supervisor.BasicContainer
-
Create a new worker ID for this process and store in in this object and in the local state.
- createNode(CuratorFramework, String, byte[], List<ACL>) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- createNode(CuratorFramework, String, byte[], List<ACL>, CreateMode) - Static method in class org.apache.storm.trident.topology.state.TestTransactionalState
- createNode(CuratorFramework, String, byte[], List<ACL>, CreateMode) - Static method in class org.apache.storm.trident.topology.state.TransactionalState
- createNode(CuratorFramework, String, byte[], CreateMode, List<ACL>) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- createOrUpdateTokenFor(WorkerTokenServiceType, String, String) - Method in class org.apache.storm.security.auth.workertoken.WorkerTokenManager
-
Create or update an existing key.
- createRemoteTopology() - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.storm.security.auth.plain.SaslPlainServer.SaslPlainServerFactory
-
Deprecated.
- createScalarInstance(List<RexNode>, RelDataType, String) - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- createScalarInstance(RexProgram, String) - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- createSchedulingResult(boolean, String) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- createSslContext(Map<String, Object>, boolean) - Static method in class org.apache.storm.messaging.netty.NettyTlsUtils
- createStateInZookeeper() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.createStateInZookeeper
- createStateInZookeeper() - Constructor for class org.apache.storm.generated.Nimbus.Processor.createStateInZookeeper
- createStateInZookeeper(String) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Creates state inside a zookeeper.
- createStateInZookeeper(String) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- createStateInZookeeper(String) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- createStateInZookeeper(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- createStateInZookeeper(String) - Method in class org.apache.storm.generated.Nimbus.Client
- createStateInZookeeper(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- createStateInZookeeper(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- createStateInZookeeper(String) - Method in class org.apache.storm.LocalCluster
- createStateInZookeeper(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- createStateInZookeeper(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- createStateInZookeeper(Map<String, Object>, String, NimbusInfo) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- createStateInZookeeper_args() - Constructor for class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- createStateInZookeeper_args(String) - Constructor for class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- createStateInZookeeper_args(Nimbus.createStateInZookeeper_args) - Constructor for class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
-
Performs a deep copy on other.
- createStateInZookeeper_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.createStateInZookeeper_call
- createStateInZookeeper_result() - Constructor for class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- createStateInZookeeper_result(Nimbus.createStateInZookeeper_result) - Constructor for class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
-
Performs a deep copy on other.
- createSupervisorClient() - Method in class org.apache.storm.utils.SupervisorClient.Builder
- createSymlink(File, File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Create a symbolic link pointing at target.
- createSymlink(File, File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Create a symbolic link pointing at target.
- createTopology() - Method in class org.apache.storm.topology.TopologyBuilder
- createTrustManager(String, String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- createVersion() - Method in class org.apache.storm.utils.VersionedStore
- createVersion(long) - Method in class org.apache.storm.utils.VersionedStore
- createWorkerUncaughtExceptionHandler() - Static method in class org.apache.storm.utils.Utils
- createZKClient(Map<String, Object>, DaemonType) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- creationIndex - Variable in class org.apache.storm.trident.planner.Node
- CredentialKeyProvider - Interface in org.apache.storm.common
-
Provider interface for credential key.
- credentials - Variable in class org.apache.storm.executor.Executor
- credentials(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
- credentials(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- Credentials - Class in org.apache.storm.generated
- Credentials() - Constructor for class org.apache.storm.generated.Credentials
- Credentials(Map<String, String>) - Constructor for class org.apache.storm.generated.Credentials
- Credentials(Credentials) - Constructor for class org.apache.storm.generated.Credentials
-
Performs a deep copy on other.
- CREDENTIALS_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
- CREDENTIALS_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
- Credentials._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- credentialsChanged(Credentials) - Method in class org.apache.storm.executor.ExecutorShutdown
- credentialsChanged(Credentials) - Method in interface org.apache.storm.executor.IRunningExecutor
- credentialsPath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
- CREDS - Enum constant in enum class org.apache.storm.generated.Credentials._Fields
- CREDS - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_args._Fields
- CREDS - Enum constant in enum class org.apache.storm.generated.SubmitOptions._Fields
- CROSS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CSV_LOG_DIR - Static variable in class org.apache.storm.metrics2.reporters.CsvStormReporter
- CsvPreparableReporter - Class in org.apache.storm.daemon.metrics.reporters
- CsvPreparableReporter() - Constructor for class org.apache.storm.daemon.metrics.reporters.CsvPreparableReporter
- CsvScheme - Class in org.apache.storm.sql.runtime.serde.csv
-
CsvScheme uses the standard RFC4180 CSV Parser One of the difference from Tsv format is that fields with embedded commas will be quoted.
- CsvScheme(List<String>) - Constructor for class org.apache.storm.sql.runtime.serde.csv.CsvScheme
- CsvSerializer - Class in org.apache.storm.sql.runtime.serde.csv
-
CsvSerializer uses the standard RFC4180 CSV Parser One of the difference from Tsv format is that fields with embedded commas will be quoted.
- CsvSerializer(List<String>) - Constructor for class org.apache.storm.sql.runtime.serde.csv.CsvSerializer
- CsvStormReporter - Class in org.apache.storm.metrics2.reporters
- CsvStormReporter() - Constructor for class org.apache.storm.metrics2.reporters.CsvStormReporter
- CUBE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CUME_DIST - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CuratorUtils - Class in org.apache.storm.utils
- CuratorUtils() - Constructor for class org.apache.storm.utils.CuratorUtils
- curChar - Variable in class org.apache.storm.sql.parser.impl.StormParserImplTokenManager
- CURRENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_DATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_DEFAULT_TRANSFORM_GROUP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_PATH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_ROLE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_ROW - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_SCHEMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_TIME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_TIMESTAMP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_TRANSFORM_GROUP_FOR_TYPE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURRENT_USER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- currentClasspath() - Static method in class org.apache.storm.utils.ServerUtils
-
Returns the value of java.class.path System property.
- currentClasspathImpl() - Method in class org.apache.storm.utils.ServerUtils
- currentCount - Variable in class org.apache.storm.windowing.CountEvictionPolicy
- currentCount - Variable in class org.apache.storm.windowing.WatermarkCountEvictionPolicy
- currentExec() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Get the current unassigned executor.
- currentRecord - Variable in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
- currentTimeMillis() - Static method in class org.apache.storm.utils.Time
- currentTimeSecs() - Static method in class org.apache.storm.utils.Time
- currentToken - Variable in exception org.apache.storm.sql.parser.impl.ParseException
-
This is the last token that has been consumed successfully.
- currGroup - Variable in class org.apache.storm.trident.operation.impl.GroupCollector
- CURSOR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CURSOR_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- CursorExpression(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a CURSOR(query) expression.
- CUSTOM - Enum constant in enum class org.apache.storm.flux.model.GroupingDef.Type
- custom_object(JavaObject) - Static method in class org.apache.storm.generated.Grouping
- CUSTOM_OBJECT - Enum constant in enum class org.apache.storm.generated.Grouping._Fields
- custom_serialized(byte[]) - Static method in class org.apache.storm.generated.Grouping
- custom_serialized(ByteBuffer) - Static method in class org.apache.storm.generated.Grouping
- CUSTOM_SERIALIZED - Enum constant in enum class org.apache.storm.generated.Grouping._Fields
- customGrouping(String, String, CustomStreamGrouping) - Method in interface org.apache.storm.topology.InputDeclarer
-
A custom stream grouping by implementing the CustomStreamGrouping interface.
- customGrouping(String, String, CustomStreamGrouping) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- customGrouping(String, CustomStreamGrouping) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- customGrouping(String, CustomStreamGrouping) - Method in interface org.apache.storm.topology.InputDeclarer
-
A custom stream grouping by implementing the CustomStreamGrouping interface.
- customGrouping(String, CustomStreamGrouping) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- customGrouping(CustomStreamGrouping) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- CustomIsExactlyOneOfValidators(Map<String, Object>) - Constructor for class org.apache.storm.validation.ConfigValidation.CustomIsExactlyOneOfValidators
- CustomStreamGrouping - Interface in org.apache.storm.grouping
- CYCLE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
D
- DaemonCommon - Interface in org.apache.storm.daemon
- DaemonConfig - Class in org.apache.storm
-
Storm configs are specified as a plain old map.
- DaemonConfig() - Constructor for class org.apache.storm.DaemonConfig
- DaemonConfigValidation - Class in org.apache.storm.utils
- DaemonConfigValidation() - Constructor for class org.apache.storm.utils.DaemonConfigValidation
- DaemonConfigValidation.NumaEntryValidator - Class in org.apache.storm.utils
- daemonLog(HttpServletRequest) - Method in class org.apache.storm.daemon.logviewer.webapp.LogviewerResource
-
Handles '/daemonlog' request.
- daemonLogPage(String, Integer, Integer, String, String) - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogPageHandler
-
Provides a daemon log file to view.
- DaemonType - Enum Class in org.apache.storm.cluster
-
The type of process/daemon that this server is running as.
- DATA - Enum constant in enum class org.apache.storm.generated.HBMessage._Fields
- DATA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DATA_SIZE - Enum constant in enum class org.apache.storm.generated.BeginDownloadResult._Fields
- DATABASE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- dataContext - Variable in class org.apache.storm.sql.AbstractStreamsProcessor
- DataPoint - Class in org.apache.storm.metric.api
- DataPoint() - Constructor for class org.apache.storm.metric.api.DataPoint
- DataPoint() - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
- DataPoint(String, Object) - Constructor for class org.apache.storm.metric.api.DataPoint
- DataPoint(String, Object) - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
- DataPoint(String, Object, Map<String, String>) - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
- DataPointExpander - Class in org.apache.storm.metric.util
- DataPointExpander(boolean, String) - Constructor for class org.apache.storm.metric.util.DataPointExpander
- DataSourcesProvider - Interface in org.apache.storm.sql.runtime
- DataSourcesRegistry - Class in org.apache.storm.sql.runtime
- dataType - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
- dataType - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateUpdater
- DataType() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- dataTypeDescription - Variable in class org.apache.storm.redis.trident.state.Options
- DATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DATETIME_INTERVAL_CODE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DATETIME_INTERVAL_PRECISION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DateTimeLiteral() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a date/time literal.
- DAY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- days(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
-
Returns a
BaseWindowedBolt.Duration
corresponding to the the given value in days. - DAYS - Enum constant in enum class org.apache.storm.hdfs.bolt.rotation.TimedRotationPolicy.TimeUnit
- DAYS - Enum constant in enum class org.apache.storm.hdfs.trident.rotation.TimedRotationPolicy.TimeUnit
- deactivate() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.deactivate
- deactivate() - Constructor for class org.apache.storm.generated.Nimbus.Processor.deactivate
- deactivate() - Method in class org.apache.storm.clojure.ClojureSpout
- deactivate() - Method in class org.apache.storm.jdbc.spout.UserSpout
- deactivate() - Method in class org.apache.storm.kafka.spout.KafkaSpout
- deactivate() - Method in class org.apache.storm.redis.topology.WordSpout
- deactivate() - Method in interface org.apache.storm.spout.ISpout
-
Called when a spout has been deactivated.
- deactivate() - Method in class org.apache.storm.spout.ShellSpout
- deactivate() - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- deactivate() - Method in class org.apache.storm.testing.FixedTupleSpout
- deactivate() - Method in class org.apache.storm.topology.base.BaseRichSpout
- deactivate() - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- deactivate() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- deactivate(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- deactivate(String) - Method in class org.apache.storm.generated.Nimbus.Client
- deactivate(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- deactivate(String) - Method in interface org.apache.storm.ILocalCluster
-
Deactivate a topology.
- deactivate(String) - Method in class org.apache.storm.LocalCluster
- deactivate(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- deactivate(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- Deactivate - Class in org.apache.storm.command
- Deactivate() - Constructor for class org.apache.storm.command.Deactivate
- deactivate_args() - Constructor for class org.apache.storm.generated.Nimbus.deactivate_args
- deactivate_args(String) - Constructor for class org.apache.storm.generated.Nimbus.deactivate_args
- deactivate_args(Nimbus.deactivate_args) - Constructor for class org.apache.storm.generated.Nimbus.deactivate_args
-
Performs a deep copy on other.
- deactivate_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.deactivate_call
- deactivate_result() - Constructor for class org.apache.storm.generated.Nimbus.deactivate_result
- deactivate_result(Nimbus.deactivate_result) - Constructor for class org.apache.storm.generated.Nimbus.deactivate_result
-
Performs a deep copy on other.
- deactivate_result(NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.deactivate_result
- DEALLOCATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- debug() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.debug
- debug() - Constructor for class org.apache.storm.generated.Nimbus.Processor.debug
- debug(String, String, boolean, double) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- debug(String, String, boolean, double) - Method in class org.apache.storm.generated.Nimbus.Client
- debug(String, String, boolean, double) - Method in interface org.apache.storm.generated.Nimbus.Iface
-
Enable/disable logging the tuples generated in topology via an internal EventLogger bolt.
- debug(String, String, boolean, double) - Method in class org.apache.storm.LocalCluster
- debug(String, String, boolean, double, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- debug(String, String, boolean, double, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- Debug - Class in org.apache.storm.trident.operation.builtin
-
Filter for debugging purposes.
- Debug() - Constructor for class org.apache.storm.trident.operation.builtin.Debug
- Debug(boolean) - Constructor for class org.apache.storm.trident.operation.builtin.Debug
- Debug(String) - Constructor for class org.apache.storm.trident.operation.builtin.Debug
-
Creates a `Debug` filter with a string identifier.
- DEBUG - Enum constant in enum class org.apache.storm.multilang.ShellMsg.ShellLogLevel
- debug_args() - Constructor for class org.apache.storm.generated.Nimbus.debug_args
- debug_args(String, String, boolean, double) - Constructor for class org.apache.storm.generated.Nimbus.debug_args
- debug_args(Nimbus.debug_args) - Constructor for class org.apache.storm.generated.Nimbus.debug_args
-
Performs a deep copy on other.
- debug_call(String, String, boolean, double, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.debug_call
- DEBUG_OPTIONS - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- DEBUG_OPTIONS - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- debug_result() - Constructor for class org.apache.storm.generated.Nimbus.debug_result
- debug_result(Nimbus.debug_result) - Constructor for class org.apache.storm.generated.Nimbus.debug_result
-
Performs a deep copy on other.
- debug_result(NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.debug_result
- DebuggableExecutableExpression - Class in org.apache.storm.sql.runtime.calcite
- DebuggableExecutableExpression(ExecutableExpression, String) - Constructor for class org.apache.storm.sql.runtime.calcite.DebuggableExecutableExpression
- DebugHelper - Class in org.apache.storm.debug
- DebugHelper() - Constructor for class org.apache.storm.debug.DebugHelper
- DebugMemoryMapState<T> - Class in org.apache.storm.starter.trident
- DebugMemoryMapState(String) - Constructor for class org.apache.storm.starter.trident.DebugMemoryMapState
- DebugMemoryMapState.Factory - Class in org.apache.storm.starter.trident
- DebugOptions - Class in org.apache.storm.generated
- DebugOptions() - Constructor for class org.apache.storm.generated.DebugOptions
- DebugOptions(DebugOptions) - Constructor for class org.apache.storm.generated.DebugOptions
-
Performs a deep copy on other.
- DebugOptions._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- debugStream - Variable in class org.apache.storm.sql.parser.impl.StormParserImplTokenManager
-
Debug output.
- DEC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DECADE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DECIMAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DECIMAL_NUMERIC_LITERAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- declare(boolean, Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
- declare(boolean, Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
- declare(Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
-
Uses default stream id.
- declare(Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
- DECLARE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- declareCheckpointStream(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.bolt.JoinBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.clojure.ClojureBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.clojure.ClojureSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.clojure.RichShellBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.clojure.RichShellSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.coordination.BatchBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.coordination.CoordinatedBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.drpc.DRPCSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.drpc.JoinResult
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.drpc.KeyedFairBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.drpc.PrepareRequest
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.drpc.ReturnResults
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.ExclamationTopology.ExclamationBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.ExclamationTopology.FixedOrderWordSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.examples.StatefulWordCounter
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.examples.TestPrintBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.examples.TestWindowBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.examples.WordCounter
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.wrappers.bolts.LogInfoBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.MyBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.SentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.MyBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.SentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.hdfs.spout.HdfsSpoutTopology.ConstBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jdbc.bolt.JdbcInsertBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jdbc.bolt.JdbcLookupBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.storm.jdbc.mapper.JdbcLookupMapper
-
declare what are the fields that this code will output.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jdbc.mapper.SimpleJdbcLookupMapper
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jdbc.spout.UserSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jms.bolt.JmsBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jms.example.GenericBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jms.example.JsonTupleProducer
- declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.storm.jms.JmsTupleProducer
-
Declare the output fields produced by this JmsTupleProducer.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.jms.spout.JmsSpout
-
Use the
JmsSpout.tupleProducer
to determine which fields are about to be emitted. - declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.kafka.bolt.KafkaBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.kafka.spout.KafkaSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.kafka.spout.KafkaSpoutTestBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.lambda.LambdaBiConsumerBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.lambda.LambdaConsumerBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.lambda.LambdaSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.loadgen.LoadBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.loadgen.LoadSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.loadgen.ThroughputVsLatency.FastRandomSentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.loadgen.ThroughputVsLatency.SplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.loadgen.ThroughputVsLatency.WordCount
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.bolt.CountBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.bolt.DevNullBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.bolt.IdBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.bolt.SplitSentenceBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.spout.ConstSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.spout.FileReadSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.spout.StringGenSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.spout.WordGenSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.perf.utils.IdentityBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.bolt.RedisFilterBolt
-
Declare the output schema for all the streams of this topology.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.bolt.RedisLookupBolt
-
Declare the output schema for all the streams of this topology.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.bolt.RedisStoreBolt
-
Declare the output schema for all the streams of this topology.
- declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.storm.redis.common.mapper.RedisFilterMapper
-
declare what are the fields that this code will output.
- declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.storm.redis.common.mapper.RedisLookupMapper
-
declare what are the fields that this code will output.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.topology.LookupWordCount.PrintWordTotalCountBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.topology.WhitelistWordCount.PrintWordTotalCountBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.topology.WordCounter
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.topology.WordSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.redis.trident.WordCountLookupMapper
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.spout.CheckpointSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.sql.runtime.datasource.socket.bolt.SocketBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.st.topology.window.IncrementingSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.st.topology.window.TimeDataIncrementingSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.st.topology.window.TimeDataVerificationBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.st.topology.window.VerificationBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.AnchoredWordCount.RandomSentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.AnchoredWordCount.SplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.AnchoredWordCount.WordCount
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.BasicDRPCTopology.ExclaimBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.FilterWords
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.RandomSentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.SplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.AbstractRankerBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.PrinterBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.RollingCountAggBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.RollingCountBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.SingleJoinBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.SlidingWindowSumBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.bolt.WordCountBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ExclamationTopology.ExclamationBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.FastWordCountTopology.FastRandomSentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.FastWordCountTopology.SplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.FastWordCountTopology.WordCount
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.InOrderDeliveryTest.Check
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.InOrderDeliveryTest.InOrderSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ManualDRPC.ExclamationBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.MultipleLoggerTopology.ExclamationLoggingBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.MultiThreadWordCountTopology.MultiThreadedSplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ReachTopology.CountAggregator
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ReachTopology.GetFollowers
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ReachTopology.GetTweeters
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ReachTopology.PartialUniquer
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.ResourceAwareExampleTopology.ExclamationBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.spout.RandomIntegerSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.spout.RandomSentenceSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.StatefulTopology.PrinterBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.WordCountTopology.SplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.WordCountTopologyNode.RandomSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.WordCountTopologyNode.SplitSentence
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.starter.WordCountTopologyNode.WordCount
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.BoltTracker
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.FeederSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.FixedTupleSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.IdentityBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.PrepareBatchBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.PythonShellMetricsBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.PythonShellMetricsSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.SpoutTracker
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestAggregatesCounter
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestConfBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestEventLogSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestEventOrderCheckBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestGlobalCount
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestPlannerBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestPlannerSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestWordCounter
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestWordSpout
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TupleCaptureBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.base.BaseStatefulBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.BasicBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.CheckpointTupleForwarder
- declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.storm.topology.IComponent
-
Declare the output schema for all the streams of this topology.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.StatefulBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.WindowedBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.trident.planner.SubtopologyBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.trident.spout.TridentSpoutCoordinator
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.trident.topology.TridentBoltExecutor
- declareStream(String, boolean, Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
- declareStream(String, boolean, Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
- declareStream(String, Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
- declareStream(String, Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.storm.messaging.netty.MessageDecoder
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.storm.pacemaker.codec.ThriftDecoder
- decodeKey(byte[]) - Method in class org.apache.storm.redis.state.RedisKeyValueStateIterator
- decodeKey(byte[]) - Method in class org.apache.storm.state.BaseBinaryStateIterator
-
Decode key to convert byte array to state key type.
- decodeKey(byte[]) - Method in class org.apache.storm.state.DefaultStateEncoder
- decodeKey(KENCODEDT) - Method in class org.apache.storm.state.BaseStateIterator
-
Decode key to convert encoded type of key to state key type.
- decodeKey(KENCODEDT) - Method in interface org.apache.storm.state.StateEncoder
-
Decode key.
- decodeValue(byte[]) - Method in class org.apache.storm.redis.state.RedisKeyValueStateIterator
- decodeValue(byte[]) - Method in class org.apache.storm.state.BaseBinaryStateIterator
-
Decode value to convert byte array to state value type.
- decodeValue(byte[]) - Method in class org.apache.storm.state.DefaultStateEncoder
- decodeValue(VENCODEDT) - Method in class org.apache.storm.state.BaseStateIterator
-
Decode value to convert encoded type of value to state value type.
- decodeValue(VENCODEDT) - Method in interface org.apache.storm.state.StateEncoder
-
Decode value.
- decodeVIntSize(byte) - Static method in class org.apache.storm.utils.WritableUtils
-
Parse the first byte of a vint/vlong to determine the number of bytes.
- decorate(Kryo) - Method in interface org.apache.storm.serialization.IKryoDecorator
- decorate(Kryo) - Method in class org.apache.storm.testing.TestKryoDecorator
- decorate(String, String) - Static method in class org.apache.storm.st.utils.StringDecorator
- decrement() - Method in class org.apache.storm.streams.RefCountedTuple
- deepCopy() - Method in class org.apache.storm.generated.AccessControl
- deepCopy() - Method in exception org.apache.storm.generated.AlreadyAliveException
- deepCopy() - Method in class org.apache.storm.generated.Assignment
- deepCopy() - Method in exception org.apache.storm.generated.AuthorizationException
- deepCopy() - Method in class org.apache.storm.generated.BeginDownloadResult
- deepCopy() - Method in class org.apache.storm.generated.Bolt
- deepCopy() - Method in class org.apache.storm.generated.BoltAggregateStats
- deepCopy() - Method in class org.apache.storm.generated.BoltStats
- deepCopy() - Method in class org.apache.storm.generated.ClusterSummary
- deepCopy() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- deepCopy() - Method in class org.apache.storm.generated.CommonAggregateStats
- deepCopy() - Method in class org.apache.storm.generated.ComponentAggregateStats
- deepCopy() - Method in class org.apache.storm.generated.ComponentCommon
- deepCopy() - Method in class org.apache.storm.generated.ComponentObject
- deepCopy() - Method in class org.apache.storm.generated.ComponentPageInfo
- deepCopy() - Method in class org.apache.storm.generated.Credentials
- deepCopy() - Method in class org.apache.storm.generated.DebugOptions
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- deepCopy() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- deepCopy() - Method in exception org.apache.storm.generated.DRPCExecutionException
- deepCopy() - Method in class org.apache.storm.generated.DRPCRequest
- deepCopy() - Method in class org.apache.storm.generated.ErrorInfo
- deepCopy() - Method in class org.apache.storm.generated.ExecutorAggregateStats
- deepCopy() - Method in class org.apache.storm.generated.ExecutorInfo
- deepCopy() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- deepCopy() - Method in class org.apache.storm.generated.ExecutorStats
- deepCopy() - Method in class org.apache.storm.generated.ExecutorSummary
- deepCopy() - Method in class org.apache.storm.generated.GetInfoOptions
- deepCopy() - Method in class org.apache.storm.generated.GlobalStreamId
- deepCopy() - Method in class org.apache.storm.generated.Grouping
- deepCopy() - Method in exception org.apache.storm.generated.HBAuthorizationException
- deepCopy() - Method in exception org.apache.storm.generated.HBExecutionException
- deepCopy() - Method in class org.apache.storm.generated.HBMessage
- deepCopy() - Method in class org.apache.storm.generated.HBMessageData
- deepCopy() - Method in class org.apache.storm.generated.HBNodes
- deepCopy() - Method in class org.apache.storm.generated.HBPulse
- deepCopy() - Method in class org.apache.storm.generated.HBRecords
- deepCopy() - Method in exception org.apache.storm.generated.IllegalStateException
- deepCopy() - Method in exception org.apache.storm.generated.InvalidTopologyException
- deepCopy() - Method in class org.apache.storm.generated.JavaObject
- deepCopy() - Method in class org.apache.storm.generated.JavaObjectArg
- deepCopy() - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- deepCopy() - Method in exception org.apache.storm.generated.KeyNotFoundException
- deepCopy() - Method in class org.apache.storm.generated.KillOptions
- deepCopy() - Method in class org.apache.storm.generated.ListBlobsResult
- deepCopy() - Method in class org.apache.storm.generated.LocalAssignment
- deepCopy() - Method in class org.apache.storm.generated.LocalStateData
- deepCopy() - Method in class org.apache.storm.generated.LogConfig
- deepCopy() - Method in class org.apache.storm.generated.LogLevel
- deepCopy() - Method in class org.apache.storm.generated.LSApprovedWorkers
- deepCopy() - Method in class org.apache.storm.generated.LSSupervisorAssignments
- deepCopy() - Method in class org.apache.storm.generated.LSSupervisorId
- deepCopy() - Method in class org.apache.storm.generated.LSTopoHistory
- deepCopy() - Method in class org.apache.storm.generated.LSTopoHistoryList
- deepCopy() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.activate_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.activate_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.debug_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.debug_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- deepCopy() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- deepCopy() - Method in class org.apache.storm.generated.NimbusSummary
- deepCopy() - Method in class org.apache.storm.generated.NodeInfo
- deepCopy() - Method in exception org.apache.storm.generated.NotAliveException
- deepCopy() - Method in class org.apache.storm.generated.NullStruct
- deepCopy() - Method in class org.apache.storm.generated.OwnerResourceSummary
- deepCopy() - Method in class org.apache.storm.generated.PrivateWorkerKey
- deepCopy() - Method in class org.apache.storm.generated.ProfileRequest
- deepCopy() - Method in class org.apache.storm.generated.ReadableBlobMeta
- deepCopy() - Method in class org.apache.storm.generated.RebalanceOptions
- deepCopy() - Method in class org.apache.storm.generated.SettableBlobMeta
- deepCopy() - Method in class org.apache.storm.generated.SharedMemory
- deepCopy() - Method in class org.apache.storm.generated.ShellComponent
- deepCopy() - Method in class org.apache.storm.generated.SpecificAggregateStats
- deepCopy() - Method in class org.apache.storm.generated.SpoutAggregateStats
- deepCopy() - Method in class org.apache.storm.generated.SpoutSpec
- deepCopy() - Method in class org.apache.storm.generated.SpoutStats
- deepCopy() - Method in class org.apache.storm.generated.StateSpoutSpec
- deepCopy() - Method in class org.apache.storm.generated.StormBase
- deepCopy() - Method in class org.apache.storm.generated.StormTopology
- deepCopy() - Method in class org.apache.storm.generated.StreamInfo
- deepCopy() - Method in class org.apache.storm.generated.SubmitOptions
- deepCopy() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- deepCopy() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- deepCopy() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- deepCopy() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- deepCopy() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- deepCopy() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- deepCopy() - Method in class org.apache.storm.generated.SupervisorAssignments
- deepCopy() - Method in class org.apache.storm.generated.SupervisorInfo
- deepCopy() - Method in class org.apache.storm.generated.SupervisorPageInfo
- deepCopy() - Method in class org.apache.storm.generated.SupervisorSummary
- deepCopy() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- deepCopy() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- deepCopy() - Method in class org.apache.storm.generated.ThriftSerializedObject
- deepCopy() - Method in class org.apache.storm.generated.TopologyActionOptions
- deepCopy() - Method in class org.apache.storm.generated.TopologyHistoryInfo
- deepCopy() - Method in class org.apache.storm.generated.TopologyInfo
- deepCopy() - Method in class org.apache.storm.generated.TopologyPageInfo
- deepCopy() - Method in class org.apache.storm.generated.TopologyStats
- deepCopy() - Method in class org.apache.storm.generated.TopologySummary
- deepCopy() - Method in class org.apache.storm.generated.WorkerMetricList
- deepCopy() - Method in class org.apache.storm.generated.WorkerMetricPoint
- deepCopy() - Method in class org.apache.storm.generated.WorkerMetrics
- deepCopy() - Method in class org.apache.storm.generated.WorkerResources
- deepCopy() - Method in class org.apache.storm.generated.WorkerSummary
- deepCopy() - Method in class org.apache.storm.generated.WorkerToken
- deepCopy() - Method in class org.apache.storm.generated.WorkerTokenInfo
- deepSearch(String, HttpServletRequest) - Method in class org.apache.storm.daemon.logviewer.webapp.LogviewerResource
-
Handles '/deepSearch' request.
- deepSearchLogsForTopology(String, String, String, String, String, String, String, Boolean, String, String) - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler
-
Advanced search across worker log files in a topology.
- Default() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- DEFAULT - Static variable in class org.apache.storm.blobstore.BlobStoreAclHandler
- DEFAULT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
Lexical state.
- DEFAULT_ - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEFAULT_BATCH_SIZE - Static variable in class org.apache.storm.jms.trident.TridentJmsSpout
- DEFAULT_BLACKLIST_SCHEDULER_RESUME_TIME - Static variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- DEFAULT_BLACKLIST_SCHEDULER_RESUME_TIME - Static variable in class org.apache.storm.scheduler.blacklist.strategies.DefaultBlacklistStrategy
- DEFAULT_BLACKLIST_SCHEDULER_TOLERANCE_COUNT - Static variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- DEFAULT_BLACKLIST_SCHEDULER_TOLERANCE_COUNT - Static variable in class org.apache.storm.scheduler.blacklist.strategies.DefaultBlacklistStrategy
- DEFAULT_BLACKLIST_SCHEDULER_TOLERANCE_TIME - Static variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- DEFAULT_BOLT_NUM - Static variable in class org.apache.storm.perf.HdfsSpoutNullBoltTopo
- DEFAULT_BOLT_NUM - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- DEFAULT_BOLT_NUM - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
- DEFAULT_BOLT_NUM - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- DEFAULT_BYTES_PER_PAGE - Static variable in class org.apache.storm.daemon.logviewer.LogviewerConstant
- DEFAULT_CHARSET - Static variable in class org.apache.storm.multilang.JsonSerializer
- DEFAULT_COMMIT_FREQ_COUNT - Static variable in class org.apache.storm.hdfs.spout.Configs
- DEFAULT_COMMIT_FREQ_SEC - Static variable in class org.apache.storm.hdfs.spout.Configs
- DEFAULT_COUNT_BOLT_NUM - Static variable in class org.apache.storm.perf.FileReadWordCountTopo
- DEFAULT_COUNT_BOLT_NUM - Static variable in class org.apache.storm.perf.SimplifiedWordCountTopo
- DEFAULT_FAILBACK_MAVEN_LOCAL_REPOSITORY_DIRECTORY - Static variable in class org.apache.storm.submit.command.DependencyResolverMain
- DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.storm.hdfs.bolt.format.DelimitedRecordFormat
- DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.storm.hdfs.trident.format.DelimitedRecordFormat
- DEFAULT_FIRST_POLL_OFFSET_STRATEGY - Static variable in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- DEFAULT_GROUPING - Static variable in class org.apache.storm.perf.ConstSpoutNullBoltTopo
- DEFAULT_HDFS_BATCH - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- DEFAULT_HDFS_BATCH - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- DEFAULT_HDFS_CONFIG_KEY - Static variable in class org.apache.storm.hdfs.spout.Configs
- DEFAULT_IDENTIFIER_MAX_LENGTH - Static variable in class org.apache.storm.sql.parser.StormParser
- DEFAULT_INMEMORY_TUPLE_CACHE_LIMIT - Static variable in class org.apache.storm.trident.windowing.WindowTridentProcessor
- DEFAULT_LOCK_DIR - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Filenames with this suffix in archive dir will be ignored by the Spout.
- DEFAULT_LOCK_TIMEOUT - Static variable in class org.apache.storm.hdfs.spout.Configs
- DEFAULT_MAX_LENGTH - Static variable in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- DEFAULT_MAX_OUTSTANDING - Static variable in class org.apache.storm.hdfs.spout.Configs
- DEFAULT_MAX_RETRIES - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_MAX_UNCOMMITTED_OFFSETS - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_METHOD_NAME - Static variable in class org.apache.storm.flux.model.TopologySourceDef
- DEFAULT_METRICS_TIME_BUCKET_SIZE_SECONDS - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_OFFSET_COMMIT_PERIOD_MS - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_ON_ERROR_TIMEOUT - Static variable in class org.apache.storm.daemon.supervisor.ReadClusterState
- DEFAULT_ON_WARN_TIMEOUT - Static variable in class org.apache.storm.daemon.supervisor.ReadClusterState
- DEFAULT_OUT_DIR - Static variable in class org.apache.storm.loadgen.CaptureLoad
- DEFAULT_PARALLELISM_HINT - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsScanRule
- DEFAULT_PARTITION_REFRESH_PERIOD_MS - Static variable in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- DEFAULT_POLL_TIMEOUT_MS - Static variable in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- DEFAULT_POOL_CONFIG - Static variable in class org.apache.storm.redis.trident.state.RedisClusterMapState.Factory
- DEFAULT_POOL_CONFIG - Static variable in class org.apache.storm.redis.trident.state.RedisClusterState.Factory
- DEFAULT_POOL_CONFIG - Static variable in class org.apache.storm.redis.trident.state.RedisMapState.Factory
- DEFAULT_POOL_CONFIG - Static variable in class org.apache.storm.redis.trident.state.RedisState.Factory
- DEFAULT_PROCESSING_GUARANTEE - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_RACK - Static variable in interface org.apache.storm.networktopography.DNSToSwitchMapping
- DEFAULT_RAS - Enum constant in enum class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.NodeSortType
-
Deprecated.used by DefaultResourceAwareStrategyOld only. Use {link #COMMON} instead.
- DEFAULT_RECORD_DELIMITER - Static variable in class org.apache.storm.hdfs.bolt.format.DelimitedRecordFormat
- DEFAULT_RECORD_DELIMITER - Static variable in class org.apache.storm.hdfs.trident.format.DelimitedRecordFormat
- DEFAULT_REPORT_INTERVAL - Static variable in class org.apache.storm.loadgen.LoadMetricsServer
- DEFAULT_RETRY_SERVICE - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_SERIALIZERS - Static variable in class org.apache.storm.redis.trident.state.AbstractRedisMapState
- DEFAULT_SHARED_RESOURCES - Static variable in class org.apache.storm.Constants
- DEFAULT_SPLIT_BOLT_NUM - Static variable in class org.apache.storm.perf.FileReadWordCountTopo
- DEFAULT_SPOUT_NUM - Static variable in class org.apache.storm.perf.FileReadWordCountTopo
- DEFAULT_SPOUT_NUM - Static variable in class org.apache.storm.perf.HdfsSpoutNullBoltTopo
- DEFAULT_SPOUT_NUM - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- DEFAULT_SPOUT_NUM - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
- DEFAULT_SPOUT_NUM - Static variable in class org.apache.storm.perf.SimplifiedWordCountTopo
- DEFAULT_SPOUT_NUM - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- DEFAULT_START_TS - Static variable in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- DEFAULT_STREAM - Static variable in interface org.apache.storm.kafka.spout.RecordTranslator
- DEFAULT_STREAM_ID - Static variable in class org.apache.storm.utils.Utils
- DEFAULT_TUPLE_LISTENER - Static variable in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- DEFAULT_WINDOW_INTERVAL - Static variable in class org.apache.storm.loadgen.LoadMetricsServer
- DefaultBlacklistStrategy - Class in org.apache.storm.scheduler.blacklist.strategies
-
The default strategy used for blacklisting hosts.
- DefaultBlacklistStrategy() - Constructor for class org.apache.storm.scheduler.blacklist.strategies.DefaultBlacklistStrategy
- DefaultEvictionContext - Class in org.apache.storm.windowing
- DefaultEvictionContext(Long) - Constructor for class org.apache.storm.windowing.DefaultEvictionContext
- DefaultEvictionContext(Long, Long) - Constructor for class org.apache.storm.windowing.DefaultEvictionContext
- DefaultEvictionContext(Long, Long, Long) - Constructor for class org.apache.storm.windowing.DefaultEvictionContext
- DefaultEvictionContext(Long, Long, Long, Long) - Constructor for class org.apache.storm.windowing.DefaultEvictionContext
- DefaultExceptionMapper - Class in org.apache.storm.daemon.ui.exceptionmappers
- DefaultExceptionMapper() - Constructor for class org.apache.storm.daemon.ui.exceptionmappers.DefaultExceptionMapper
- defaultFields - Static variable in class org.apache.storm.hdfs.spout.SequenceFileReader
- defaultFields - Static variable in class org.apache.storm.hdfs.spout.TextFileReader
- DefaultFileNameFormat - Class in org.apache.storm.hdfs.bolt.format
-
Creates file names with the following format:
- DefaultFileNameFormat - Class in org.apache.storm.hdfs.trident.format
-
Creates file names with the following format:
- DefaultFileNameFormat() - Constructor for class org.apache.storm.hdfs.bolt.format.DefaultFileNameFormat
- DefaultFileNameFormat() - Constructor for class org.apache.storm.hdfs.trident.format.DefaultFileNameFormat
- DefaultHttpCredentialsPlugin - Class in org.apache.storm.security.auth
- DefaultHttpCredentialsPlugin() - Constructor for class org.apache.storm.security.auth.DefaultHttpCredentialsPlugin
- DefaultKeyFactory() - Constructor for class org.apache.storm.redis.trident.state.KeyFactory.DefaultKeyFactory
- DefaultKryoFactory - Class in org.apache.storm.serialization
- DefaultKryoFactory() - Constructor for class org.apache.storm.serialization.DefaultKryoFactory
- DefaultKryoFactory.KryoSerializableDefault - Class in org.apache.storm.serialization
- DefaultPool - Class in org.apache.storm.scheduler.multitenant
-
A pool of machines that anyone can use, but topologies are not isolated.
- DefaultPool() - Constructor for class org.apache.storm.scheduler.multitenant.DefaultPool
- DefaultPrincipalToLocal - Class in org.apache.storm.security.auth
-
Storm can be configured to launch worker processed as a given user.
- DefaultPrincipalToLocal() - Constructor for class org.apache.storm.security.auth.DefaultPrincipalToLocal
- DefaultRackDNSToSwitchMapping - Class in org.apache.storm.networktopography
-
This class implements the
DNSToSwitchMapping
interface It returns the DEFAULT_RACK for every host. - DefaultRackDNSToSwitchMapping() - Constructor for class org.apache.storm.networktopography.DefaultRackDNSToSwitchMapping
- DefaultRecordTranslator<K,
V> - Class in org.apache.storm.kafka.spout - DefaultRecordTranslator() - Constructor for class org.apache.storm.kafka.spout.DefaultRecordTranslator
- DefaultResourceAwareStrategy - Class in org.apache.storm.scheduler.resource.strategies.scheduling
- DefaultResourceAwareStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.DefaultResourceAwareStrategy
- DefaultResourceAwareStrategyOld - Class in org.apache.storm.scheduler.resource.strategies.scheduling
- DefaultResourceAwareStrategyOld() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.DefaultResourceAwareStrategyOld
- DefaultResourceDeclarer<T extends DefaultResourceDeclarer> - Class in org.apache.storm.trident.operation
-
Default implementation of resources declarer.
- DefaultResourceDeclarer() - Constructor for class org.apache.storm.trident.operation.DefaultResourceDeclarer
- DefaultResourceIsolationManager - Class in org.apache.storm.container
-
This is the default class to manage worker processes, including launching, killing, profiling and etc.
- DefaultResourceIsolationManager() - Constructor for class org.apache.storm.container.DefaultResourceIsolationManager
- DEFAULTS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- defaultSchedule(Topologies, Cluster) - Static method in class org.apache.storm.scheduler.DefaultScheduler
- DefaultScheduler - Class in org.apache.storm.scheduler
- DefaultScheduler() - Constructor for class org.apache.storm.scheduler.DefaultScheduler
- DefaultSchedulingPriorityStrategy - Class in org.apache.storm.scheduler.resource.strategies.priority
- DefaultSchedulingPriorityStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy
- DefaultSchedulingPriorityStrategy.SimulatedUser - Class in org.apache.storm.scheduler.resource.strategies.priority
- DefaultSequenceFormat - Class in org.apache.storm.hdfs.bolt.format
-
Basic
SequenceFormat
implementation that usesLongWritable
for keys andText
for values. - DefaultSequenceFormat - Class in org.apache.storm.hdfs.trident.format
-
Basic
SequenceFormat
implementation that usesLongWritable
for keys andText
for values. - DefaultSequenceFormat(String, String) - Constructor for class org.apache.storm.hdfs.bolt.format.DefaultSequenceFormat
- DefaultSequenceFormat(String, String) - Constructor for class org.apache.storm.hdfs.trident.format.DefaultSequenceFormat
- DefaultShellLogHandler - Class in org.apache.storm.utils
-
Default implementation of
ShellLogHandler
. - DefaultShellLogHandler() - Constructor for class org.apache.storm.utils.DefaultShellLogHandler
-
Default constructor; used when loading with Class.forName(...).newInstance().
- DefaultStateEncoder<K,
V> - Class in org.apache.storm.state -
Default state encoder class for encoding/decoding key values.
- DefaultStateEncoder(Serializer<K>, Serializer<V>) - Constructor for class org.apache.storm.state.DefaultStateEncoder
- DefaultStateSerializer<T> - Class in org.apache.storm.state
-
A default implementation that uses Kryo to serialize and de-serialize the state.
- DefaultStateSerializer() - Constructor for class org.apache.storm.state.DefaultStateSerializer
- DefaultStateSerializer(Map<String, Object>, TopologyContext) - Constructor for class org.apache.storm.state.DefaultStateSerializer
- DefaultStateSerializer(Map<String, Object>, TopologyContext, List<Class<?>>) - Constructor for class org.apache.storm.state.DefaultStateSerializer
-
Constructs a
DefaultStateSerializer
instance with the given list of classes registered in kryo. - DefaultTopicSelector - Class in org.apache.storm.kafka.bolt.selector
- DefaultTopicSelector - Class in org.apache.storm.kafka.trident.selector
- DefaultTopicSelector(String) - Constructor for class org.apache.storm.kafka.bolt.selector.DefaultTopicSelector
- DefaultTopicSelector(String) - Constructor for class org.apache.storm.kafka.trident.selector.DefaultTopicSelector
- DefaultTopologyValidator - Class in org.apache.storm.nimbus
- DefaultTopologyValidator() - Constructor for class org.apache.storm.nimbus.DefaultTopologyValidator
- DefaultUncaughtExceptionHandler - Class in org.apache.storm.daemon.supervisor
- DefaultUncaughtExceptionHandler() - Constructor for class org.apache.storm.daemon.supervisor.DefaultUncaughtExceptionHandler
- DefaultWatcherCallBack - Class in org.apache.storm.callback
- DefaultWatcherCallBack() - Constructor for class org.apache.storm.callback.DefaultWatcherCallBack
- DEFERRABLE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEFERRED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEFINE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEFINED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEFINER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEGREE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- del(byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- del(byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- del(byte[]) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- del(String) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- del(String) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- del(String) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- delay() - Method in class org.apache.storm.kafka.spout.internal.Timer
- delegate - Variable in class org.apache.storm.trident.state.map.CachedBatchReadsMap
- delegateCollector - Variable in class org.apache.storm.trident.windowing.AbstractTridentWindowManager
- delegateIndex - Variable in class org.apache.storm.trident.tuple.ValuePointer
- delete() - Method in class org.apache.storm.blobstore.BlobStoreFile
- delete() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- delete() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- delete() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- delete(File) - Method in class org.apache.storm.blobstore.FileBlobStoreImpl
- delete(String) - Method in class org.apache.storm.trident.topology.state.TransactionalState
- delete(K) - Method in class org.apache.storm.redis.state.RedisKeyValueState
- delete(K) - Method in class org.apache.storm.state.InMemoryKeyValueState
- delete(K) - Method in interface org.apache.storm.state.KeyValueState
-
Deletes the value mapped to the key, if there is any.
- delete(Path) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- DELETE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- delete_node(String) - Method in interface org.apache.storm.cluster.IStateStorage
-
Deletes the node at a given path, and any child nodes that may exist.
- delete_node(String) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- delete_node(String) - Method in class org.apache.storm.cluster.ZKStateStorage
- delete_node_blobstore(String, String) - Method in interface org.apache.storm.cluster.IStateStorage
-
Allows us to delete the znodes within /storm/blobstore/key_name whose znodes start with the corresponding nimbusHostPortInfo.
- delete_node_blobstore(String, String) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- delete_node_blobstore(String, String) - Method in class org.apache.storm.cluster.ZKStateStorage
- DELETE_PATH - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- DELETE_PATH_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- DELETE_PULSE_ID - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- DELETE_PULSE_ID_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- delete_worker_hb(String) - Method in interface org.apache.storm.cluster.IStateStorage
-
Deletes the heartbeat at a given path, and any child nodes that may exist.
- delete_worker_hb(String) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- delete_worker_hb(String) - Method in class org.apache.storm.cluster.ZKStateStorage
- deleteAllBlobStoreKeys(BlobStore, Subject) - Static method in class org.apache.storm.blobstore.MigrateBlobs
- deleteBlob() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.deleteBlob
- deleteBlob() - Constructor for class org.apache.storm.generated.Nimbus.Processor.deleteBlob
- deleteBlob(String) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to delete a blob.
- deleteBlob(String) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- deleteBlob(String) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- deleteBlob(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- deleteBlob(String) - Method in class org.apache.storm.generated.Nimbus.Client
- deleteBlob(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- deleteBlob(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- deleteBlob(String) - Method in class org.apache.storm.LocalCluster
- deleteBlob(String, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Deletes the blob data and metadata.
- deleteBlob(String, Subject) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- deleteBlob(String, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- deleteBlob(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- deleteBlob(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- deleteBlob_args() - Constructor for class org.apache.storm.generated.Nimbus.deleteBlob_args
- deleteBlob_args(String) - Constructor for class org.apache.storm.generated.Nimbus.deleteBlob_args
- deleteBlob_args(Nimbus.deleteBlob_args) - Constructor for class org.apache.storm.generated.Nimbus.deleteBlob_args
-
Performs a deep copy on other.
- deleteBlob_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.deleteBlob_call
- deleteBlob_result() - Constructor for class org.apache.storm.generated.Nimbus.deleteBlob_result
- deleteBlob_result(AuthorizationException, KeyNotFoundException, IllegalStateException) - Constructor for class org.apache.storm.generated.Nimbus.deleteBlob_result
- deleteBlob_result(Nimbus.deleteBlob_result) - Constructor for class org.apache.storm.generated.Nimbus.deleteBlob_result
-
Performs a deep copy on other.
- deleteBlobs(List<String>) - Method in class org.apache.storm.dependency.DependencyUploader
- deleteCgroup(CgroupCommon) - Method in class org.apache.storm.container.cgroup.CgroupCenter
- deleteCgroup(CgroupCommon) - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
delete a cgroup.
- deleteDir(String) - Static method in class org.apache.storm.container.cgroup.CgroupUtils
- deleteIfExists(File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Delete a file or a directory and all of the children.
- deleteIfExists(File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Delete a file or a directory and all of the children.
- deleteIfExists(File, String, String) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Delete a file or a directory and all of the children.
- deleteIfExists(File, String, String) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Delete a file or a directory and all of the children.
- deleteKey(String) - Method in class org.apache.storm.blobstore.FileBlobStoreImpl
-
Delete a key from the blob store.
- deleteKey(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
-
Delete a key from the blob store.
- deleteKeySetFromBlobStoreNotOnZookeeper(Set<String>, Set<String>) - Method in class org.apache.storm.blobstore.LocalFsBlobStoreSynchronizer
- deleteNode(CuratorFramework, String) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- deleteNodeBlobstore(CuratorFramework, String, String) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- deleteOldestWhileTooLarge(List<Path>, long, boolean, Set<Path>) - Method in class org.apache.storm.daemon.logviewer.utils.DirectoryCleaner
-
If totalSize of files exceeds the either the per-worker quota or global quota, Logviewer deletes oldest inactive log files in a worker directory or in all worker dirs.
- deleteSavedWorkerUser() - Method in class org.apache.storm.daemon.supervisor.Container
- deleteStormId(String) - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
Delete a local cache of stormId which is mapped to a specific storm name.
- deleteStormId(String) - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- deleteTopoConf(String, Subject) - Method in class org.apache.storm.daemon.nimbus.TopoCache
-
Delete a topology conf when we are done.
- deleteTopology(String, Subject) - Method in class org.apache.storm.daemon.nimbus.TopoCache
-
Delete a topology when we are done.
- deleteTopologyProfileRequests(String, ProfileRequest) - Method in interface org.apache.storm.cluster.IStormClusterState
- deleteTopologyProfileRequests(String, ProfileRequest) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- deleteVersion(long) - Method in class org.apache.storm.utils.VersionedStore
- DelimitedRecordFormat - Class in org.apache.storm.hdfs.bolt.format
-
RecordFormat implementation that uses field and record delimiters.
- DelimitedRecordFormat - Class in org.apache.storm.hdfs.trident.format
-
RecordFormat implementation that uses field and record delimiters.
- DelimitedRecordFormat() - Constructor for class org.apache.storm.hdfs.bolt.format.DelimitedRecordFormat
- DelimitedRecordFormat() - Constructor for class org.apache.storm.hdfs.trident.format.DelimitedRecordFormat
- deltaMs(long) - Static method in class org.apache.storm.utils.Time
- deltaSecs(int) - Static method in class org.apache.storm.utils.Time
- DENSE_RANK - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DenyAuthorizer - Class in org.apache.storm.security.auth.authorizer
-
An authorization implementation that denies everything, for testing purposes.
- DenyAuthorizer() - Constructor for class org.apache.storm.security.auth.authorizer.DenyAuthorizer
- DEPENDENCY_ARTIFACTS - Enum constant in enum class org.apache.storm.generated.StormTopology._Fields
- DEPENDENCY_JARS - Enum constant in enum class org.apache.storm.generated.StormTopology._Fields
- DependencyBlobStoreUtils - Class in org.apache.storm.dependency
- DependencyBlobStoreUtils() - Constructor for class org.apache.storm.dependency.DependencyBlobStoreUtils
- DependencyPropertiesParser - Class in org.apache.storm.dependency
- DependencyPropertiesParser() - Constructor for class org.apache.storm.dependency.DependencyPropertiesParser
- DependencyResolver - Class in org.apache.storm.submit.dependency
-
Resolver class of dependencies.
- DependencyResolver(String) - Constructor for class org.apache.storm.submit.dependency.DependencyResolver
-
Constuctor.
- DependencyResolver(String, List<RemoteRepository>) - Constructor for class org.apache.storm.submit.dependency.DependencyResolver
-
Constuctor.
- DependencyResolverMain - Class in org.apache.storm.submit.command
-
Main class of dependency resolver.
- DependencyResolverMain() - Constructor for class org.apache.storm.submit.command.DependencyResolverMain
- DependencyUploader - Class in org.apache.storm.dependency
- DependencyUploader() - Constructor for class org.apache.storm.dependency.DependencyUploader
- DEPTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEREF - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- deregister(Set<Metric>) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- DERIVED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DerivedTypeValidator(Map<String, Object>) - Constructor for class org.apache.storm.validation.ConfigValidation.DerivedTypeValidator
- DESC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DESCRIBE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DESCRIPTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DESCRIPTOR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- deserialize(byte[]) - Method in interface org.apache.storm.serialization.ITupleDeserializer
- deserialize(byte[]) - Method in class org.apache.storm.serialization.KryoTupleDeserializer
- deserialize(byte[]) - Method in class org.apache.storm.serialization.KryoValuesDeserializer
- deserialize(byte[]) - Method in class org.apache.storm.state.DefaultStateSerializer
- deserialize(byte[]) - Method in interface org.apache.storm.state.Serializer
- deserialize(byte[]) - Method in class org.apache.storm.trident.state.JSONNonTransactionalSerializer
- deserialize(byte[]) - Method in class org.apache.storm.trident.state.JSONOpaqueSerializer
- deserialize(byte[]) - Method in class org.apache.storm.trident.state.JSONTransactionalSerializer
- deserialize(byte[]) - Method in interface org.apache.storm.trident.state.Serializer
- deserialize(byte[]) - Method in class org.apache.storm.trident.windowing.WindowKryoSerializer
-
Returns an Object which is created using Kryo deserialization of given byte array instance.
- deserialize(byte[], Class<T>) - Method in class org.apache.storm.serialization.GzipBridgeThriftSerializationDelegate
- deserialize(byte[], Class<T>) - Method in class org.apache.storm.serialization.GzipSerializationDelegate
- deserialize(byte[], Class<T>) - Method in class org.apache.storm.serialization.GzipThriftSerializationDelegate
- deserialize(byte[], Class<T>) - Method in interface org.apache.storm.serialization.SerializationDelegate
- deserialize(byte[], Class<T>) - Method in class org.apache.storm.serialization.ThriftSerializationDelegate
- deserialize(byte[], Class<T>) - Static method in class org.apache.storm.utils.Utils
- deserialize(Input) - Static method in class org.apache.storm.tuple.MessageId
- deserialize(String) - Static method in class org.apache.storm.hdfs.spout.FileLock.LogEntry
- deserialize(ByteBuffer) - Method in class org.apache.storm.messaging.TaskMessage
- deserialize(ByteBuffer) - Method in interface org.apache.storm.spout.MultiScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.spout.RawMultiScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.spout.RawScheme
- deserialize(ByteBuffer) - Method in interface org.apache.storm.spout.Scheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.spout.SchemeAsMultiScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.sql.runtime.serde.avro.AvroScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.sql.runtime.serde.csv.CsvScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.sql.runtime.serde.json.JsonScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.sql.runtime.serde.tsv.TsvScheme
- deserialize(ByteBuffer) - Method in class org.apache.storm.trident.windowing.WindowKryoSerializer
-
Returns an Object which is created using Kryo deserialization of given
byteBuffer
instance. - deserializeComponentObject(ComponentObject) - Static method in class org.apache.storm.Thrift
- deserializeFrom(Input) - Method in class org.apache.storm.serialization.KryoValuesDeserializer
- deserializeFromString(String, Class<T>) - Static method in class org.apache.storm.utils.Utils
-
Deserialize an object stored in a string.
- deserializeKerberosTicket(byte[]) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
- deserializeObject(byte[]) - Method in class org.apache.storm.serialization.KryoValuesDeserializer
- deserializeSSLFile(String, String, Map<String, String>) - Static method in class org.apache.storm.security.auth.AutoSSL
- DeserializingConnectionCallback - Class in org.apache.storm.messaging
-
A class that is called when a TaskMessage arrives.
- DeserializingConnectionCallback(Map<String, Object>, GeneralTopologyContext, WorkerState.ILocalTransferCallback) - Constructor for class org.apache.storm.messaging.DeserializingConnectionCallback
- dest - Variable in class org.apache.storm.tuple.AddressedTuple
- destination() - Method in class org.apache.storm.jms.example.SpringJmsProvider
- destination() - Method in interface org.apache.storm.jms.JmsProvider
-
Provides the
Destination
(topic or queue) from which theJmsSpout
will receive messages. - destroy() - Method in class org.apache.storm.daemon.drpc.webapp.ReqContextFilter
- destroy() - Method in class org.apache.storm.daemon.ui.filters.HeaderResponseServletFilter
- destroy() - Method in class org.apache.storm.daemon.ui.TestingFilter
- destroy() - Method in class org.apache.storm.logging.filters.AccessLoggingFilter
- destroy() - Method in class org.apache.storm.utils.ShellProcess
- detachOnRun() - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Add -d option.
- DETAILS - Enum constant in enum class org.apache.storm.generated.HBPulse._Fields
- DETERMINISTIC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DEV_ZOOKEEPER_PATH - Static variable in class org.apache.storm.DaemonConfig
-
The path to use as the zookeeper dir when running a zookeeper server via "storm dev-zookeeper".
- Device - Class in org.apache.storm.container.cgroup
-
a class that represents a device in linux.
- Device(int, int) - Constructor for class org.apache.storm.container.cgroup.Device
- Device(String) - Constructor for class org.apache.storm.container.cgroup.Device
- devices - Enum constant in enum class org.apache.storm.container.cgroup.SubSystemType
- DevicesCore - Class in org.apache.storm.container.cgroup.core
- DevicesCore(String) - Constructor for class org.apache.storm.container.cgroup.core.DevicesCore
- DevicesCore.Record - Class in org.apache.storm.container.cgroup.core
- DevNullBolt - Class in org.apache.storm.perf.bolt
- DevNullBolt() - Constructor for class org.apache.storm.perf.bolt.DevNullBolt
- DevZookeeper - Class in org.apache.storm.command
- DevZookeeper() - Constructor for class org.apache.storm.command.DevZookeeper
- DIAGNOSTICS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- didMainProcessExit() - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- didMainProcessExit() - Method in class org.apache.storm.daemon.supervisor.Container
-
Return true if the main process exited, else false.
- didMainProcessExit() - Method in class org.apache.storm.daemon.supervisor.LocalContainer
- DIGEST - Enum constant in enum class org.apache.storm.pacemaker.codec.ThriftNettyClientCodec.AuthMethod
- DIGEST - Enum constant in enum class org.apache.storm.pacemaker.codec.ThriftNettyServerCodec.AuthMethod
- DIGEST - Static variable in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
- DigestSaslTransportPlugin - Class in org.apache.storm.security.auth.digest
- DigestSaslTransportPlugin() - Constructor for class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
- DIGIT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DimensionalReporter - Class in org.apache.storm.metrics2
-
Class that allows using a ScheduledReporter to report V2 task metrics with support for dimensions.
- DimensionalReporter(MetricRegistryProvider, ScheduledReporter, DimensionalReporter.DimensionHandler, String, MetricFilter, TimeUnit, TimeUnit, ScheduledExecutorService, boolean) - Constructor for class org.apache.storm.metrics2.DimensionalReporter
-
Constructor.
- DimensionalReporter.DimensionHandler - Interface in org.apache.storm.metrics2
- dimensions - Variable in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
- DIR_LOCK_FILE - Static variable in class org.apache.storm.hdfs.spout.DirLock
- direct(NullStruct) - Static method in class org.apache.storm.generated.Grouping
- DIRECT - Enum constant in enum class org.apache.storm.flux.model.GroupingDef.Type
- DIRECT - Enum constant in enum class org.apache.storm.generated.Grouping._Fields
- DIRECT - Enum constant in enum class org.apache.storm.generated.StreamInfo._Fields
- DIRECT - Static variable in class org.apache.storm.daemon.GrouperFactory
- directGrouping() - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- directGrouping(String) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- directGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
-
A stream grouped this way means that the producer of the tuple decides which task of the consumer will receive this tuple.
- directGrouping(String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- directGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
-
A stream grouped this way means that the producer of the tuple decides which task of the consumer will receive this tuple.
- directGrouping(String, String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- DirectoryCleaner - Class in org.apache.storm.daemon.logviewer.utils
-
Provide methods to help Logviewer to clean up files in directories and to get a list of files without worrying about excessive memory usage.
- DirectoryCleaner(StormMetricsRegistry) - Constructor for class org.apache.storm.daemon.logviewer.utils.DirectoryCleaner
- directOutputFields(List<String>) - Static method in class org.apache.storm.Thrift
- DirLock - Class in org.apache.storm.hdfs.spout
-
Facility to synchronize access to HDFS directory.
- DISABLE_SYMLINKS - Static variable in class org.apache.storm.Config
-
On some systems (windows for example) symlinks require special privileges that not everyone wants to grant a headless user.
- disable_tracing() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Disable tracing.
- disableDetach() - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Disable detach.
- DISALLOW - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DisallowedStrategyException - Exception in org.apache.storm.utils
- DisallowedStrategyException(String, List<String>) - Constructor for exception org.apache.storm.utils.DisallowedStrategyException
- disconnect() - Method in interface org.apache.storm.cluster.IStormClusterState
- disconnect() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- DISCONNECT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DISPATCH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- displayByteArray(byte[]) - Static method in class org.apache.storm.utils.WritableUtils
-
Test Utility Method Display Byte Array.
- dispose() - Method in class org.apache.storm.security.auth.plain.SaslPlainServer
-
Deprecated.
- DISTINCT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DistributedRPC - Class in org.apache.storm.generated
- DistributedRPC() - Constructor for class org.apache.storm.generated.DistributedRPC
- DistributedRPC.AsyncClient - Class in org.apache.storm.generated
- DistributedRPC.AsyncClient.execute_call - Class in org.apache.storm.generated
- DistributedRPC.AsyncClient.Factory - Class in org.apache.storm.generated
- DistributedRPC.AsyncIface - Interface in org.apache.storm.generated
- DistributedRPC.AsyncProcessor<I extends DistributedRPC.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPC.AsyncProcessor.execute<I extends DistributedRPC.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPC.Client - Class in org.apache.storm.generated
- DistributedRPC.Client.Factory - Class in org.apache.storm.generated
- DistributedRPC.execute_args - Class in org.apache.storm.generated
- DistributedRPC.execute_args._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPC.execute_result - Class in org.apache.storm.generated
- DistributedRPC.execute_result._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPC.Iface - Interface in org.apache.storm.generated
- DistributedRPC.Processor<I extends DistributedRPC.Iface> - Class in org.apache.storm.generated
- DistributedRPC.Processor.execute<I extends DistributedRPC.Iface> - Class in org.apache.storm.generated
- DistributedRPCInvocations - Class in org.apache.storm.generated
- DistributedRPCInvocations() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations
- DistributedRPCInvocations.AsyncClient - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncClient.Factory - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncClient.failRequest_call - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncClient.failRequestV2_call - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncClient.fetchRequest_call - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncClient.result_call - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncIface - Interface in org.apache.storm.generated
- DistributedRPCInvocations.AsyncProcessor<I extends DistributedRPCInvocations.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncProcessor.failRequest<I extends DistributedRPCInvocations.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncProcessor.failRequestV2<I extends DistributedRPCInvocations.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncProcessor.fetchRequest<I extends DistributedRPCInvocations.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.AsyncProcessor.result<I extends DistributedRPCInvocations.AsyncIface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.Client - Class in org.apache.storm.generated
- DistributedRPCInvocations.Client.Factory - Class in org.apache.storm.generated
- DistributedRPCInvocations.failRequest_args - Class in org.apache.storm.generated
- DistributedRPCInvocations.failRequest_args._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.failRequest_result - Class in org.apache.storm.generated
- DistributedRPCInvocations.failRequest_result._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.failRequestV2_args - Class in org.apache.storm.generated
- DistributedRPCInvocations.failRequestV2_args._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.failRequestV2_result - Class in org.apache.storm.generated
- DistributedRPCInvocations.failRequestV2_result._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.fetchRequest_args - Class in org.apache.storm.generated
- DistributedRPCInvocations.fetchRequest_args._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.fetchRequest_result - Class in org.apache.storm.generated
- DistributedRPCInvocations.fetchRequest_result._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.Iface - Interface in org.apache.storm.generated
- DistributedRPCInvocations.Processor<I extends DistributedRPCInvocations.Iface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.Processor.failRequest<I extends DistributedRPCInvocations.Iface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.Processor.failRequestV2<I extends DistributedRPCInvocations.Iface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.Processor.fetchRequest<I extends DistributedRPCInvocations.Iface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.Processor.result<I extends DistributedRPCInvocations.Iface> - Class in org.apache.storm.generated
- DistributedRPCInvocations.result_args - Class in org.apache.storm.generated
- DistributedRPCInvocations.result_args._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DistributedRPCInvocations.result_result - Class in org.apache.storm.generated
- DistributedRPCInvocations.result_result._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DNSToSwitchMapping - Interface in org.apache.storm.networktopography
-
An interface that must be implemented to allow pluggable DNS-name/IP-address to RackID resolvers.
- DO_REBALANCE - Enum constant in enum class org.apache.storm.daemon.nimbus.TopologyActions
- DockerCommand - Class in org.apache.storm.container.docker
- DockerCommand(String) - Constructor for class org.apache.storm.container.docker.DockerCommand
- DockerExecCommand - Class in org.apache.storm.container.docker
-
Encapsulates the docker exec command and its command line arguments.
- DockerExecCommand(String) - Constructor for class org.apache.storm.container.docker.DockerExecCommand
- DockerInspectCommand - Class in org.apache.storm.container.docker
-
Encapsulates the docker inspect command and its command line arguments.
- DockerInspectCommand(String) - Constructor for class org.apache.storm.container.docker.DockerInspectCommand
- DockerManager - Class in org.apache.storm.container.docker
-
For security, we can launch worker processes inside the docker container.
- DockerManager() - Constructor for class org.apache.storm.container.docker.DockerManager
- DockerPsCommand - Class in org.apache.storm.container.docker
- DockerPsCommand() - Constructor for class org.apache.storm.container.docker.DockerPsCommand
- DockerRmCommand - Class in org.apache.storm.container.docker
-
Encapsulates the docker rm command and its command line arguments.
- DockerRmCommand(String) - Constructor for class org.apache.storm.container.docker.DockerRmCommand
- DockerRunCommand - Class in org.apache.storm.container.docker
-
Encapsulates the docker run command and its command line arguments.
- DockerRunCommand(String, String, String) - Constructor for class org.apache.storm.container.docker.DockerRunCommand
-
The Construction function.
- DockerStopCommand - Class in org.apache.storm.container.docker
-
Encapsulates the docker stop command and its command line arguments.
- DockerStopCommand(String) - Constructor for class org.apache.storm.container.docker.DockerStopCommand
- DockerWaitCommand - Class in org.apache.storm.container.docker
-
Encapsulates the docker wait command and its command line arguments.
- DockerWaitCommand(String) - Constructor for class org.apache.storm.container.docker.DockerWaitCommand
- doCleanup() - Method in class org.apache.storm.daemon.nimbus.Nimbus
-
Cleanup topologies and Jars.
- doClose() - Method in class org.apache.storm.hdfs.common.AbstractHDFSWriter
- doClose() - Method in class org.apache.storm.hdfs.common.AvroGenericRecordHDFSWriter
- doClose() - Method in class org.apache.storm.hdfs.common.HDFSWriter
- doClose() - Method in class org.apache.storm.hdfs.common.SequenceFileWriter
- doCommit(Long) - Method in class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
- doCommit(Long) - Method in class org.apache.storm.hdfs.trident.HdfsState.SequenceFileOptions
- doConnectWithRetry(ITransportPlugin, TTransport, String, String) - Method in class org.apache.storm.security.auth.TBackoffConnect
- doExecutorHeartbeats() - Method in class org.apache.storm.daemon.worker.Worker
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.storm.daemon.drpc.webapp.ReqContextFilter
-
A filter which populates the request if it is null and then passes it on to the next entity in the chain.
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.storm.daemon.ui.filters.HeaderResponseServletFilter
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.storm.daemon.ui.TestingFilter
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.storm.logging.filters.AccessLoggingFilter
- doGet(String, String, String, Integer) - Method in class org.apache.storm.scheduler.utils.ArtifactoryConfigLoader
-
Protected so we can override this in unit tests.
- doHeartBeat() - Method in class org.apache.storm.daemon.worker.Worker
- doInnerJoin(JoinBolt.JoinAccumulator, Map<Object, ArrayList<Tuple>>, JoinBolt.JoinInfo, boolean) - Method in class org.apache.storm.bolt.JoinBolt
- doJoin(JoinBolt.JoinAccumulator, HashMap<Object, ArrayList<Tuple>>, JoinBolt.JoinInfo, boolean) - Method in class org.apache.storm.bolt.JoinBolt
- doLeftJoin(JoinBolt.JoinAccumulator, Map<Object, ArrayList<Tuple>>, JoinBolt.JoinInfo, boolean) - Method in class org.apache.storm.bolt.JoinBolt
- DOLLAR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DOMAIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- Done() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Reset buffer when finished.
- doPrepare(Map<String, Object>) - Method in class org.apache.storm.common.AbstractHadoopAutoCreds
-
Prepare the plugin.
- doPrepare(Map<String, Object>) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
-
Prepare the plugin.
- doPrepare(Map<String, Object>) - Method in class org.apache.storm.hbase.security.AutoHBase
- doPrepare(Map<String, Object>) - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- doPrepare(Map<String, Object>) - Method in class org.apache.storm.hdfs.security.AutoHDFS
- doPrepare(Map<String, Object>) - Method in class org.apache.storm.hdfs.security.AutoHDFSNimbus
- doPrepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- doPrepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.storm.hdfs.bolt.AvroGenericRecordBolt
- doPrepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.storm.hdfs.bolt.HdfsBolt
- doPrepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.storm.hdfs.bolt.SequenceFileBolt
- doPrepare(Map<String, Object>, TopologyContext, OutputCollector, Collection<Event<Tuple>>, boolean) - Method in class org.apache.storm.topology.WindowedBoltExecutor
- doProjection(ArrayList<Tuple>, JoinBolt.FieldSelector[]) - Method in class org.apache.storm.bolt.JoinBolt
- doReconnect() - Method in class org.apache.storm.pacemaker.PacemakerClient
- doRefreshLoad() - Method in class org.apache.storm.daemon.worker.Worker
- doRenew(Map<String, String>, Map<String, Object>, String) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- doRenew(Map<String, String>, Map<String, Object>, String) - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- doRenew(Map<String, String>, Map<String, Object>, String) - Method in class org.apache.storm.hdfs.security.AutoHDFSNimbus
- doRequiredTopoFilesExist(Map<String, Object>, String) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Sanity check if everything the topology needs is there for it to run.
- doRequiredTopoFilesExist(Map<String, Object>, String) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Sanity check if everything the topology needs is there for it to run.
- doSanityCheck - Variable in class org.apache.storm.task.GeneralTopologyContext
- doSanityCheck() - Method in class org.apache.storm.task.GeneralTopologyContext
- doStart() - Method in class org.apache.storm.daemon.common.ReloadableSslContextFactory
- doStop() - Method in class org.apache.storm.daemon.common.ReloadableSslContextFactory
- doSync() - Method in class org.apache.storm.hdfs.common.AbstractHDFSWriter
- doSync() - Method in class org.apache.storm.hdfs.common.AvroGenericRecordHDFSWriter
- doSync() - Method in class org.apache.storm.hdfs.common.HDFSWriter
- doSync() - Method in class org.apache.storm.hdfs.common.SequenceFileWriter
- DOT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DOUBLE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- double_arg(double) - Static method in class org.apache.storm.generated.JavaObjectArg
- DOUBLE_ARG - Enum constant in enum class org.apache.storm.generated.JavaObjectArg._Fields
- DOUBLE_PERIOD - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DOUBLE_QUOTE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DoubleValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.DoubleValidator
- DOW - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- downloadBlobChunk() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadBlobChunk
- downloadBlobChunk() - Constructor for class org.apache.storm.generated.Nimbus.Processor.downloadBlobChunk
- downloadBlobChunk(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- downloadBlobChunk(String) - Method in class org.apache.storm.generated.Nimbus.Client
- downloadBlobChunk(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- downloadBlobChunk(String) - Method in class org.apache.storm.LocalCluster
- downloadBlobChunk(String, AsyncMethodCallback<ByteBuffer>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- downloadBlobChunk(String, AsyncMethodCallback<ByteBuffer>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- downloadBlobChunk_args() - Constructor for class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- downloadBlobChunk_args(String) - Constructor for class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- downloadBlobChunk_args(Nimbus.downloadBlobChunk_args) - Constructor for class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
-
Performs a deep copy on other.
- downloadBlobChunk_call(String, AsyncMethodCallback<ByteBuffer>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.downloadBlobChunk_call
- downloadBlobChunk_result() - Constructor for class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- downloadBlobChunk_result(ByteBuffer, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- downloadBlobChunk_result(Nimbus.downloadBlobChunk_result) - Constructor for class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
-
Performs a deep copy on other.
- downloadChunk() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadChunk
- downloadChunk() - Constructor for class org.apache.storm.generated.Nimbus.Processor.downloadChunk
- downloadChunk(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- downloadChunk(String) - Method in class org.apache.storm.generated.Nimbus.Client
- downloadChunk(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- downloadChunk(String) - Method in class org.apache.storm.LocalCluster
- downloadChunk(String, AsyncMethodCallback<ByteBuffer>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- downloadChunk(String, AsyncMethodCallback<ByteBuffer>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- downloadChunk_args() - Constructor for class org.apache.storm.generated.Nimbus.downloadChunk_args
- downloadChunk_args(String) - Constructor for class org.apache.storm.generated.Nimbus.downloadChunk_args
- downloadChunk_args(Nimbus.downloadChunk_args) - Constructor for class org.apache.storm.generated.Nimbus.downloadChunk_args
-
Performs a deep copy on other.
- downloadChunk_call(String, AsyncMethodCallback<ByteBuffer>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.downloadChunk_call
- downloadChunk_result() - Constructor for class org.apache.storm.generated.Nimbus.downloadChunk_result
- downloadChunk_result(ByteBuffer, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.downloadChunk_result
- downloadChunk_result(Nimbus.downloadChunk_result) - Constructor for class org.apache.storm.generated.Nimbus.downloadChunk_result
-
Performs a deep copy on other.
- downloadDaemonLogFile(HttpServletRequest) - Method in class org.apache.storm.daemon.logviewer.webapp.LogviewerResource
-
Handles '/daemondownload' (downloading specific daemon log file) request.
- downloadDaemonLogFile(String, String, String) - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogDownloadHandler
-
Download a daemon log.
- downloadDumpFile(String, String, String, HttpServletRequest) - Method in class org.apache.storm.daemon.logviewer.webapp.LogviewerResource
-
Handles '/dumps' (downloading specific dump file) request.
- downloadDumpFile(String, String, String, String) - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerProfileHandler
-
Download a dump file.
- downloadFile(String, String, String, boolean) - Method in class org.apache.storm.daemon.logviewer.utils.LogFileDownloader
-
Checks authorization for the log file and download.
- downloadLogFile(HttpServletRequest) - Method in class org.apache.storm.daemon.logviewer.webapp.LogviewerResource
-
Handles '/download' (downloading specific log file) request.
- downloadLogFile(String, String, String) - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogDownloadHandler
-
Download a worker log.
- downloadMissingBlob(Map<String, Object>, BlobStore, String, Set<NimbusInfo>) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- downloadUpdatedBlob(Map<String, Object>, BlobStore, String, Set<NimbusInfo>) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- doWrite(Tuple) - Method in class org.apache.storm.hdfs.common.AbstractHDFSWriter
- doWrite(Tuple) - Method in class org.apache.storm.hdfs.common.AvroGenericRecordHDFSWriter
- doWrite(Tuple) - Method in class org.apache.storm.hdfs.common.HDFSWriter
- doWrite(Tuple) - Method in class org.apache.storm.hdfs.common.SequenceFileWriter
- DOY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DQID - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
Lexical state.
- drain() - Method in class org.apache.storm.messaging.netty.MessageBuffer
- drop(List<T>, int) - Static method in class org.apache.storm.daemon.utils.ListFunctionalSupport
-
Drop the first N elements and create a new list.
- DROP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DRPC - Class in org.apache.storm.daemon.drpc
- DRPC - Enum constant in enum class org.apache.storm.generated.WorkerTokenServiceType
- DRPC - Enum constant in enum class org.apache.storm.security.auth.ThriftConnectionType
- DRPC - Enum constant in enum class org.apache.storm.trident.planner.SpoutNode.SpoutType
- DRPC(StormMetricsRegistry, Map<String, Object>) - Constructor for class org.apache.storm.daemon.drpc.DRPC
- DRPC(StormMetricsRegistry, IAuthorizer, long) - Constructor for class org.apache.storm.daemon.drpc.DRPC
- DRPC_AUTHORIZER - Static variable in class org.apache.storm.DaemonConfig
-
Class name for authorization plugin for DRPC client.
- DRPC_AUTHORIZER_ACL - Static variable in class org.apache.storm.Config
-
The Access Control List for the DRPC Authorizer.
- DRPC_AUTHORIZER_ACL_FILENAME - Static variable in class org.apache.storm.Config
-
File name of the DRPC Authorizer ACL.
- DRPC_AUTHORIZER_ACL_STRICT - Static variable in class org.apache.storm.Config
-
Whether the DRPCSimpleAclAuthorizer should deny requests for operations involving functions that have no explicit ACL entry.
- DRPC_CHILDOPTS - Static variable in class org.apache.storm.DaemonConfig
-
Childopts for Storm DRPC Java process.
- DRPC_DISABLE_HTTP_BINDING - Static variable in class org.apache.storm.DaemonConfig
-
This controls wheather Storm DRPC should bind to http port even if drpc.http.port is > 0.
- DRPC_HTTP_CREDS_PLUGIN - Static variable in class org.apache.storm.DaemonConfig
-
Class name of the HTTP credentials plugin for DRPC.
- DRPC_HTTP_FILTER - Static variable in class org.apache.storm.DaemonConfig
-
A class implementing jakarta.servlet.Filter for DRPC HTTP requests.
- DRPC_HTTP_FILTER_PARAMS - Static variable in class org.apache.storm.DaemonConfig
-
Initialization parameters for the jakarta.servlet.Filter of the DRPC HTTP service.
- DRPC_HTTP_PORT - Static variable in class org.apache.storm.DaemonConfig
-
This port is used by Storm DRPC for receiving HTTP DPRC requests from clients.
- DRPC_HTTPS_ENABLE_SSL_RELOAD - Static variable in class org.apache.storm.DaemonConfig
-
If set to true, keystore and truststore for DRPC Server will be automatically reloaded when modified.
- DRPC_HTTPS_KEY_PASSWORD - Static variable in class org.apache.storm.DaemonConfig
-
Password to the private key in the keystore for setting up HTTPS (SSL).
- DRPC_HTTPS_KEYSTORE_PASSWORD - Static variable in class org.apache.storm.DaemonConfig
-
Password to the keystore used by Storm DRPC for setting up HTTPS (SSL).
- DRPC_HTTPS_KEYSTORE_PATH - Static variable in class org.apache.storm.DaemonConfig
-
Path to the keystore used by Storm DRPC for setting up HTTPS (SSL).
- DRPC_HTTPS_KEYSTORE_TYPE - Static variable in class org.apache.storm.DaemonConfig
-
Type of keystore used by Storm DRPC for setting up HTTPS (SSL).
- DRPC_HTTPS_NEED_CLIENT_AUTH - Static variable in class org.apache.storm.DaemonConfig
- DRPC_HTTPS_PORT - Static variable in class org.apache.storm.DaemonConfig
-
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
- DRPC_HTTPS_TRUSTSTORE_PASSWORD - Static variable in class org.apache.storm.DaemonConfig
-
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
- DRPC_HTTPS_TRUSTSTORE_PATH - Static variable in class org.apache.storm.DaemonConfig
-
Path to the truststore used by Storm DRPC setting up HTTPS (SSL).
- DRPC_HTTPS_TRUSTSTORE_TYPE - Static variable in class org.apache.storm.DaemonConfig
-
Type of truststore used by Storm DRPC for setting up HTTPS (SSL).
- DRPC_HTTPS_WANT_CLIENT_AUTH - Static variable in class org.apache.storm.DaemonConfig
-
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
- DRPC_INVOCATIONS - Enum constant in enum class org.apache.storm.security.auth.ThriftConnectionType
- DRPC_INVOCATIONS_PORT - Static variable in class org.apache.storm.Config
-
This port on Storm DRPC is used by DRPC topologies to receive function invocations and send results back.
- DRPC_INVOCATIONS_THREADS - Static variable in class org.apache.storm.Config
-
DRPC invocations thrift server worker threads.
- DRPC_INVOCATIONS_THRIFT_TRANSPORT_PLUGIN - Static variable in class org.apache.storm.Config
-
The DRPC invocations transport plug-in for Thrift client/server communication.
- DRPC_MAX_BUFFER_SIZE - Static variable in class org.apache.storm.Config
-
The maximum buffer size thrift should use when reading messages for DRPC.
- DRPC_PORT - Static variable in class org.apache.storm.Config
-
This port is used by Storm DRPC for receiving DPRC requests from clients.
- DRPC_QUEUE_SIZE - Static variable in class org.apache.storm.Config
-
DRPC thrift server queue size.
- DRPC_REQUEST_TIMEOUT_SECS - Static variable in class org.apache.storm.DaemonConfig
-
The timeout on DRPC requests within the DRPC server.
- DRPC_SERVERS - Static variable in class org.apache.storm.Config
-
List of DRPC servers so that the DRPCSpout knows who to talk to.
- DRPC_THRIFT_TRANSPORT_PLUGIN - Static variable in class org.apache.storm.Config
-
The DRPC transport plug-in for Thrift client/server communication.
- DRPC_WORKER_THREADS - Static variable in class org.apache.storm.Config
-
DRPC thrift server worker threads.
- DRPCApplication - Class in org.apache.storm.daemon.drpc.webapp
- DRPCApplication() - Constructor for class org.apache.storm.daemon.drpc.webapp.DRPCApplication
-
Constructor.
- DRPCAuthorizerBase - Class in org.apache.storm.security.auth.authorizer
- DRPCAuthorizerBase() - Constructor for class org.apache.storm.security.auth.authorizer.DRPCAuthorizerBase
- DRPCClient - Class in org.apache.storm.utils
- DRPCClient(Map<String, Object>, String, int) - Constructor for class org.apache.storm.utils.DRPCClient
- DRPCClient(Map<String, Object>, String, int, Integer) - Constructor for class org.apache.storm.utils.DRPCClient
- DRPCClient.LocalOverride - Class in org.apache.storm.utils
- DRPCExceptionMapper - Class in org.apache.storm.daemon.drpc.webapp
- DRPCExceptionMapper() - Constructor for class org.apache.storm.daemon.drpc.webapp.DRPCExceptionMapper
- DRPCExceptionType - Enum Class in org.apache.storm.generated
- DRPCExecutionException - Exception in org.apache.storm.generated
- DRPCExecutionException() - Constructor for exception org.apache.storm.generated.DRPCExecutionException
- DRPCExecutionException(String) - Constructor for exception org.apache.storm.generated.DRPCExecutionException
- DRPCExecutionException(DRPCExecutionException) - Constructor for exception org.apache.storm.generated.DRPCExecutionException
-
Performs a deep copy on other.
- DRPCExecutionException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DRPCInvocationsClient - Class in org.apache.storm.drpc
- DRPCInvocationsClient(Map<String, Object>, String, int) - Constructor for class org.apache.storm.drpc.DRPCInvocationsClient
- DRPCRequest - Class in org.apache.storm.generated
- DRPCRequest() - Constructor for class org.apache.storm.generated.DRPCRequest
- DRPCRequest(String, String) - Constructor for class org.apache.storm.generated.DRPCRequest
- DRPCRequest(DRPCRequest) - Constructor for class org.apache.storm.generated.DRPCRequest
-
Performs a deep copy on other.
- DRPCRequest._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- DRPCResource - Class in org.apache.storm.daemon.drpc.webapp
- DRPCResource(DRPC, StormMetricsRegistry) - Constructor for class org.apache.storm.daemon.drpc.webapp.DRPCResource
- DRPCServer - Class in org.apache.storm.daemon.drpc
- DRPCServer(Map<String, Object>, StormMetricsRegistry) - Constructor for class org.apache.storm.daemon.drpc.DRPCServer
-
Constructor.
- DRPCSimpleACLAuthorizer - Class in org.apache.storm.security.auth.authorizer
- DRPCSimpleACLAuthorizer() - Constructor for class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
- DRPCSimpleACLAuthorizer.AclFunctionEntry - Class in org.apache.storm.security.auth.authorizer
- DRPCSpout - Class in org.apache.storm.drpc
- DRPCSpout(String) - Constructor for class org.apache.storm.drpc.DRPCSpout
- DRPCSpout(String, ILocalDRPC) - Constructor for class org.apache.storm.drpc.DRPCSpout
- DRPCThrift - Class in org.apache.storm.daemon.drpc
- DRPCThrift(DRPC) - Constructor for class org.apache.storm.daemon.drpc.DRPCThrift
- dstAddressPrefixedName - Variable in class org.apache.storm.messaging.netty.Client
- DUMMY_FIELD - Static variable in interface org.apache.storm.st.topology.TestableTopology
- dump(File, String) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Dump a string to a file.
- dump(File, String) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Dump a string to a file.
- dumpState(PrintStream) - Method in class org.apache.storm.hdfs.spout.ProgressTracker
- dumpTopology() - Method in class org.apache.storm.networktopography.AbstractDNSToSwitchMapping
-
Generate a string listing the switch mapping implementation, the mapping for every known node and the number of nodes and unique switches known about -each entry to a separate line.
- Duration(int, TimeUnit) - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt.Duration
- DYNAMIC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DYNAMIC_FUNCTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DYNAMIC_FUNCTION_CODE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- DynamicParam() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a dynamic parameter marker.
E
- E - Enum constant in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
- E - Enum constant in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
- each(Function, Fields) - Method in class org.apache.storm.trident.Stream
- each(Fields, Filter) - Method in class org.apache.storm.trident.Stream
- each(Fields, Function, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
- each(Fields, Function, Fields) - Method in interface org.apache.storm.trident.fluent.IAggregatableStream
- each(Fields, Function, Fields) - Method in class org.apache.storm.trident.Stream
- EACH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EachOperation - Interface in org.apache.storm.trident.operation
- EachProcessor - Class in org.apache.storm.trident.planner.processor
- EachProcessor(Fields, Function) - Constructor for class org.apache.storm.trident.planner.processor.EachProcessor
- EARLIEST - Enum constant in enum class org.apache.storm.kafka.spout.FirstPollOffsetStrategy
-
The kafka spout polls records starting in the first offset of the partition, regardless of previous commits.
- earliestRetriableOffsets() - Method in class org.apache.storm.kafka.spout.KafkaSpoutRetryExponentialBackoff
- earliestRetriableOffsets() - Method in interface org.apache.storm.kafka.spout.KafkaSpoutRetryService
-
Gets the earliest retriable offsets.
- ELEMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ELSE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- emit(String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
- emit(String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
- emit(String, Collection<Tuple>, List<Object>) - Method in interface org.apache.storm.task.IOutputCollector
-
Returns the task ids that received the tuples.
- emit(String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
- emit(String, List<Object>) - Method in class org.apache.storm.coordination.BatchOutputCollector
- emit(String, List<Object>) - Method in class org.apache.storm.coordination.BatchOutputCollectorImpl
- emit(String, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a tuple to the specified output stream with a null message id.
- emit(String, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a new unanchored tuple to the specified stream.
- emit(String, List<Object>) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor.AnchoringOutputCollector
- emit(String, List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
- emit(String, List<Object>) - Method in interface org.apache.storm.topology.IBasicOutputCollector
- emit(String, List<Object>, Object) - Method in class org.apache.storm.executor.spout.SpoutOutputCollectorImpl
- emit(String, List<Object>, Object) - Method in interface org.apache.storm.spout.ISpoutOutputCollector
-
Returns the task ids that received the tuples.
- emit(String, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a new tuple to the specified output stream with the given message ID.
- emit(String, Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a new tuple to a specific stream with a single anchor.
- emit(Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a new tuple to the default stream anchored on a group of input tuples.
- emit(List<Object>) - Method in class org.apache.storm.coordination.BatchOutputCollector
-
Emits a tuple to the default output stream.
- emit(List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a tuple to the default output stream with a null message id.
- emit(List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a new unanchored tuple to the default stream.
- emit(List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
- emit(List<Object>) - Method in class org.apache.storm.trident.operation.impl.CaptureCollector
- emit(List<Object>) - Method in class org.apache.storm.trident.operation.impl.GroupCollector
- emit(List<Object>) - Method in interface org.apache.storm.trident.operation.TridentCollector
-
Emits a tuple to a Stream.
- emit(List<Object>) - Method in class org.apache.storm.trident.planner.processor.AppendCollector
- emit(List<Object>) - Method in class org.apache.storm.trident.planner.processor.FreshCollector
- emit(List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a new tuple to the default output stream with the given message ID.
- emit(EmitInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
- emit(EmitInfo) - Method in interface org.apache.storm.hooks.ITaskHook
- emit(Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a new tuple to the default stream anchored on a single tuple.
- emitBatch(long, TridentCollector) - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
- emitBatch(long, TridentCollector) - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
- emitBatch(long, TridentCollector) - Method in interface org.apache.storm.trident.spout.IBatchSpout
- emitBatch(long, TridentCollector) - Method in class org.apache.storm.trident.testing.FixedBatchSpout
- emitBatch(TransactionAttempt, Object, TridentCollector) - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.BatchSpoutEmitter
- emitBatch(TransactionAttempt, Object, TridentCollector) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Emitter
- emitBatch(TransactionAttempt, X, TridentCollector) - Method in interface org.apache.storm.trident.spout.ITridentSpout.Emitter
-
Emit a batch for the specified transaction attempt and metadata for the transaction.
- emitBatchNew(TransactionAttempt, TridentCollector, Set<KafkaTridentSpoutTopicPartition>, Map<KafkaTridentSpoutTopicPartition, Map<String, Object>>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentOpaqueSpoutEmitter
- emitBatchNew(TransactionAttempt, TridentCollector, Set<KafkaTridentSpoutTopicPartition>, Map<KafkaTridentSpoutTopicPartition, Map<String, Object>>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutEmitter
-
Emit a new batch.
- emitBatchNew(TransactionAttempt, TridentCollector, Set<KafkaTridentSpoutTopicPartition>, Map<KafkaTridentSpoutTopicPartition, Map<String, Object>>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentTransactionalSpoutEmitter
- emitBatchNew(TransactionAttempt, TridentCollector, Set<PartitionT>, Map<PartitionT, M>) - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Emitter
-
Emit a batch of tuples for a list of partitions/transactions.
- emitBatchNew(TransactionAttempt, TridentCollector, Set<PartitionT>, Map<PartitionT, X>) - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Emitter
-
Emit a batch of tuples for the partitions that's never been emitted before.
- emitData(List<Object>, HdfsSpout.MessageId) - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
- emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
- emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in interface org.apache.storm.task.IOutputCollector
- emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
- emitDirect(int, String, List<Object>) - Method in class org.apache.storm.coordination.BatchOutputCollector
- emitDirect(int, String, List<Object>) - Method in class org.apache.storm.coordination.BatchOutputCollectorImpl
- emitDirect(int, String, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the specified output stream.
- emitDirect(int, String, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a tuple directly to the specified task id on the specified stream.
- emitDirect(int, String, List<Object>) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor.AnchoringOutputCollector
- emitDirect(int, String, List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
- emitDirect(int, String, List<Object>) - Method in interface org.apache.storm.topology.IBasicOutputCollector
- emitDirect(int, String, List<Object>, Object) - Method in class org.apache.storm.executor.spout.SpoutOutputCollectorImpl
- emitDirect(int, String, List<Object>, Object) - Method in interface org.apache.storm.spout.ISpoutOutputCollector
- emitDirect(int, String, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the specified output stream.
- emitDirect(int, String, Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a tuple directly to the specified task id on the specified stream.
- emitDirect(int, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a tuple directly to the specified task id on the default stream.
- emitDirect(int, List<Object>) - Method in class org.apache.storm.coordination.BatchOutputCollector
-
Emits a tuple to the specified task on the default output stream.
- emitDirect(int, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the default output stream.
- emitDirect(int, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a tuple directly to the specified task id on the default stream.
- emitDirect(int, List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
- emitDirect(int, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the default output stream.
- emitDirect(int, Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
-
Emits a tuple directly to the specified task id on the default stream.
- EmitInfo - Class in org.apache.storm.hooks.info
- EmitInfo(List<Object>, String, int, Collection<Integer>) - Constructor for class org.apache.storm.hooks.info.EmitInfo
- emitsPair() - Method in class org.apache.storm.streams.WindowNode
- EMITTED - Enum constant in enum class org.apache.storm.generated.CommonAggregateStats._Fields
- EMITTED - Enum constant in enum class org.apache.storm.generated.ExecutorStats._Fields
- emittedTuple(String) - Method in class org.apache.storm.metrics2.TaskMetrics
- emittedTuple(String) - Method in class org.apache.storm.stats.CommonStats
- Emitter(String, Map<String, Object>, TopologyContext) - Constructor for class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Emitter
- EmittingProcessorContext<T> - Class in org.apache.storm.streams.processors
-
A context that emits the results to downstream processors which are in another bolt.
- EmittingProcessorContext(ProcessorNode, OutputCollector, String) - Constructor for class org.apache.storm.streams.processors.EmittingProcessorContext
- empty() - Method in class org.apache.storm.clojure.ClojureTuple
- empty() - Method in class org.apache.storm.clojure.IndifferentAccessMap
- empty() - Method in class org.apache.storm.scheduler.resource.normalization.ResourceMapArrayBridge
-
Create an array that has all values 0.
- EMPTY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EMPTY_PENDING_COMMIT_MAP - Static variable in class org.apache.storm.redis.state.RedisKeyValueState
- EMPTY_TUPLE - Static variable in class org.apache.storm.trident.tuple.TridentTupleView
- EmptyCoordinator() - Constructor for class org.apache.storm.trident.spout.BatchSpoutExecutor.EmptyCoordinator
- EmptyKafkaTupleListener - Class in org.apache.storm.kafka.spout
- EmptyKafkaTupleListener() - Constructor for class org.apache.storm.kafka.spout.EmptyKafkaTupleListener
- ENABLE - Enum constant in enum class org.apache.storm.generated.DebugOptions._Fields
- ENABLE - Enum constant in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
- enable_tracing() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Enable tracing.
- enabled - Variable in class org.apache.storm.metrics2.cgroup.CGroupMetricsBase
- enabled() - Static method in class org.apache.storm.container.cgroup.CgroupUtils
- enableDetach() - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Enable detach.
- encode(ChannelHandlerContext, Object, List<Object>) - Method in class org.apache.storm.pacemaker.codec.ThriftEncoder
- encode(ChannelHandlerContext, BackPressureStatus, List<Object>) - Method in class org.apache.storm.messaging.netty.BackPressureStatusEncoder
- encode(ChannelHandlerContext, INettySerializable, ByteBuf) - Method in class org.apache.storm.messaging.netty.NettySerializableMessageEncoder
- encodeKey(K) - Method in class org.apache.storm.state.DefaultStateEncoder
- encodeKey(K) - Method in interface org.apache.storm.state.StateEncoder
-
Encode key.
- encodeLength() - Method in enum class org.apache.storm.messaging.netty.ControlMessage
- encodeLength() - Method in interface org.apache.storm.messaging.netty.INettySerializable
- encodeLength() - Method in class org.apache.storm.messaging.netty.SaslMessageToken
- encodeValue(V) - Method in class org.apache.storm.state.DefaultStateEncoder
- encodeValue(V) - Method in interface org.apache.storm.state.StateEncoder
-
Encode value.
- END - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- END_EXEC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- END_FRAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- END_PARTITION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- endColumn - Variable in class org.apache.storm.sql.parser.impl.Token
-
The column number of the last character of this Token.
- endLine - Variable in class org.apache.storm.sql.parser.impl.Token
-
The line number of the last character of this Token.
- endTask - Variable in class org.apache.storm.scheduler.ExecutorDetails
- endTime() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- endTimeMs - Variable in class org.apache.storm.StormTimer.QueueEntry
- Entry(String, Object) - Constructor for class org.apache.storm.trident.windowing.WindowsStore.Entry
- entryAt(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- entryAt(Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- entrySet() - Method in class org.apache.storm.clojure.ClojureTuple
- entrySet() - Method in class org.apache.storm.clojure.IndifferentAccessMap
- entrySet() - Method in class org.apache.storm.metricstore.rocksdb.StringMetadataCache
-
Get the map of the cache contents.
- entrySet() - Method in interface org.apache.storm.metricstore.rocksdb.WritableStringMetadataCache
-
Get the map of the cache contents.
- entryValidatorClasses() - Element in annotation interface org.apache.storm.validation.ConfigValidationAnnotations.IsListEntryCustom
- enumForId(short) - Method in class org.apache.storm.generated.ComponentObject
- enumForId(short) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- enumForId(short) - Method in class org.apache.storm.generated.Grouping
- enumForId(short) - Method in class org.apache.storm.generated.HBMessageData
- enumForId(short) - Method in class org.apache.storm.generated.JavaObjectArg
- enumForId(short) - Method in class org.apache.storm.generated.SpecificAggregateStats
- enumForId(short) - Method in class org.apache.storm.generated.TopologyActionOptions
- EnumUtil - Class in org.apache.storm.utils
- EnumUtil() - Constructor for class org.apache.storm.utils.EnumUtil
- EOB_MESSAGE - Enum constant in enum class org.apache.storm.messaging.netty.ControlMessage
- EOF - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
End of File.
- EOL - Static variable in exception org.apache.storm.sql.parser.impl.ParseException
-
The end of line string for this machine.
- EPOCH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EQ - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- equals(Object) - Method in class org.apache.storm.container.cgroup.CgroupCommon
- equals(Object) - Method in class org.apache.storm.container.cgroup.core.CpuCore.Stat
- equals(Object) - Method in class org.apache.storm.container.cgroup.core.DevicesCore.Record
- equals(Object) - Method in class org.apache.storm.container.cgroup.Device
- equals(Object) - Method in class org.apache.storm.container.cgroup.Hierarchy
- equals(Object) - Method in class org.apache.storm.container.cgroup.SubSystem
- equals(Object) - Method in class org.apache.storm.generated.AccessControl
- equals(Object) - Method in exception org.apache.storm.generated.AlreadyAliveException
- equals(Object) - Method in class org.apache.storm.generated.Assignment
- equals(Object) - Method in exception org.apache.storm.generated.AuthorizationException
- equals(Object) - Method in class org.apache.storm.generated.BeginDownloadResult
- equals(Object) - Method in class org.apache.storm.generated.Bolt
- equals(Object) - Method in class org.apache.storm.generated.BoltAggregateStats
- equals(Object) - Method in class org.apache.storm.generated.BoltStats
- equals(Object) - Method in class org.apache.storm.generated.ClusterSummary
- equals(Object) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- equals(Object) - Method in class org.apache.storm.generated.CommonAggregateStats
- equals(Object) - Method in class org.apache.storm.generated.ComponentAggregateStats
- equals(Object) - Method in class org.apache.storm.generated.ComponentCommon
- equals(Object) - Method in class org.apache.storm.generated.ComponentObject
- equals(Object) - Method in class org.apache.storm.generated.ComponentPageInfo
- equals(Object) - Method in class org.apache.storm.generated.Credentials
- equals(Object) - Method in class org.apache.storm.generated.DebugOptions
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- equals(Object) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- equals(Object) - Method in exception org.apache.storm.generated.DRPCExecutionException
- equals(Object) - Method in class org.apache.storm.generated.DRPCRequest
- equals(Object) - Method in class org.apache.storm.generated.ErrorInfo
- equals(Object) - Method in class org.apache.storm.generated.ExecutorAggregateStats
- equals(Object) - Method in class org.apache.storm.generated.ExecutorInfo
- equals(Object) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- equals(Object) - Method in class org.apache.storm.generated.ExecutorStats
- equals(Object) - Method in class org.apache.storm.generated.ExecutorSummary
- equals(Object) - Method in class org.apache.storm.generated.GetInfoOptions
- equals(Object) - Method in class org.apache.storm.generated.GlobalStreamId
- equals(Object) - Method in class org.apache.storm.generated.Grouping
- equals(Object) - Method in exception org.apache.storm.generated.HBAuthorizationException
- equals(Object) - Method in exception org.apache.storm.generated.HBExecutionException
- equals(Object) - Method in class org.apache.storm.generated.HBMessage
- equals(Object) - Method in class org.apache.storm.generated.HBMessageData
- equals(Object) - Method in class org.apache.storm.generated.HBNodes
- equals(Object) - Method in class org.apache.storm.generated.HBPulse
- equals(Object) - Method in class org.apache.storm.generated.HBRecords
- equals(Object) - Method in exception org.apache.storm.generated.IllegalStateException
- equals(Object) - Method in exception org.apache.storm.generated.InvalidTopologyException
- equals(Object) - Method in class org.apache.storm.generated.JavaObject
- equals(Object) - Method in class org.apache.storm.generated.JavaObjectArg
- equals(Object) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- equals(Object) - Method in exception org.apache.storm.generated.KeyNotFoundException
- equals(Object) - Method in class org.apache.storm.generated.KillOptions
- equals(Object) - Method in class org.apache.storm.generated.ListBlobsResult
- equals(Object) - Method in class org.apache.storm.generated.LocalAssignment
- equals(Object) - Method in class org.apache.storm.generated.LocalStateData
- equals(Object) - Method in class org.apache.storm.generated.LogConfig
- equals(Object) - Method in class org.apache.storm.generated.LogLevel
- equals(Object) - Method in class org.apache.storm.generated.LSApprovedWorkers
- equals(Object) - Method in class org.apache.storm.generated.LSSupervisorAssignments
- equals(Object) - Method in class org.apache.storm.generated.LSSupervisorId
- equals(Object) - Method in class org.apache.storm.generated.LSTopoHistory
- equals(Object) - Method in class org.apache.storm.generated.LSTopoHistoryList
- equals(Object) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.activate_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.activate_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.debug_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.debug_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- equals(Object) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- equals(Object) - Method in class org.apache.storm.generated.NimbusSummary
- equals(Object) - Method in class org.apache.storm.generated.NodeInfo
- equals(Object) - Method in exception org.apache.storm.generated.NotAliveException
- equals(Object) - Method in class org.apache.storm.generated.NullStruct
- equals(Object) - Method in class org.apache.storm.generated.OwnerResourceSummary
- equals(Object) - Method in class org.apache.storm.generated.PrivateWorkerKey
- equals(Object) - Method in class org.apache.storm.generated.ProfileRequest
- equals(Object) - Method in class org.apache.storm.generated.ReadableBlobMeta
- equals(Object) - Method in class org.apache.storm.generated.RebalanceOptions
- equals(Object) - Method in class org.apache.storm.generated.SettableBlobMeta
- equals(Object) - Method in class org.apache.storm.generated.SharedMemory
- equals(Object) - Method in class org.apache.storm.generated.ShellComponent
- equals(Object) - Method in class org.apache.storm.generated.SpecificAggregateStats
- equals(Object) - Method in class org.apache.storm.generated.SpoutAggregateStats
- equals(Object) - Method in class org.apache.storm.generated.SpoutSpec
- equals(Object) - Method in class org.apache.storm.generated.SpoutStats
- equals(Object) - Method in class org.apache.storm.generated.StateSpoutSpec
- equals(Object) - Method in class org.apache.storm.generated.StormBase
- equals(Object) - Method in class org.apache.storm.generated.StormTopology
- equals(Object) - Method in class org.apache.storm.generated.StreamInfo
- equals(Object) - Method in class org.apache.storm.generated.SubmitOptions
- equals(Object) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- equals(Object) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- equals(Object) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- equals(Object) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- equals(Object) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- equals(Object) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- equals(Object) - Method in class org.apache.storm.generated.SupervisorAssignments
- equals(Object) - Method in class org.apache.storm.generated.SupervisorInfo
- equals(Object) - Method in class org.apache.storm.generated.SupervisorPageInfo
- equals(Object) - Method in class org.apache.storm.generated.SupervisorSummary
- equals(Object) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- equals(Object) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- equals(Object) - Method in class org.apache.storm.generated.ThriftSerializedObject
- equals(Object) - Method in class org.apache.storm.generated.TopologyActionOptions
- equals(Object) - Method in class org.apache.storm.generated.TopologyHistoryInfo
- equals(Object) - Method in class org.apache.storm.generated.TopologyInfo
- equals(Object) - Method in class org.apache.storm.generated.TopologyPageInfo
- equals(Object) - Method in class org.apache.storm.generated.TopologyStats
- equals(Object) - Method in class org.apache.storm.generated.TopologySummary
- equals(Object) - Method in class org.apache.storm.generated.WorkerMetricList
- equals(Object) - Method in class org.apache.storm.generated.WorkerMetricPoint
- equals(Object) - Method in class org.apache.storm.generated.WorkerMetrics
- equals(Object) - Method in class org.apache.storm.generated.WorkerResources
- equals(Object) - Method in class org.apache.storm.generated.WorkerSummary
- equals(Object) - Method in class org.apache.storm.generated.WorkerToken
- equals(Object) - Method in class org.apache.storm.generated.WorkerTokenInfo
- equals(Object) - Method in class org.apache.storm.hdfs.spout.TextFileReader
- equals(Object) - Method in class org.apache.storm.hdfs.spout.FileLock.LogEntry
- equals(Object) - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
- equals(Object) - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
- equals(Object) - Method in class org.apache.storm.jdbc.common.Column
- equals(Object) - Method in class org.apache.storm.jms.spout.JmsMessageID
- equals(Object) - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- equals(Object) - Method in class org.apache.storm.kafka.monitor.KafkaPartitionOffsetLag
- equals(Object) - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- equals(Object) - Method in class org.apache.storm.kafka.spout.KafkaSpoutMessageId
- equals(Object) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTopicPartition
- equals(Object) - Method in class org.apache.storm.localizer.LocalizedResource
- equals(Object) - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- equals(Object) - Method in class org.apache.storm.localizer.TimePortAndAssignment
-
All implementations of PortAndAssignment should implement the same equals() method.
- equals(Object) - Method in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
- equals(Object) - Method in class org.apache.storm.metrics2.TaskMetricDimensions
- equals(Object) - Method in class org.apache.storm.metricstore.Metric
-
Check if a Metric matches another object.
- equals(Object) - Method in class org.apache.storm.nimbus.NimbusInfo
- equals(Object) - Method in class org.apache.storm.scheduler.ExecutorDetails
- equals(Object) - Method in class org.apache.storm.scheduler.multitenant.Node
- equals(Object) - Method in class org.apache.storm.scheduler.resource.RasNode
- equals(Object) - Method in class org.apache.storm.scheduler.resource.User
- equals(Object) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- equals(Object) - Method in class org.apache.storm.scheduler.TopologyDetails
- equals(Object) - Method in class org.apache.storm.scheduler.WorkerSlot
- equals(Object) - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin.User
- equals(Object) - Method in class org.apache.storm.security.auth.SingleUserPrincipal
- equals(Object) - Method in class org.apache.storm.spout.CheckPointState
- equals(Object) - Method in class org.apache.storm.st.topology.window.data.TimeData
- equals(Object) - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
- equals(Object) - Method in class org.apache.storm.streams.Pair
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple10
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple3
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple4
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple5
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple6
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple7
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple8
- equals(Object) - Method in class org.apache.storm.streams.tuple.Tuple9
- equals(Object) - Method in class org.apache.storm.streams.windowing.BaseWindow
- equals(Object) - Method in class org.apache.storm.streams.windowing.SlidingWindows
- equals(Object) - Method in class org.apache.storm.streams.windowing.TumblingWindows
- equals(Object) - Method in class org.apache.storm.testing.TestSerObject
- equals(Object) - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Count
- equals(Object) - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
- equals(Object) - Method in class org.apache.storm.transactional.TransactionAttempt
-
Deprecated.
- equals(Object) - Method in class org.apache.storm.trident.graph.Group
- equals(Object) - Method in class org.apache.storm.trident.planner.Node
- equals(Object) - Method in class org.apache.storm.trident.spout.RichSpoutBatchId
- equals(Object) - Method in class org.apache.storm.trident.topology.TransactionAttempt
- equals(Object) - Method in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordType
- equals(Object) - Method in class org.apache.storm.trident.util.IndexedEdge
- equals(Object) - Method in class org.apache.storm.tuple.Fields
- equals(Object) - Method in class org.apache.storm.tuple.MessageId
- equals(Object) - Method in class org.apache.storm.tuple.TupleImpl
- equals(Object) - Method in class org.apache.storm.utils.SimpleVersion
- equals(Object) - Method in class org.apache.storm.windowing.TupleWindowImpl
- equals(AccessControl) - Method in class org.apache.storm.generated.AccessControl
- equals(AlreadyAliveException) - Method in exception org.apache.storm.generated.AlreadyAliveException
- equals(Assignment) - Method in class org.apache.storm.generated.Assignment
- equals(AuthorizationException) - Method in exception org.apache.storm.generated.AuthorizationException
- equals(BeginDownloadResult) - Method in class org.apache.storm.generated.BeginDownloadResult
- equals(Bolt) - Method in class org.apache.storm.generated.Bolt
- equals(BoltAggregateStats) - Method in class org.apache.storm.generated.BoltAggregateStats
- equals(BoltStats) - Method in class org.apache.storm.generated.BoltStats
- equals(ClusterSummary) - Method in class org.apache.storm.generated.ClusterSummary
- equals(ClusterWorkerHeartbeat) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- equals(CommonAggregateStats) - Method in class org.apache.storm.generated.CommonAggregateStats
- equals(ComponentAggregateStats) - Method in class org.apache.storm.generated.ComponentAggregateStats
- equals(ComponentCommon) - Method in class org.apache.storm.generated.ComponentCommon
- equals(ComponentObject) - Method in class org.apache.storm.generated.ComponentObject
- equals(ComponentPageInfo) - Method in class org.apache.storm.generated.ComponentPageInfo
- equals(Credentials) - Method in class org.apache.storm.generated.Credentials
- equals(DebugOptions) - Method in class org.apache.storm.generated.DebugOptions
- equals(DistributedRPC.execute_args) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- equals(DistributedRPC.execute_result) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- equals(DistributedRPCInvocations.failRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- equals(DistributedRPCInvocations.failRequest_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- equals(DistributedRPCInvocations.failRequestV2_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- equals(DistributedRPCInvocations.failRequestV2_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- equals(DistributedRPCInvocations.fetchRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- equals(DistributedRPCInvocations.fetchRequest_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- equals(DistributedRPCInvocations.result_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- equals(DistributedRPCInvocations.result_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- equals(DRPCExecutionException) - Method in exception org.apache.storm.generated.DRPCExecutionException
- equals(DRPCRequest) - Method in class org.apache.storm.generated.DRPCRequest
- equals(ErrorInfo) - Method in class org.apache.storm.generated.ErrorInfo
- equals(ExecutorAggregateStats) - Method in class org.apache.storm.generated.ExecutorAggregateStats
- equals(ExecutorInfo) - Method in class org.apache.storm.generated.ExecutorInfo
- equals(ExecutorSpecificStats) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- equals(ExecutorStats) - Method in class org.apache.storm.generated.ExecutorStats
- equals(ExecutorSummary) - Method in class org.apache.storm.generated.ExecutorSummary
- equals(GetInfoOptions) - Method in class org.apache.storm.generated.GetInfoOptions
- equals(GlobalStreamId) - Method in class org.apache.storm.generated.GlobalStreamId
- equals(Grouping) - Method in class org.apache.storm.generated.Grouping
- equals(HBAuthorizationException) - Method in exception org.apache.storm.generated.HBAuthorizationException
- equals(HBExecutionException) - Method in exception org.apache.storm.generated.HBExecutionException
- equals(HBMessage) - Method in class org.apache.storm.generated.HBMessage
- equals(HBMessageData) - Method in class org.apache.storm.generated.HBMessageData
- equals(HBNodes) - Method in class org.apache.storm.generated.HBNodes
- equals(HBPulse) - Method in class org.apache.storm.generated.HBPulse
- equals(HBRecords) - Method in class org.apache.storm.generated.HBRecords
- equals(IllegalStateException) - Method in exception org.apache.storm.generated.IllegalStateException
- equals(InvalidTopologyException) - Method in exception org.apache.storm.generated.InvalidTopologyException
- equals(JavaObject) - Method in class org.apache.storm.generated.JavaObject
- equals(JavaObjectArg) - Method in class org.apache.storm.generated.JavaObjectArg
- equals(KeyAlreadyExistsException) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- equals(KeyNotFoundException) - Method in exception org.apache.storm.generated.KeyNotFoundException
- equals(KillOptions) - Method in class org.apache.storm.generated.KillOptions
- equals(ListBlobsResult) - Method in class org.apache.storm.generated.ListBlobsResult
- equals(LocalAssignment) - Method in class org.apache.storm.generated.LocalAssignment
- equals(LocalStateData) - Method in class org.apache.storm.generated.LocalStateData
- equals(LogConfig) - Method in class org.apache.storm.generated.LogConfig
- equals(LogLevel) - Method in class org.apache.storm.generated.LogLevel
- equals(LSApprovedWorkers) - Method in class org.apache.storm.generated.LSApprovedWorkers
- equals(LSSupervisorAssignments) - Method in class org.apache.storm.generated.LSSupervisorAssignments
- equals(LSSupervisorId) - Method in class org.apache.storm.generated.LSSupervisorId
- equals(LSTopoHistory) - Method in class org.apache.storm.generated.LSTopoHistory
- equals(LSTopoHistoryList) - Method in class org.apache.storm.generated.LSTopoHistoryList
- equals(LSWorkerHeartbeat) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- equals(Nimbus.activate_args) - Method in class org.apache.storm.generated.Nimbus.activate_args
- equals(Nimbus.activate_result) - Method in class org.apache.storm.generated.Nimbus.activate_result
- equals(Nimbus.beginBlobDownload_args) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- equals(Nimbus.beginBlobDownload_result) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- equals(Nimbus.beginCreateBlob_args) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- equals(Nimbus.beginCreateBlob_result) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- equals(Nimbus.beginFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- equals(Nimbus.beginFileUpload_result) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- equals(Nimbus.beginUpdateBlob_args) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- equals(Nimbus.beginUpdateBlob_result) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- equals(Nimbus.cancelBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- equals(Nimbus.cancelBlobUpload_result) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- equals(Nimbus.createStateInZookeeper_args) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- equals(Nimbus.createStateInZookeeper_result) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- equals(Nimbus.deactivate_args) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- equals(Nimbus.deactivate_result) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- equals(Nimbus.debug_args) - Method in class org.apache.storm.generated.Nimbus.debug_args
- equals(Nimbus.debug_result) - Method in class org.apache.storm.generated.Nimbus.debug_result
- equals(Nimbus.deleteBlob_args) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- equals(Nimbus.deleteBlob_result) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- equals(Nimbus.downloadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- equals(Nimbus.downloadBlobChunk_result) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- equals(Nimbus.downloadChunk_args) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- equals(Nimbus.downloadChunk_result) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- equals(Nimbus.finishBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- equals(Nimbus.finishBlobUpload_result) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- equals(Nimbus.finishFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- equals(Nimbus.finishFileUpload_result) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- equals(Nimbus.getBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- equals(Nimbus.getBlobMeta_result) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- equals(Nimbus.getBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- equals(Nimbus.getBlobReplication_result) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- equals(Nimbus.getClusterInfo_args) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- equals(Nimbus.getClusterInfo_result) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- equals(Nimbus.getComponentPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- equals(Nimbus.getComponentPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- equals(Nimbus.getComponentPendingProfileActions_args) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- equals(Nimbus.getComponentPendingProfileActions_result) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- equals(Nimbus.getLeader_args) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- equals(Nimbus.getLeader_result) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- equals(Nimbus.getLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- equals(Nimbus.getLogConfig_result) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- equals(Nimbus.getNimbusConf_args) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- equals(Nimbus.getNimbusConf_result) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- equals(Nimbus.getOwnerResourceSummaries_args) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- equals(Nimbus.getOwnerResourceSummaries_result) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- equals(Nimbus.getSupervisorAssignments_args) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- equals(Nimbus.getSupervisorAssignments_result) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- equals(Nimbus.getSupervisorPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- equals(Nimbus.getSupervisorPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- equals(Nimbus.getTopology_args) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- equals(Nimbus.getTopology_result) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- equals(Nimbus.getTopologyConf_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- equals(Nimbus.getTopologyConf_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- equals(Nimbus.getTopologyHistory_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- equals(Nimbus.getTopologyHistory_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- equals(Nimbus.getTopologyInfo_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- equals(Nimbus.getTopologyInfo_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- equals(Nimbus.getTopologyInfoByName_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- equals(Nimbus.getTopologyInfoByName_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- equals(Nimbus.getTopologyInfoByNameWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- equals(Nimbus.getTopologyInfoByNameWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- equals(Nimbus.getTopologyInfoWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- equals(Nimbus.getTopologyInfoWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- equals(Nimbus.getTopologyPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- equals(Nimbus.getTopologyPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- equals(Nimbus.getTopologySummaries_args) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- equals(Nimbus.getTopologySummaries_result) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- equals(Nimbus.getTopologySummary_args) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- equals(Nimbus.getTopologySummary_result) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- equals(Nimbus.getTopologySummaryByName_args) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- equals(Nimbus.getTopologySummaryByName_result) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- equals(Nimbus.getUserTopology_args) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- equals(Nimbus.getUserTopology_result) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- equals(Nimbus.isRemoteBlobExists_args) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- equals(Nimbus.isRemoteBlobExists_result) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- equals(Nimbus.isTopologyNameAllowed_args) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- equals(Nimbus.isTopologyNameAllowed_result) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- equals(Nimbus.killTopology_args) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- equals(Nimbus.killTopology_result) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- equals(Nimbus.killTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- equals(Nimbus.killTopologyWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- equals(Nimbus.listBlobs_args) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- equals(Nimbus.listBlobs_result) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- equals(Nimbus.processWorkerMetrics_args) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- equals(Nimbus.processWorkerMetrics_result) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- equals(Nimbus.rebalance_args) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- equals(Nimbus.rebalance_result) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- equals(Nimbus.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- equals(Nimbus.sendSupervisorWorkerHeartbeat_result) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- equals(Nimbus.sendSupervisorWorkerHeartbeats_args) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- equals(Nimbus.sendSupervisorWorkerHeartbeats_result) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- equals(Nimbus.setBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- equals(Nimbus.setBlobMeta_result) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- equals(Nimbus.setLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- equals(Nimbus.setLogConfig_result) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- equals(Nimbus.setWorkerProfiler_args) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- equals(Nimbus.setWorkerProfiler_result) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- equals(Nimbus.submitTopology_args) - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- equals(Nimbus.submitTopology_result) - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- equals(Nimbus.submitTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- equals(Nimbus.submitTopologyWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- equals(Nimbus.updateBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- equals(Nimbus.updateBlobReplication_result) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- equals(Nimbus.uploadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- equals(Nimbus.uploadBlobChunk_result) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- equals(Nimbus.uploadChunk_args) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- equals(Nimbus.uploadChunk_result) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- equals(Nimbus.uploadNewCredentials_args) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- equals(Nimbus.uploadNewCredentials_result) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- equals(NimbusSummary) - Method in class org.apache.storm.generated.NimbusSummary
- equals(NodeInfo) - Method in class org.apache.storm.generated.NodeInfo
- equals(NotAliveException) - Method in exception org.apache.storm.generated.NotAliveException
- equals(NullStruct) - Method in class org.apache.storm.generated.NullStruct
- equals(OwnerResourceSummary) - Method in class org.apache.storm.generated.OwnerResourceSummary
- equals(PrivateWorkerKey) - Method in class org.apache.storm.generated.PrivateWorkerKey
- equals(ProfileRequest) - Method in class org.apache.storm.generated.ProfileRequest
- equals(ReadableBlobMeta) - Method in class org.apache.storm.generated.ReadableBlobMeta
- equals(RebalanceOptions) - Method in class org.apache.storm.generated.RebalanceOptions
- equals(SettableBlobMeta) - Method in class org.apache.storm.generated.SettableBlobMeta
- equals(SharedMemory) - Method in class org.apache.storm.generated.SharedMemory
- equals(ShellComponent) - Method in class org.apache.storm.generated.ShellComponent
- equals(SpecificAggregateStats) - Method in class org.apache.storm.generated.SpecificAggregateStats
- equals(SpoutAggregateStats) - Method in class org.apache.storm.generated.SpoutAggregateStats
- equals(SpoutSpec) - Method in class org.apache.storm.generated.SpoutSpec
- equals(SpoutStats) - Method in class org.apache.storm.generated.SpoutStats
- equals(StateSpoutSpec) - Method in class org.apache.storm.generated.StateSpoutSpec
- equals(StormBase) - Method in class org.apache.storm.generated.StormBase
- equals(StormTopology) - Method in class org.apache.storm.generated.StormTopology
- equals(StreamInfo) - Method in class org.apache.storm.generated.StreamInfo
- equals(SubmitOptions) - Method in class org.apache.storm.generated.SubmitOptions
- equals(Supervisor.getLocalAssignmentForStorm_args) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- equals(Supervisor.getLocalAssignmentForStorm_result) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- equals(Supervisor.sendSupervisorAssignments_args) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- equals(Supervisor.sendSupervisorAssignments_result) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- equals(Supervisor.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- equals(Supervisor.sendSupervisorWorkerHeartbeat_result) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- equals(SupervisorAssignments) - Method in class org.apache.storm.generated.SupervisorAssignments
- equals(SupervisorInfo) - Method in class org.apache.storm.generated.SupervisorInfo
- equals(SupervisorPageInfo) - Method in class org.apache.storm.generated.SupervisorPageInfo
- equals(SupervisorSummary) - Method in class org.apache.storm.generated.SupervisorSummary
- equals(SupervisorWorkerHeartbeat) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- equals(SupervisorWorkerHeartbeats) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- equals(ThriftSerializedObject) - Method in class org.apache.storm.generated.ThriftSerializedObject
- equals(TopologyActionOptions) - Method in class org.apache.storm.generated.TopologyActionOptions
- equals(TopologyHistoryInfo) - Method in class org.apache.storm.generated.TopologyHistoryInfo
- equals(TopologyInfo) - Method in class org.apache.storm.generated.TopologyInfo
- equals(TopologyPageInfo) - Method in class org.apache.storm.generated.TopologyPageInfo
- equals(TopologyStats) - Method in class org.apache.storm.generated.TopologyStats
- equals(TopologySummary) - Method in class org.apache.storm.generated.TopologySummary
- equals(WorkerMetricList) - Method in class org.apache.storm.generated.WorkerMetricList
- equals(WorkerMetricPoint) - Method in class org.apache.storm.generated.WorkerMetricPoint
- equals(WorkerMetrics) - Method in class org.apache.storm.generated.WorkerMetrics
- equals(WorkerResources) - Method in class org.apache.storm.generated.WorkerResources
- equals(WorkerSummary) - Method in class org.apache.storm.generated.WorkerSummary
- equals(WorkerToken) - Method in class org.apache.storm.generated.WorkerToken
- equals(WorkerTokenInfo) - Method in class org.apache.storm.generated.WorkerTokenInfo
- Equals - Class in org.apache.storm.trident.operation.builtin
- Equals() - Constructor for class org.apache.storm.trident.operation.builtin.Equals
- EQUALS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- equalsIgnoreResources(Object) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
-
Like the equals command, but ignores the resources.
- equiv(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- equiv(Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- EquivalenceUtils - Class in org.apache.storm.utils
- EquivalenceUtils() - Constructor for class org.apache.storm.utils.EquivalenceUtils
- ERROR - Enum constant in enum class org.apache.storm.generated.ErrorInfo._Fields
- ERROR - Enum constant in enum class org.apache.storm.multilang.ShellMsg.ShellLogLevel
- ERROR_TIME_SECS - Enum constant in enum class org.apache.storm.generated.ErrorInfo._Fields
- ErrorEdgeFactory - Class in org.apache.storm.trident.util
- ErrorEdgeFactory() - Constructor for class org.apache.storm.trident.util.ErrorEdgeFactory
- ErrorInfo - Class in org.apache.storm.generated
- ErrorInfo() - Constructor for class org.apache.storm.generated.ErrorInfo
- ErrorInfo(String, int) - Constructor for class org.apache.storm.generated.ErrorInfo
- ErrorInfo(ErrorInfo) - Constructor for class org.apache.storm.generated.ErrorInfo
-
Performs a deep copy on other.
- ErrorInfo._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- errorPath(String, String) - Static method in class org.apache.storm.cluster.ClusterUtils
- errors(String, String) - Method in interface org.apache.storm.cluster.IStormClusterState
- errors(String, String) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- ERRORS - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- ERRORS - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- ERRORS_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
- ERRORS_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
- errorStormRoot(String) - Static method in class org.apache.storm.cluster.ClusterUtils
- errorSubset(String) - Static method in class org.apache.storm.stats.StatsUtil
- errorTopologies() - Method in interface org.apache.storm.cluster.IStormClusterState
- errorTopologies() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- ESCAPE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- establishConnections(List<DRPCSpout.DRPCClientBuilder>) - Method in class org.apache.storm.drpc.DRPCSpout
- establishLogSettingCallback() - Method in class org.apache.storm.daemon.worker.Worker
- EstimateThroughput - Class in org.apache.storm.loadgen
-
Estimate the throughput of all topologies.
- EstimateThroughput() - Constructor for class org.apache.storm.loadgen.EstimateThroughput
- evaluateResponse(byte[]) - Method in class org.apache.storm.security.auth.plain.SaslPlainServer
-
Deprecated.
- EvaluationCalc - Class in org.apache.storm.sql.runtime.streams.functions
- EvaluationCalc(ExecutableExpression, ExecutableExpression, int, DataContext) - Constructor for class org.apache.storm.sql.runtime.streams.functions.EvaluationCalc
-
EvaluationCalc Constructor.
- EvaluationFilter - Class in org.apache.storm.sql.runtime.streams.functions
- EvaluationFilter(ExecutableExpression, DataContext) - Constructor for class org.apache.storm.sql.runtime.streams.functions.EvaluationFilter
-
EvaluationFilter Constructor.
- EvaluationFunction - Class in org.apache.storm.sql.runtime.streams.functions
- EvaluationFunction(ExecutableExpression, int, DataContext) - Constructor for class org.apache.storm.sql.runtime.streams.functions.EvaluationFunction
-
EvaluationFunction Constructor.
- evenSampler(int) - Static method in class org.apache.storm.utils.ConfigUtils
- EvenScheduler - Class in org.apache.storm.scheduler
- EvenScheduler() - Constructor for class org.apache.storm.scheduler.EvenScheduler
- Event<T> - Interface in org.apache.storm.windowing
-
An event is a wrapper object that gets stored in the window.
- EventImpl<T> - Class in org.apache.storm.windowing
- EventInfo(long, String, int, Object, List<Object>) - Constructor for class org.apache.storm.metric.IEventLogger.EventInfo
- EVENTLOG_HOST - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- EVENTLOG_PORT - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- EVENTLOGGER_COMPONENT_ID - Static variable in class org.apache.storm.daemon.StormCommon
- EVENTLOGGER_STREAM_ID - Static variable in class org.apache.storm.daemon.StormCommon
- EventLoggerBolt - Class in org.apache.storm.metric
- EventLoggerBolt() - Constructor for class org.apache.storm.metric.EventLoggerBolt
- eventLoggerBoltFields() - Static method in class org.apache.storm.daemon.StormCommon
- eventLoggerInputs(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
- EventLoggerRegistryValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.EventLoggerRegistryValidator
- eventLogsFilename(String, String) - Static method in class org.apache.storm.utils.WebAppUtils
- EventManager - Interface in org.apache.storm.event
- EventManagerImp - Class in org.apache.storm.event
- EventManagerImp(boolean) - Constructor for class org.apache.storm.event.EventManagerImp
- EventManagerPushCallback - Class in org.apache.storm.daemon.supervisor
- EventManagerPushCallback(Runnable, EventManager) - Constructor for class org.apache.storm.daemon.supervisor.EventManagerPushCallback
- eventTime - Variable in class org.apache.storm.hdfs.spout.FileLock.LogEntry
- EVERY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- evict(Event<T>) - Method in class org.apache.storm.windowing.CountEvictionPolicy
- evict(Event<T>) - Method in interface org.apache.storm.windowing.EvictionPolicy
-
Decides if an event should be expired from the window, processed in the current window or kept for later processing.
- evict(Event<T>) - Method in class org.apache.storm.windowing.TimeEvictionPolicy
-
Decides if an event should be expired from the window, processed in the current window or kept for later processing.
- evict(Event<T>) - Method in class org.apache.storm.windowing.WatermarkCountEvictionPolicy
- evict(Event<T>) - Method in class org.apache.storm.windowing.WatermarkTimeEvictionPolicy
-
Decides if an event should be expired from the window, processed in the current window or kept for later processing.
- evictionCallback(String, StringMetadata) - Method in class org.apache.storm.metricstore.rocksdb.StringMetadataCache
-
Callback when data is about to be removed from the cache.
- evictionCallback(K, V) - Method in interface org.apache.storm.utils.LruMap.CacheEvictionCallback
- evictionContext - Variable in class org.apache.storm.windowing.TimeEvictionPolicy
- EvictionContext - Interface in org.apache.storm.windowing
-
Context information that can be used by the eviction policy.
- evictionPolicy - Variable in class org.apache.storm.windowing.WindowManager
- EvictionPolicy<T,
S> - Interface in org.apache.storm.windowing -
Eviction policy tracks events and decides whether an event should be evicted from the window or not.
- EvictionPolicy.Action - Enum Class in org.apache.storm.windowing
-
The action to be taken when
EvictionPolicy.evict(Event)
is invoked. - ExampleJmsTopology - Class in org.apache.storm.jms.example
-
An example JMS topology.
- ExampleJmsTopology() - Constructor for class org.apache.storm.jms.example.ExampleJmsTopology
- EXCEPT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EXCEPTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.messaging.netty.KerberosSaslServerHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.messaging.netty.MessageDecoder
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.messaging.netty.SaslStormServerHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.messaging.netty.StormClientHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.messaging.netty.StormServerHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.storm.pacemaker.PacemakerClientHandler
- exceptionCauseIsInstanceOf(Class, Throwable) - Static method in class org.apache.storm.utils.Utils
-
Checks if a throwable is an instance of a particular class.
- ExceptionMapperUtils - Class in org.apache.storm.daemon.ui.exceptionmappers
- ExceptionMapperUtils() - Constructor for class org.apache.storm.daemon.ui.exceptionmappers.ExceptionMapperUtils
- ExceptionMeterNames - Class in org.apache.storm.daemon.logviewer.utils
- ExceptionMeterNames() - Constructor for class org.apache.storm.daemon.logviewer.utils.ExceptionMeterNames
- exceptionToJson(Exception, int) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Converts exception into json map.
- EXCLAIM_1 - Static variable in class org.apache.storm.ExclamationTopology
- EXCLAIM_2 - Static variable in class org.apache.storm.ExclamationTopology
- EXCLAIM_2_EXECUTORS - Static variable in class org.apache.storm.ExclamationTopology
- ExclaimBolt() - Constructor for class org.apache.storm.starter.BasicDRPCTopology.ExclaimBolt
- ExclamationBolt() - Constructor for class org.apache.storm.ExclamationTopology.ExclamationBolt
- ExclamationBolt() - Constructor for class org.apache.storm.starter.ExclamationTopology.ExclamationBolt
- ExclamationBolt() - Constructor for class org.apache.storm.starter.ManualDRPC.ExclamationBolt
- ExclamationBolt() - Constructor for class org.apache.storm.starter.ResourceAwareExampleTopology.ExclamationBolt
- ExclamationLoggingBolt() - Constructor for class org.apache.storm.starter.MultipleLoggerTopology.ExclamationLoggingBolt
- ExclamationTopology - Class in org.apache.storm
-
This is a basic example of a Storm topology.
- ExclamationTopology - Class in org.apache.storm.starter
-
This is a basic example of a Storm topology.
- ExclamationTopology() - Constructor for class org.apache.storm.ExclamationTopology
- ExclamationTopology() - Constructor for class org.apache.storm.starter.ExclamationTopology
- ExclamationTopology.ExclamationBolt - Class in org.apache.storm
- ExclamationTopology.ExclamationBolt - Class in org.apache.storm.starter
- ExclamationTopology.FixedOrderWordSpout - Class in org.apache.storm
- EXCLUDE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EXCLUDING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- exec() - Method in interface org.apache.storm.Testing.Condition
- exec(String) - Static method in class org.apache.storm.container.cgroup.SystemOperation
- EXEC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EXEC_ID_STRING - Enum constant in enum class org.apache.storm.metricstore.rocksdb.KeyType
- EXEC_STATS - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- EXEC_SUMMARY - Enum constant in enum class org.apache.storm.generated.ExecutorAggregateStats._Fields
- ExecAndProcessLatencyEngine - Class in org.apache.storm.loadgen
-
A more accurate sleep implementation.
- ExecAndProcessLatencyEngine() - Constructor for class org.apache.storm.loadgen.ExecAndProcessLatencyEngine
- ExecAndProcessLatencyEngine(SlowExecutorPattern) - Constructor for class org.apache.storm.loadgen.ExecAndProcessLatencyEngine
- execCommand(String...) - Static method in class org.apache.storm.utils.ServerUtils
- execCommand(String...) - Method in interface org.apache.storm.utils.ShellCommandRunner
-
Method to execute a shell command.
- execCommand(String...) - Method in class org.apache.storm.utils.ShellCommandRunnerImpl
- execCommand(Map<String, String>, String...) - Method in interface org.apache.storm.utils.ShellCommandRunner
-
Method to execute a shell command.
- execCommand(Map<String, String>, String...) - Method in class org.apache.storm.utils.ShellCommandRunnerImpl
- execCommand(Map<String, String>, String[], long) - Method in interface org.apache.storm.utils.ShellCommandRunner
-
Method to execute a shell command.
- execCommand(Map<String, String>, String[], long) - Method in class org.apache.storm.utils.ShellCommandRunnerImpl
- execSorter - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- ExecSorterByConnectionCount - Class in org.apache.storm.scheduler.resource.strategies.scheduling.sorter
- ExecSorterByConnectionCount(TopologyDetails) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.ExecSorterByConnectionCount
- ExecSorterByConstraintSeverity - Class in org.apache.storm.scheduler.resource.strategies.scheduling.sorter
- ExecSorterByConstraintSeverity(Cluster, TopologyDetails) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.ExecSorterByConstraintSeverity
- ExecSorterByProximity - Class in org.apache.storm.scheduler.resource.strategies.scheduling.sorter
- ExecSorterByProximity(TopologyDetails) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.ExecSorterByProximity
- execTime - Variable in class org.apache.storm.loadgen.InputStream
- execToComp - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- ExecutableExpression - Interface in org.apache.storm.sql.runtime.calcite
-
Compiled executable expression.
- execute() - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncProcessor.execute
- execute() - Constructor for class org.apache.storm.generated.DistributedRPC.Processor.execute
- execute() - Method in class org.apache.storm.executor.Executor
-
separated from mkExecutor in order to replace executor transfer in executor data for testing.
- execute() - Method in class org.apache.storm.maven.plugin.versioninfo.VersionInfoMojo
- execute() - Method in class org.apache.storm.utils.ShellUtils.ShellCommandExecutor
-
Execute the shell command.
- execute(A) - Method in class org.apache.storm.streams.processors.MergeAggregateProcessor
- execute(String[]) - Method in class org.apache.storm.jdbc.topology.AbstractUserTopology
-
A main method template to extend.
- execute(String, String) - Method in class org.apache.storm.daemon.drpc.DRPCThrift
- execute(String, String) - Method in class org.apache.storm.generated.DistributedRPC.Client
- execute(String, String) - Method in interface org.apache.storm.generated.DistributedRPC.Iface
- execute(String, String) - Method in class org.apache.storm.LocalDRPC
- execute(String, String) - Method in class org.apache.storm.utils.DRPCClient
- execute(String, String, RequestFactory<T>) - Method in class org.apache.storm.daemon.drpc.DRPC
- execute(String, String, AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.DistributedRPC.AsyncClient
- execute(String, String, AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.DistributedRPC.AsyncIface
- execute(List<TridentTuple>) - Method in class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
- execute(List<TridentTuple>) - Method in class org.apache.storm.hdfs.trident.HdfsState.SequenceFileOptions
- execute(Map<TridentTuple, Object>, int, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedMultiReducerExecutor
- execute(K) - Method in class org.apache.storm.streams.processors.StateQueryProcessor
- execute(K, Runnable) - Method in class org.apache.storm.daemon.supervisor.OnlyLatestExecutor
-
Run something in the future, but replace it with the latest if it is taking too long.
- execute(Context) - Method in class org.apache.storm.sql.runtime.calcite.DebuggableExecutableExpression
- execute(Context) - Method in interface org.apache.storm.sql.runtime.calcite.ExecutableExpression
- execute(Context, Object[]) - Method in class org.apache.storm.sql.runtime.calcite.DebuggableExecutableExpression
- execute(Context, Object[]) - Method in interface org.apache.storm.sql.runtime.calcite.ExecutableExpression
- execute(FileSystem, Path) - Method in class org.apache.storm.hdfs.common.rotation.MoveFileAction
- execute(FileSystem, Path) - Method in interface org.apache.storm.hdfs.common.rotation.RotationAction
- execute(Watcher.Event.KeeperState, Watcher.Event.EventType, String) - Method in class org.apache.storm.callback.DefaultWatcherCallBack
- execute(Watcher.Event.KeeperState, Watcher.Event.EventType, String) - Method in interface org.apache.storm.callback.WatcherCallBack
- execute(Pair<K, ?>, String) - Method in class org.apache.storm.streams.processors.CoGroupByKeyProcessor
- execute(Pair<K, ?>, String) - Method in class org.apache.storm.streams.processors.JoinProcessor
- execute(Pair<K, A>) - Method in class org.apache.storm.streams.processors.MergeAggregateByKeyProcessor
- execute(Pair<K, V>) - Method in class org.apache.storm.streams.processors.AggregateByKeyProcessor
- execute(Pair<K, V>) - Method in class org.apache.storm.streams.processors.FlatMapValuesProcessor
- execute(Pair<K, V>) - Method in class org.apache.storm.streams.processors.MapValuesProcessor
- execute(Pair<K, V>) - Method in class org.apache.storm.streams.processors.ReduceByKeyProcessor
- execute(Pair<K, V>) - Method in class org.apache.storm.streams.processors.UpdateStateByKeyProcessor
- execute(ReturnResultsReducer.ReturnResultsState, int, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.drpc.ReturnResultsReducer
- execute(JoinState, int, TridentTuple, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.JoinerMultiReducer
- execute(JoinState, int, TridentTuple, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.PreservingFieldsOrderJoinerMultiReducer
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.BridgeReceiver
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.AggregateProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.EachProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.MapProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.MultiReducerProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.PartitionPersistProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.ProjectedProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.planner.processor.StateQueryProcessor
- execute(ProcessorContext, String, TridentTuple) - Method in interface org.apache.storm.trident.planner.TupleReceiver
- execute(ProcessorContext, String, TridentTuple) - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- execute(BatchInfo, Tuple) - Method in class org.apache.storm.trident.planner.SubtopologyBolt
- execute(BatchInfo, Tuple) - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
- execute(BatchInfo, Tuple) - Method in interface org.apache.storm.trident.topology.ITridentBatchBolt
- execute(TridentTuple) - Method in interface org.apache.storm.trident.operation.FlatMapFunction
-
Invoked by the framework for each trident tuple in a stream.
- execute(TridentTuple) - Method in interface org.apache.storm.trident.operation.MapFunction
-
Invoked by the framework for each trident tuple in a stream.
- execute(TridentTuple, Object, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.MapGet
- execute(TridentTuple, Object, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.SnapshotGet
- execute(TridentTuple, Iterator<List<Object>>, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.TupleCollectionGet
- execute(TridentTuple, List<Values>, TridentCollector) - Method in class org.apache.storm.jdbc.trident.state.JdbcQuery
- execute(TridentTuple, List<Values>, TridentCollector) - Method in class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.redis.trident.PrintFunction
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.starter.trident.TridentReach.ExpandList
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.starter.trident.TridentWordCount.Split
- execute(TridentTuple, TridentCollector) - Method in interface org.apache.storm.trident.operation.Function
-
Performs the function logic on an individual tuple and emits 0 or more tuples.
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorInitImpl
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ConsumerExecutor
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.FilterExecutor
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.FlatMapFunctionExecutor
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.MapFunctionExecutor
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.testing.Split
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.testing.StringLength
- execute(TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.testing.TuplifyArgs
- execute(TridentTuple, T, TridentCollector) - Method in interface org.apache.storm.trident.state.QueryFunction
- execute(Tuple) - Method in class org.apache.storm.clojure.ClojureBolt
- execute(Tuple) - Method in class org.apache.storm.coordination.BatchBoltExecutor
- execute(Tuple) - Method in class org.apache.storm.coordination.CoordinatedBolt
- execute(Tuple) - Method in interface org.apache.storm.coordination.IBatchBolt
- execute(Tuple) - Method in class org.apache.storm.daemon.Acker
- execute(Tuple) - Method in class org.apache.storm.drpc.JoinResult
- execute(Tuple) - Method in class org.apache.storm.drpc.KeyedFairBolt
- execute(Tuple) - Method in class org.apache.storm.drpc.ReturnResults
- execute(Tuple) - Method in class org.apache.storm.ExclamationTopology.ExclamationBolt
- execute(Tuple) - Method in class org.apache.storm.flux.examples.StatefulWordCounter
- execute(Tuple) - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- execute(Tuple) - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.MyBolt
- execute(Tuple) - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.MyBolt
- execute(Tuple) - Method in class org.apache.storm.hdfs.spout.HdfsSpoutTopology.ConstBolt
- execute(Tuple) - Method in class org.apache.storm.jms.example.GenericBolt
- execute(Tuple) - Method in class org.apache.storm.kafka.spout.KafkaSpoutTestBolt
- execute(Tuple) - Method in class org.apache.storm.loadgen.LoadBolt
- execute(Tuple) - Method in class org.apache.storm.metric.EventLoggerBolt
- execute(Tuple) - Method in class org.apache.storm.metric.MetricsConsumerBolt
- execute(Tuple) - Method in class org.apache.storm.metric.SystemBolt
- execute(Tuple) - Method in class org.apache.storm.perf.bolt.DevNullBolt
- execute(Tuple) - Method in class org.apache.storm.perf.bolt.IdBolt
- execute(Tuple) - Method in class org.apache.storm.perf.utils.IdentityBolt
- execute(Tuple) - Method in class org.apache.storm.redis.topology.LookupWordCount.PrintWordTotalCountBolt
- execute(Tuple) - Method in class org.apache.storm.redis.topology.WhitelistWordCount.PrintWordTotalCountBolt
- execute(Tuple) - Method in class org.apache.storm.sql.runtime.datasource.socket.bolt.SocketBolt
- execute(Tuple) - Method in class org.apache.storm.starter.bolt.RollingCountAggBolt
- execute(Tuple) - Method in class org.apache.storm.starter.bolt.RollingCountBolt
- execute(Tuple) - Method in class org.apache.storm.starter.bolt.SingleJoinBolt
- execute(Tuple) - Method in class org.apache.storm.starter.ExclamationTopology.ExclamationBolt
- execute(Tuple) - Method in class org.apache.storm.starter.MultipleLoggerTopology.ExclamationLoggingBolt
- execute(Tuple) - Method in class org.apache.storm.starter.MultiThreadWordCountTopology.MultiThreadedSplitSentence
- execute(Tuple) - Method in class org.apache.storm.starter.ReachTopology.CountAggregator
- execute(Tuple) - Method in class org.apache.storm.starter.ReachTopology.PartialUniquer
- execute(Tuple) - Method in class org.apache.storm.starter.ResourceAwareExampleTopology.ExclamationBolt
- execute(Tuple) - Method in interface org.apache.storm.task.IBolt
-
Process a single tuple of input.
- execute(Tuple) - Method in class org.apache.storm.task.ShellBolt
- execute(Tuple) - Method in class org.apache.storm.testing.NonRichBoltTracker
- execute(Tuple) - Method in class org.apache.storm.testing.TestAggregatesCounter
- execute(Tuple) - Method in class org.apache.storm.testing.TestEventOrderCheckBolt
- execute(Tuple) - Method in class org.apache.storm.testing.TestGlobalCount
- execute(Tuple) - Method in class org.apache.storm.testing.TestPlannerBolt
- execute(Tuple) - Method in class org.apache.storm.testing.TupleCaptureBolt
- execute(Tuple) - Method in class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
-
Process a single tuple of input.
- execute(Tuple) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor
- execute(Tuple) - Method in class org.apache.storm.topology.BasicBoltExecutor
- execute(Tuple) - Method in interface org.apache.storm.topology.IStatefulBolt
-
Analogue to bolt function.
- execute(Tuple) - Method in class org.apache.storm.topology.PersistentWindowedBoltExecutor
- execute(Tuple) - Method in class org.apache.storm.topology.StatefulWindowedBoltExecutor
- execute(Tuple) - Method in class org.apache.storm.topology.WindowedBoltExecutor
- execute(Tuple) - Method in class org.apache.storm.trident.topology.TridentBoltExecutor
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.drpc.PrepareRequest
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.flux.examples.TestPrintBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.flux.examples.WordCounter
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.flux.wrappers.bolts.LogInfoBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.lambda.LambdaBiConsumerBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.lambda.LambdaConsumerBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.loadgen.ThroughputVsLatency.SplitSentence
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.loadgen.ThroughputVsLatency.WordCount
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.perf.bolt.CountBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.perf.bolt.SplitSentenceBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.redis.topology.WordCounter
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.AnchoredWordCount.SplitSentence
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.AnchoredWordCount.WordCount
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.BasicDRPCTopology.ExclaimBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.FilterWords
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.bolt.AbstractRankerBolt
-
This method functions as a template method (design pattern).
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.bolt.PrinterBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.bolt.WordCountBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.FastWordCountTopology.SplitSentence
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.FastWordCountTopology.WordCount
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.InOrderDeliveryTest.Check
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.ManualDRPC.ExclamationBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.ReachTopology.GetFollowers
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.ReachTopology.GetTweeters
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.StatefulTopology.PrinterBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.starter.WordCountTopologyNode.WordCount
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.testing.IdentityBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.testing.PrepareBatchBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.testing.TestConfBolt
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.testing.TestWordCounter
- execute(Tuple, BasicOutputCollector) - Method in interface org.apache.storm.topology.IBasicBolt
-
Process the input tuple and optionally emit new tuples based on the input tuple.
- execute(Tuple, BasicOutputCollector) - Method in class org.apache.storm.trident.spout.TridentSpoutCoordinator
- execute(TupleWindow) - Method in class org.apache.storm.bolt.JoinBolt
- execute(TupleWindow) - Method in class org.apache.storm.flux.examples.TestWindowBolt
- execute(TupleWindow) - Method in class org.apache.storm.st.topology.window.TimeDataVerificationBolt
- execute(TupleWindow) - Method in class org.apache.storm.st.topology.window.VerificationBolt
- execute(TupleWindow) - Method in class org.apache.storm.starter.bolt.SlidingWindowSumBolt
- execute(TupleWindow) - Method in interface org.apache.storm.topology.IWindowedBolt
-
Process the tuple window and optionally emit new tuples based on the tuples in the input window.
- execute(Server) - Method in interface org.apache.storm.daemon.ui.IConfigurator
- execute(T) - Method in class org.apache.storm.streams.processors.AggregateProcessor
- execute(Pair<K, ?>) - Method in class org.apache.storm.streams.processors.JoinProcessor
-
Execute some operation on the input value.
- execute(T) - Method in class org.apache.storm.streams.processors.BranchProcessor
- execute(T) - Method in class org.apache.storm.streams.processors.FilterProcessor
- execute(T) - Method in class org.apache.storm.streams.processors.FlatMapProcessor
- execute(T) - Method in class org.apache.storm.streams.processors.ForEachProcessor
- execute(T) - Method in class org.apache.storm.streams.processors.MapProcessor
- execute(T) - Method in class org.apache.storm.streams.processors.PeekProcessor
- execute(T) - Method in class org.apache.storm.streams.processors.ReduceProcessor
- execute(T, int, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.IdentityMultiReducer
- execute(T, int, TridentTuple, TridentCollector) - Method in interface org.apache.storm.trident.operation.MultiReducer
- execute(T, int, TridentTuple, TridentTuple, TridentCollector) - Method in interface org.apache.storm.trident.operation.GroupedMultiReducer
- execute(Pair<K, V>, String) - Method in class org.apache.storm.streams.processors.MapValuesProcessor
-
Executes some operations on the input and possibly emits some results.
- execute(T, String) - Method in interface org.apache.storm.streams.processors.Processor
-
Executes some operations on the input and possibly emits some results.
- EXECUTE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- execute_args() - Constructor for class org.apache.storm.generated.DistributedRPC.execute_args
- execute_args(String, String) - Constructor for class org.apache.storm.generated.DistributedRPC.execute_args
- execute_args(DistributedRPC.execute_args) - Constructor for class org.apache.storm.generated.DistributedRPC.execute_args
-
Performs a deep copy on other.
- execute_call(String, String, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncClient.execute_call
- EXECUTE_LATENCY_MS - Enum constant in enum class org.apache.storm.generated.BoltAggregateStats._Fields
- EXECUTE_MS_AVG - Enum constant in enum class org.apache.storm.generated.BoltStats._Fields
- execute_result() - Constructor for class org.apache.storm.generated.DistributedRPC.execute_result
- execute_result(String, DRPCExecutionException, AuthorizationException) - Constructor for class org.apache.storm.generated.DistributedRPC.execute_result
- execute_result(DistributedRPC.execute_result) - Constructor for class org.apache.storm.generated.DistributedRPC.execute_result
-
Performs a deep copy on other.
- executeBlocking(String, String) - Method in class org.apache.storm.daemon.drpc.DRPC
- EXECUTED - Enum constant in enum class org.apache.storm.generated.BoltAggregateStats._Fields
- EXECUTED - Enum constant in enum class org.apache.storm.generated.BoltStats._Fields
- executeInsertQuery(String, List<List<Column>>) - Method in class org.apache.storm.jdbc.common.JdbcClient
- executeLatencyMs - Variable in class org.apache.storm.hooks.info.BoltExecuteInfo
- executeSql(String) - Method in class org.apache.storm.jdbc.common.JdbcClient
- executingTaskId - Variable in class org.apache.storm.hooks.info.BoltExecuteInfo
- EXECUTION_COMMAND - Enum constant in enum class org.apache.storm.generated.ShellComponent._Fields
- ExecutionContext - Class in org.apache.storm.flux.model
-
Container for all the objects required to instantiate a topology.
- ExecutionContext(TopologyDef, Config) - Constructor for class org.apache.storm.flux.model.ExecutionContext
- Executor - Class in org.apache.storm.executor
- Executor(WorkerState, List<Long>, Map<String, String>, String) - Constructor for class org.apache.storm.executor.Executor
- EXECUTOR_ID - Enum constant in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
- EXECUTOR_INFO - Enum constant in enum class org.apache.storm.generated.ExecutorSummary._Fields
- EXECUTOR_METRICS_FREQUENCY_SECS - Static variable in class org.apache.storm.Config
-
How often executor metrics should report to master, used for RPC heartbeat mode.
- EXECUTOR_NODE_PORT - Enum constant in enum class org.apache.storm.generated.Assignment._Fields
- EXECUTOR_RECEIVE_QUEUE_MAP - Static variable in class org.apache.storm.Constants
- EXECUTOR_START_TIME_SECS - Enum constant in enum class org.apache.storm.generated.Assignment._Fields
- EXECUTOR_STATS - Enum constant in enum class org.apache.storm.generated.ClusterWorkerHeartbeat._Fields
- ExecutorAggregateStats - Class in org.apache.storm.generated
- ExecutorAggregateStats() - Constructor for class org.apache.storm.generated.ExecutorAggregateStats
- ExecutorAggregateStats(ExecutorAggregateStats) - Constructor for class org.apache.storm.generated.ExecutorAggregateStats
-
Performs a deep copy on other.
- ExecutorAggregateStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ExecutorBeat - Class in org.apache.storm.cluster
- ExecutorBeat(int, int, ExecutorStats) - Constructor for class org.apache.storm.cluster.ExecutorBeat
- executorBeats(String, Map<List<Long>, NodeInfo>) - Method in interface org.apache.storm.cluster.IStormClusterState
- executorBeats(String, Map<List<Long>, NodeInfo>) - Method in class org.apache.storm.cluster.StormClusterStateImpl
-
need to take executor->node+port in explicitly so that we don't run into a situation where a long dead worker with a skewed clock overrides all the timestamps.
- ExecutorDetails - Class in org.apache.storm.scheduler
- ExecutorDetails(int, int) - Constructor for class org.apache.storm.scheduler.ExecutorDetails
- executorId - Variable in class org.apache.storm.executor.Executor
- executorIdToTasks(List<Long>) - Static method in class org.apache.storm.daemon.StormCommon
- ExecutorInfo - Class in org.apache.storm.generated
- ExecutorInfo() - Constructor for class org.apache.storm.generated.ExecutorInfo
- ExecutorInfo(int, int) - Constructor for class org.apache.storm.generated.ExecutorInfo
- ExecutorInfo(ExecutorInfo) - Constructor for class org.apache.storm.generated.ExecutorInfo
-
Performs a deep copy on other.
- ExecutorInfo._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- EXECUTORS - Enum constant in enum class org.apache.storm.generated.LocalAssignment._Fields
- EXECUTORS - Enum constant in enum class org.apache.storm.generated.LSWorkerHeartbeat._Fields
- EXECUTORS - Enum constant in enum class org.apache.storm.generated.SupervisorWorkerHeartbeat._Fields
- EXECUTORS - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- EXECUTORS - Static variable in class org.apache.storm.perf.utils.BasicMetricsCollector
- ExecutorShutdown - Class in org.apache.storm.executor
- ExecutorShutdown(Executor, List<Utils.SmartThread>, ArrayList<Task>, JCQueue) - Constructor for class org.apache.storm.executor.ExecutorShutdown
- ExecutorSpecificStats - Class in org.apache.storm.generated
- ExecutorSpecificStats() - Constructor for class org.apache.storm.generated.ExecutorSpecificStats
- ExecutorSpecificStats(ExecutorSpecificStats) - Constructor for class org.apache.storm.generated.ExecutorSpecificStats
- ExecutorSpecificStats(ExecutorSpecificStats._Fields, Object) - Constructor for class org.apache.storm.generated.ExecutorSpecificStats
- ExecutorSpecificStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ExecutorStats - Class in org.apache.storm.generated
- ExecutorStats() - Constructor for class org.apache.storm.generated.ExecutorStats
- ExecutorStats(Map<String, Map<String, Long>>, Map<String, Map<String, Long>>, ExecutorSpecificStats, double) - Constructor for class org.apache.storm.generated.ExecutorStats
- ExecutorStats(ExecutorStats) - Constructor for class org.apache.storm.generated.ExecutorStats
-
Performs a deep copy on other.
- ExecutorStats._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ExecutorSummary - Class in org.apache.storm.generated
- ExecutorSummary() - Constructor for class org.apache.storm.generated.ExecutorSummary
- ExecutorSummary(ExecutorInfo, String, String, int, int) - Constructor for class org.apache.storm.generated.ExecutorSummary
- ExecutorSummary(ExecutorSummary) - Constructor for class org.apache.storm.generated.ExecutorSummary
-
Performs a deep copy on other.
- ExecutorSummary._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- executorTransfer - Variable in class org.apache.storm.executor.Executor
- ExecutorTransfer - Class in org.apache.storm.executor
- ExecutorTransfer(WorkerState, Map<String, Object>) - Constructor for class org.apache.storm.executor.ExecutorTransfer
- exists(byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- exists(byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- exists(byte[]) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- exists(String) - Method in class org.apache.storm.blobstore.FileBlobStoreImpl
-
Check if the key exists in the blob store.
- exists(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
-
Check if the key exists in the blob store.
- exists(String) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- exists(String) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- exists(String) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- exists(String) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- exists(String) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- exists(String) - Method in class org.apache.storm.redis.common.container.JedisContainer
- exists(CuratorFramework, String, boolean) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- EXISTS - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- EXISTS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EXISTS_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- existsNode(CuratorFramework, String, boolean) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- ExitCodeCallback - Interface in org.apache.storm.daemon.supervisor
-
A callback that can accept an integer.
- ExitCodeException(int, String) - Constructor for exception org.apache.storm.utils.ShellUtils.ExitCodeException
- exitedEarly - Variable in class org.apache.storm.daemon.supervisor.BasicContainer
- exitProcess(int, String) - Static method in class org.apache.storm.utils.Utils
- EXP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ExpandBuff(boolean) - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
- expandDataPoint(IMetricsConsumer.DataPoint) - Method in class org.apache.storm.metric.util.DataPointExpander
- expandDataPoints(Collection<IMetricsConsumer.DataPoint>) - Method in class org.apache.storm.metric.util.DataPointExpander
- ExpandList() - Constructor for class org.apache.storm.starter.trident.TridentReach.ExpandList
- expectedTaskReports - Variable in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordCondition
- expectedTokenSequences - Variable in exception org.apache.storm.sql.parser.impl.ParseException
-
Each entry in this array is an array of integers.
- EXPIRATION_TIME_MILLIS - Enum constant in enum class org.apache.storm.generated.PrivateWorkerKey._Fields
- EXPIRATION_TIME_MILLIS - Enum constant in enum class org.apache.storm.generated.WorkerTokenInfo._Fields
- expire(K, V) - Method in interface org.apache.storm.utils.RotatingMap.ExpiredCallback
- expire(K, V) - Method in interface org.apache.storm.utils.TimeCacheMap.ExpiredCallback
-
Deprecated.
- EXPIRE - Enum constant in enum class org.apache.storm.windowing.EvictionPolicy.Action
-
expire the event and remove it from the queue.
- EXPIRE_EVENTS_THRESHOLD - Static variable in class org.apache.storm.windowing.WindowManager
-
Expire old events every EXPIRE_EVENTS_THRESHOLD to keep the window size in check.
- expireIntervalSec - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateUpdater
- expireIntervalSec - Variable in class org.apache.storm.redis.trident.state.Options
- explain(Iterable<String>) - Method in class org.apache.storm.sql.StormSql
-
Print out query plan for each query.
- explain(String) - Method in class org.apache.storm.sql.StormSqlContext
- explain(RelNode) - Static method in class org.apache.storm.sql.planner.StormRelUtils
- explain(RelNode, SqlExplainLevel) - Static method in class org.apache.storm.sql.planner.StormRelUtils
- EXPLAIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ExplainDepth() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses WITH TYPE | WITH IMPLEMENTATION | WITHOUT IMPLEMENTATION modifier for EXPLAIN PLAN.
- ExplainDetailLevel() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses INCLUDING ALL ATTRIBUTES modifier for EXPLAIN PLAN.
- EXPLICIT - Enum constant in enum class org.apache.storm.windowing.persistence.WindowPartitionCache.RemovalCause
-
The entry was forcefully invalidated from the cache.
- ExplicitTable(SqlParserPos) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses an explicit TABLE t reference.
- EXPONENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- Expression(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a row expression or a parenthesized expression of any kind.
- Expression2(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a binary row expression, or a parenthesized expression of any kind.
- Expression2b(SqlAbstractParserImpl.ExprContext, List<Object>) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- Expression3(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a unary row expression, or a parenthesized expression of any kind.
- ExpressionCommaList(Span, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a list of expressions separated by commas.
- EXTEND - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ExtendedBuiltinFunctionCall() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- ExtendedTableRef() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Allows parser to be extended with new types of table references.
- ExtendedThreadPoolExecutor - Class in org.apache.storm.utils
- ExtendedThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class org.apache.storm.utils.ExtendedThreadPoolExecutor
- ExtendedThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.apache.storm.utils.ExtendedThreadPoolExecutor
- ExtendedThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.storm.utils.ExtendedThreadPoolExecutor
- ExtendedThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.apache.storm.utils.ExtendedThreadPoolExecutor
- ExtendList() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- extendTopology(TopologyBuilder) - Method in class org.apache.storm.coordination.BatchSubtopologyBuilder
- EXTERNAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- EXTRACT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- extractDataFromHb(Map, Map, Map<List<Integer>, Map<String, Object>>, boolean, StormTopology) - Static method in class org.apache.storm.stats.StatsUtil
-
extracts a list of executor data from heart beats.
- extractDataFromHb(Map, Map, Map<List<Integer>, Map<String, Object>>, boolean, StormTopology, String) - Static method in class org.apache.storm.stats.StatsUtil
-
extracts a list of executor data from heart beats.
- extractDirFromJar(String, String, Path) - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- extractNodeInfosFromHbForComp(Map<List<? extends Number>, List<Object>>, Map<Integer, String>, boolean, String) - Static method in class org.apache.storm.stats.StatsUtil
-
extract a list of host port info for specified component.
- extractResult(MeanReducerState) - Method in class org.apache.storm.metric.api.MeanReducer
- extractResult(T) - Method in interface org.apache.storm.metric.api.IReducer
- extractTimestamp(Tuple) - Method in class org.apache.storm.topology.TupleFieldTimestampExtractor
- extractTimestamp(Tuple) - Method in interface org.apache.storm.windowing.TimestampExtractor
-
Return the tuple timestamp indicating the time when the event happened.
- extractZipFile(ZipFile, File, String) - Static method in class org.apache.storm.utils.ServerUtils
-
Extracts the given file to the given directory.
F
- f1 - Variable in class org.apache.storm.testing.TestSerObject
- f2 - Variable in class org.apache.storm.testing.TestSerObject
- factory() - Method in class org.apache.storm.utils.ZookeeperServerCnxnFactory
- factory(Nimbus.Iface, String) - Static method in class org.apache.storm.perf.utils.MetricsSample
- Factory() - Constructor for class org.apache.storm.generated.DistributedRPC.Client.Factory
- Factory() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Client.Factory
- Factory() - Constructor for class org.apache.storm.generated.Nimbus.Client.Factory
- Factory() - Constructor for class org.apache.storm.generated.Supervisor.Client.Factory
- Factory() - Constructor for class org.apache.storm.starter.trident.DebugMemoryMapState.Factory
- Factory() - Constructor for class org.apache.storm.trident.testing.MemoryMapState.Factory
- Factory(int) - Constructor for class org.apache.storm.trident.testing.LRUMemoryMapState.Factory
- Factory(int...) - Constructor for class org.apache.storm.trident.tuple.ComboList.Factory
- Factory(Map) - Constructor for class org.apache.storm.starter.trident.TridentReach.StaticSingleKeyMapState.Factory
- Factory(JedisClusterConfig) - Constructor for class org.apache.storm.redis.trident.state.RedisClusterState.Factory
-
Constructor.
- Factory(JedisClusterConfig, StateType, Options) - Constructor for class org.apache.storm.redis.trident.state.RedisClusterMapState.Factory
-
Constructor.
- Factory(JedisPoolConfig) - Constructor for class org.apache.storm.redis.trident.state.RedisState.Factory
-
Constructor.
- Factory(JedisPoolConfig, StateType, Options) - Constructor for class org.apache.storm.redis.trident.state.RedisMapState.Factory
-
Constructor.
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.storm.generated.Supervisor.AsyncClient.Factory
- FACTORY - Static variable in class org.apache.storm.daemon.drpc.BlockingOutstandingRequest
- FACTORY - Static variable in class org.apache.storm.sql.parser.impl.StormParserImpl
-
SqlParserImplFactory
implementation for creating parser. - fail(Exception) - Method in class org.apache.storm.utils.BatchHelper
- fail(Object) - Method in class org.apache.storm.clojure.ClojureSpout
- fail(Object) - Method in class org.apache.storm.drpc.DRPCSpout
- fail(Object) - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.SentenceSpout
- fail(Object) - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.SentenceSpout
- fail(Object) - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- fail(Object) - Method in class org.apache.storm.jdbc.spout.UserSpout
- fail(Object) - Method in class org.apache.storm.jms.spout.JmsSpout
-
Fail an unsuccessfully handled message by its
JmsMessageID
. - fail(Object) - Method in class org.apache.storm.kafka.spout.KafkaSpout
- fail(Object) - Method in class org.apache.storm.loadgen.LoadSpout
- fail(Object) - Method in class org.apache.storm.redis.topology.WordSpout
- fail(Object) - Method in class org.apache.storm.spout.CheckpointSpout
- fail(Object) - Method in interface org.apache.storm.spout.ISpout
-
The tuple emitted by this spout with the msgId identifier has failed to be fully processed.
- fail(Object) - Method in class org.apache.storm.spout.ShellSpout
- fail(Object) - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- fail(Object) - Method in class org.apache.storm.st.topology.window.IncrementingSpout
- fail(Object) - Method in class org.apache.storm.starter.AnchoredWordCount.RandomSentenceSpout
- fail(Object) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.RandomSentenceSpout
- fail(Object) - Method in class org.apache.storm.starter.FastWordCountTopology.FastRandomSentenceSpout
- fail(Object) - Method in class org.apache.storm.starter.InOrderDeliveryTest.InOrderSpout
- fail(Object) - Method in class org.apache.storm.starter.spout.RandomIntegerSpout
- fail(Object) - Method in class org.apache.storm.starter.spout.RandomSentenceSpout
- fail(Object) - Method in interface org.apache.storm.testing.AckFailDelegate
- fail(Object) - Method in class org.apache.storm.testing.AckFailMapTracker
- fail(Object) - Method in class org.apache.storm.testing.AckTracker
- fail(Object) - Method in class org.apache.storm.testing.FeederSpout
- fail(Object) - Method in class org.apache.storm.testing.FixedTupleSpout
- fail(Object) - Method in class org.apache.storm.testing.SpoutTracker
- fail(Object) - Method in class org.apache.storm.testing.TestEventLogSpout
- fail(Object) - Method in class org.apache.storm.testing.TestPlannerSpout
- fail(Object) - Method in class org.apache.storm.testing.TestWordSpout
- fail(Object) - Method in class org.apache.storm.topology.base.BaseRichSpout
- fail(Object) - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- fail(Object) - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- fail(DRPCExecutionException) - Method in class org.apache.storm.daemon.drpc.BlockingOutstandingRequest
- fail(DRPCExecutionException) - Method in class org.apache.storm.daemon.drpc.OutstandingRequest
- fail(Tuple) - Method in class org.apache.storm.coordination.BatchOutputCollectorImpl
- fail(Tuple) - Method in class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
- fail(Tuple) - Method in class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
- fail(Tuple) - Method in interface org.apache.storm.task.IOutputCollector
- fail(Tuple) - Method in class org.apache.storm.task.OutputCollector
- FAIL_INVALID_TOPOLOGY - Enum constant in enum class org.apache.storm.scheduler.resource.SchedulingStatus
- FAIL_NOT_ENOUGH_RESOURCES - Enum constant in enum class org.apache.storm.scheduler.resource.SchedulingStatus
- FAIL_OTHER - Enum constant in enum class org.apache.storm.scheduler.resource.SchedulingStatus
- FAILED - Enum constant in enum class org.apache.storm.generated.BoltStats._Fields
- FAILED - Enum constant in enum class org.apache.storm.generated.CommonAggregateStats._Fields
- FAILED - Enum constant in enum class org.apache.storm.generated.SpoutStats._Fields
- FAILED_REQUEST - Enum constant in enum class org.apache.storm.generated.DRPCExceptionType
- FailedException - Exception in org.apache.storm.topology
- FailedException() - Constructor for exception org.apache.storm.topology.FailedException
- FailedException(String) - Constructor for exception org.apache.storm.topology.FailedException
- FailedException(String, Throwable) - Constructor for exception org.apache.storm.topology.FailedException
- FailedException(Throwable) - Constructor for exception org.apache.storm.topology.FailedException
- failingTaskId - Variable in class org.apache.storm.hooks.info.BoltFailInfo
- failLatencyMs - Variable in class org.apache.storm.hooks.info.BoltFailInfo
- failLatencyMs - Variable in class org.apache.storm.hooks.info.SpoutFailInfo
- failRequest() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequest
- failRequest() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequest
- failRequest(String) - Method in class org.apache.storm.daemon.drpc.DRPCThrift
- failRequest(String) - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- failRequest(String) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Client
- failRequest(String) - Method in interface org.apache.storm.generated.DistributedRPCInvocations.Iface
- failRequest(String) - Method in class org.apache.storm.LocalDRPC
- failRequest(String, DRPCExecutionException) - Method in class org.apache.storm.daemon.drpc.DRPC
- failRequest(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient
- failRequest(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.DistributedRPCInvocations.AsyncIface
- failRequest_args() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- failRequest_args(String) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- failRequest_args(DistributedRPCInvocations.failRequest_args) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
-
Performs a deep copy on other.
- failRequest_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.failRequest_call
- failRequest_result() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- failRequest_result(AuthorizationException) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- failRequest_result(DistributedRPCInvocations.failRequest_result) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
-
Performs a deep copy on other.
- failRequestV2() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequestV2
- failRequestV2() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequestV2
- failRequestV2(String, DRPCExecutionException) - Method in class org.apache.storm.daemon.drpc.DRPCThrift
- failRequestV2(String, DRPCExecutionException) - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- failRequestV2(String, DRPCExecutionException) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Client
- failRequestV2(String, DRPCExecutionException) - Method in interface org.apache.storm.generated.DistributedRPCInvocations.Iface
- failRequestV2(String, DRPCExecutionException) - Method in class org.apache.storm.LocalDRPC
- failRequestV2(String, DRPCExecutionException, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient
- failRequestV2(String, DRPCExecutionException, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.DistributedRPCInvocations.AsyncIface
- failRequestV2_args() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- failRequestV2_args(String, DRPCExecutionException) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- failRequestV2_args(DistributedRPCInvocations.failRequestV2_args) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
-
Performs a deep copy on other.
- failRequestV2_call(String, DRPCExecutionException, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.failRequestV2_call
- failRequestV2_result() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- failRequestV2_result(AuthorizationException) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- failRequestV2_result(DistributedRPCInvocations.failRequestV2_result) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
-
Performs a deep copy on other.
- failSpoutMsg(SpoutExecutor, Task, Long, TupleInfo, String) - Method in class org.apache.storm.executor.spout.SpoutExecutor
- failure - Static variable in enum class org.apache.storm.scheduler.resource.SchedulingStatus
- failure(SchedulingStatus, String) - Static method in class org.apache.storm.scheduler.resource.SchedulingResult
- FAILURE_RESPONSE - Enum constant in enum class org.apache.storm.messaging.netty.ControlMessage
- failVersion(String) - Method in class org.apache.storm.utils.VersionedStore
- FALSE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FastRandomSentenceSpout() - Constructor for class org.apache.storm.starter.FastWordCountTopology.FastRandomSentenceSpout
- FastRandomSentenceSpout(long) - Constructor for class org.apache.storm.loadgen.ThroughputVsLatency.FastRandomSentenceSpout
-
Constructor.
- FastWordCountTopology - Class in org.apache.storm.starter
-
WordCount but the spout does not stop, and the bolts are implemented in java.
- FastWordCountTopology() - Constructor for class org.apache.storm.starter.FastWordCountTopology
- FastWordCountTopology.FastRandomSentenceSpout - Class in org.apache.storm.starter
- FastWordCountTopology.SplitSentence - Class in org.apache.storm.starter
- FastWordCountTopology.WordCount - Class in org.apache.storm.starter
- favoredNodeIds - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorter
- favoredNodeIds - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
- feed(Object) - Method in class org.apache.storm.trident.testing.FeederBatchSpout
- feed(Object) - Method in class org.apache.storm.trident.testing.FeederCommitterBatchSpout
- feed(Object) - Method in interface org.apache.storm.trident.testing.IFeeder
- feed(List<Object>) - Method in class org.apache.storm.testing.FeederSpout
- feed(List<Object>, Object) - Method in class org.apache.storm.testing.FeederSpout
- FeederBatchSpout - Class in org.apache.storm.trident.testing
- FeederBatchSpout(List<String>) - Constructor for class org.apache.storm.trident.testing.FeederBatchSpout
- FeederBatchSpout.FeederCoordinator - Class in org.apache.storm.trident.testing
- FeederCommitterBatchSpout - Class in org.apache.storm.trident.testing
- FeederCommitterBatchSpout(List<String>) - Constructor for class org.apache.storm.trident.testing.FeederCommitterBatchSpout
- FeederCoordinator(int) - Constructor for class org.apache.storm.trident.testing.FeederBatchSpout.FeederCoordinator
- FeederSpout - Class in org.apache.storm.testing
- FeederSpout(List<String>) - Constructor for class org.apache.storm.testing.FeederSpout
- FeederSpout(Fields) - Constructor for class org.apache.storm.testing.FeederSpout
- feedNoWait(List<Object>, Object) - Method in class org.apache.storm.testing.FeederSpout
- fetch(ClientBlobStore, String, IOFunction<Long, Path>, IOFunction<File, OutputStream>) - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Helper function to download blob from blob store.
- FETCH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- fetched() - Method in class org.apache.storm.daemon.drpc.OutstandingRequest
- fetchRequest() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.fetchRequest
- fetchRequest() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Processor.fetchRequest
- fetchRequest(String) - Method in class org.apache.storm.daemon.drpc.DRPC
- fetchRequest(String) - Method in class org.apache.storm.daemon.drpc.DRPCThrift
- fetchRequest(String) - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- fetchRequest(String) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Client
- fetchRequest(String) - Method in interface org.apache.storm.generated.DistributedRPCInvocations.Iface
- fetchRequest(String) - Method in class org.apache.storm.LocalDRPC
- fetchRequest(String, AsyncMethodCallback<DRPCRequest>) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient
- fetchRequest(String, AsyncMethodCallback<DRPCRequest>) - Method in interface org.apache.storm.generated.DistributedRPCInvocations.AsyncIface
- fetchRequest_args() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- fetchRequest_args(String) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- fetchRequest_args(DistributedRPCInvocations.fetchRequest_args) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
-
Performs a deep copy on other.
- fetchRequest_call(String, AsyncMethodCallback<DRPCRequest>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.fetchRequest_call
- fetchRequest_result() - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- fetchRequest_result(DistributedRPCInvocations.fetchRequest_result) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
-
Performs a deep copy on other.
- fetchRequest_result(DRPCRequest, AuthorizationException) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- fetchUnzipToTemp(ClientBlobStore) - Method in class org.apache.storm.localizer.LocalizedResource
- fetchUnzipToTemp(ClientBlobStore) - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Download the latest version to a temp location.
- fetchUnzipToTemp(ClientBlobStore) - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- field - Variable in class org.apache.storm.trident.tuple.ValuePointer
- field(String, RelDataType) - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
- field(String, RelDataType, ColumnConstraint) - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
- field(String, SqlDataTypeSpec, ColumnConstraint) - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
- field(String, SqlTypeName) - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
- field(String, SqlTypeName, ColumnConstraint) - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
- FIELD_COMPONENT_ID - Static variable in class org.apache.storm.metric.EventLoggerBolt
- FIELD_MESSAGE_ID - Static variable in class org.apache.storm.metric.EventLoggerBolt
- FIELD_TS - Static variable in class org.apache.storm.metric.EventLoggerBolt
- FIELD_VALUES - Static variable in class org.apache.storm.metric.EventLoggerBolt
- fieldForId(int) - Method in class org.apache.storm.generated.AccessControl
- fieldForId(int) - Method in exception org.apache.storm.generated.AlreadyAliveException
- fieldForId(int) - Method in class org.apache.storm.generated.Assignment
- fieldForId(int) - Method in exception org.apache.storm.generated.AuthorizationException
- fieldForId(int) - Method in class org.apache.storm.generated.BeginDownloadResult
- fieldForId(int) - Method in class org.apache.storm.generated.Bolt
- fieldForId(int) - Method in class org.apache.storm.generated.BoltAggregateStats
- fieldForId(int) - Method in class org.apache.storm.generated.BoltStats
- fieldForId(int) - Method in class org.apache.storm.generated.ClusterSummary
- fieldForId(int) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- fieldForId(int) - Method in class org.apache.storm.generated.CommonAggregateStats
- fieldForId(int) - Method in class org.apache.storm.generated.ComponentAggregateStats
- fieldForId(int) - Method in class org.apache.storm.generated.ComponentCommon
- fieldForId(int) - Method in class org.apache.storm.generated.ComponentObject
- fieldForId(int) - Method in class org.apache.storm.generated.ComponentPageInfo
- fieldForId(int) - Method in class org.apache.storm.generated.Credentials
- fieldForId(int) - Method in class org.apache.storm.generated.DebugOptions
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- fieldForId(int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- fieldForId(int) - Method in exception org.apache.storm.generated.DRPCExecutionException
- fieldForId(int) - Method in class org.apache.storm.generated.DRPCRequest
- fieldForId(int) - Method in class org.apache.storm.generated.ErrorInfo
- fieldForId(int) - Method in class org.apache.storm.generated.ExecutorAggregateStats
- fieldForId(int) - Method in class org.apache.storm.generated.ExecutorInfo
- fieldForId(int) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- fieldForId(int) - Method in class org.apache.storm.generated.ExecutorStats
- fieldForId(int) - Method in class org.apache.storm.generated.ExecutorSummary
- fieldForId(int) - Method in class org.apache.storm.generated.GetInfoOptions
- fieldForId(int) - Method in class org.apache.storm.generated.GlobalStreamId
- fieldForId(int) - Method in class org.apache.storm.generated.Grouping
- fieldForId(int) - Method in exception org.apache.storm.generated.HBAuthorizationException
- fieldForId(int) - Method in exception org.apache.storm.generated.HBExecutionException
- fieldForId(int) - Method in class org.apache.storm.generated.HBMessage
- fieldForId(int) - Method in class org.apache.storm.generated.HBMessageData
- fieldForId(int) - Method in class org.apache.storm.generated.HBNodes
- fieldForId(int) - Method in class org.apache.storm.generated.HBPulse
- fieldForId(int) - Method in class org.apache.storm.generated.HBRecords
- fieldForId(int) - Method in exception org.apache.storm.generated.IllegalStateException
- fieldForId(int) - Method in exception org.apache.storm.generated.InvalidTopologyException
- fieldForId(int) - Method in class org.apache.storm.generated.JavaObject
- fieldForId(int) - Method in class org.apache.storm.generated.JavaObjectArg
- fieldForId(int) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- fieldForId(int) - Method in exception org.apache.storm.generated.KeyNotFoundException
- fieldForId(int) - Method in class org.apache.storm.generated.KillOptions
- fieldForId(int) - Method in class org.apache.storm.generated.ListBlobsResult
- fieldForId(int) - Method in class org.apache.storm.generated.LocalAssignment
- fieldForId(int) - Method in class org.apache.storm.generated.LocalStateData
- fieldForId(int) - Method in class org.apache.storm.generated.LogConfig
- fieldForId(int) - Method in class org.apache.storm.generated.LogLevel
- fieldForId(int) - Method in class org.apache.storm.generated.LSApprovedWorkers
- fieldForId(int) - Method in class org.apache.storm.generated.LSSupervisorAssignments
- fieldForId(int) - Method in class org.apache.storm.generated.LSSupervisorId
- fieldForId(int) - Method in class org.apache.storm.generated.LSTopoHistory
- fieldForId(int) - Method in class org.apache.storm.generated.LSTopoHistoryList
- fieldForId(int) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.activate_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.activate_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.debug_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.debug_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- fieldForId(int) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- fieldForId(int) - Method in class org.apache.storm.generated.NimbusSummary
- fieldForId(int) - Method in class org.apache.storm.generated.NodeInfo
- fieldForId(int) - Method in exception org.apache.storm.generated.NotAliveException
- fieldForId(int) - Method in class org.apache.storm.generated.NullStruct
- fieldForId(int) - Method in class org.apache.storm.generated.OwnerResourceSummary
- fieldForId(int) - Method in class org.apache.storm.generated.PrivateWorkerKey
- fieldForId(int) - Method in class org.apache.storm.generated.ProfileRequest
- fieldForId(int) - Method in class org.apache.storm.generated.ReadableBlobMeta
- fieldForId(int) - Method in class org.apache.storm.generated.RebalanceOptions
- fieldForId(int) - Method in class org.apache.storm.generated.SettableBlobMeta
- fieldForId(int) - Method in class org.apache.storm.generated.SharedMemory
- fieldForId(int) - Method in class org.apache.storm.generated.ShellComponent
- fieldForId(int) - Method in class org.apache.storm.generated.SpecificAggregateStats
- fieldForId(int) - Method in class org.apache.storm.generated.SpoutAggregateStats
- fieldForId(int) - Method in class org.apache.storm.generated.SpoutSpec
- fieldForId(int) - Method in class org.apache.storm.generated.SpoutStats
- fieldForId(int) - Method in class org.apache.storm.generated.StateSpoutSpec
- fieldForId(int) - Method in class org.apache.storm.generated.StormBase
- fieldForId(int) - Method in class org.apache.storm.generated.StormTopology
- fieldForId(int) - Method in class org.apache.storm.generated.StreamInfo
- fieldForId(int) - Method in class org.apache.storm.generated.SubmitOptions
- fieldForId(int) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- fieldForId(int) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- fieldForId(int) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- fieldForId(int) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- fieldForId(int) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- fieldForId(int) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- fieldForId(int) - Method in class org.apache.storm.generated.SupervisorAssignments
- fieldForId(int) - Method in class org.apache.storm.generated.SupervisorInfo
- fieldForId(int) - Method in class org.apache.storm.generated.SupervisorPageInfo
- fieldForId(int) - Method in class org.apache.storm.generated.SupervisorSummary
- fieldForId(int) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- fieldForId(int) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- fieldForId(int) - Method in class org.apache.storm.generated.ThriftSerializedObject
- fieldForId(int) - Method in class org.apache.storm.generated.TopologyActionOptions
- fieldForId(int) - Method in class org.apache.storm.generated.TopologyHistoryInfo
- fieldForId(int) - Method in class org.apache.storm.generated.TopologyInfo
- fieldForId(int) - Method in class org.apache.storm.generated.TopologyPageInfo
- fieldForId(int) - Method in class org.apache.storm.generated.TopologyStats
- fieldForId(int) - Method in class org.apache.storm.generated.TopologySummary
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerMetricList
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerMetricPoint
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerMetrics
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerResources
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerSummary
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerToken
- fieldForId(int) - Method in class org.apache.storm.generated.WorkerTokenInfo
- fieldGrouping(Grouping) - Static method in class org.apache.storm.Thrift
- fieldIndex(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- fieldIndex(String) - Method in class org.apache.storm.tuple.Fields
-
Returns the position of the specified named field.
- fieldIndex(String) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the position of the specified field in this tuple.
- fieldIndex(String) - Method in class org.apache.storm.tuple.TupleImpl
- FieldIndexTopicSelector - Class in org.apache.storm.kafka.bolt.selector
-
Uses field with a given index to select the topic name from a tuple .
- FieldIndexTopicSelector(int, String) - Constructor for class org.apache.storm.kafka.bolt.selector.FieldIndexTopicSelector
-
Creates a new FieldIndexTopicSelector.
- FieldInfo - Class in org.apache.storm.sql.runtime
-
Describe each column of the field.
- FieldInfo(String, Class<?>, boolean) - Constructor for class org.apache.storm.sql.runtime.FieldInfo
-
FieldInfo Constructor.
- FieldInfoUtils - Class in org.apache.storm.sql.runtime.utils
- FieldInfoUtils() - Constructor for class org.apache.storm.sql.runtime.utils.FieldInfoUtils
- fieldList() - Method in class org.apache.storm.sql.parser.SqlCreateTable
- FieldNameBasedTupleToKafkaMapper<K,
V> - Class in org.apache.storm.kafka.bolt.mapper - FieldNameBasedTupleToKafkaMapper<K,
V> - Class in org.apache.storm.kafka.trident.mapper - FieldNameBasedTupleToKafkaMapper() - Constructor for class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- FieldNameBasedTupleToKafkaMapper(String, String) - Constructor for class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- FieldNameBasedTupleToKafkaMapper(String, String) - Constructor for class org.apache.storm.kafka.trident.mapper.FieldNameBasedTupleToKafkaMapper
- FieldNameTopicSelector - Class in org.apache.storm.kafka.bolt.selector
-
Uses field name to select topic name from tuple .
- FieldNameTopicSelector(String, String) - Constructor for class org.apache.storm.kafka.bolt.selector.FieldNameTopicSelector
- fields(List<String>) - Static method in class org.apache.storm.generated.Grouping
- Fields - Class in org.apache.storm.tuple
-
Collection of unique named fields using in an ITuple.
- Fields(String...) - Constructor for class org.apache.storm.tuple.Fields
- Fields(List<String>) - Constructor for class org.apache.storm.tuple.Fields
- FIELDS - Enum constant in enum class org.apache.storm.flux.model.GroupingDef.Type
- FIELDS - Enum constant in enum class org.apache.storm.generated.Grouping._Fields
- FIELDS - Enum constant in enum class org.apache.storm.loadgen.GroupingType
- FIELDS - Static variable in class org.apache.storm.hdfs.spout.HdfsSpoutTopology.ConstBolt
- FIELDS - Static variable in class org.apache.storm.kafka.spout.DefaultRecordTranslator
- FIELDS - Static variable in class org.apache.storm.perf.bolt.SplitSentenceBolt
- FIELDS - Static variable in class org.apache.storm.perf.spout.FileReadSpout
- FIELDS - Static variable in class org.apache.storm.perf.spout.WordGenSpout
- FIELDS_COUNT - Static variable in class org.apache.storm.perf.bolt.CountBolt
- FIELDS_WORD - Static variable in class org.apache.storm.perf.bolt.CountBolt
- fieldsConcat(Fields...) - Static method in class org.apache.storm.trident.util.TridentUtils
- FieldSelector(String) - Constructor for class org.apache.storm.bolt.JoinBolt.FieldSelector
- FieldSelector(String, String) - Constructor for class org.apache.storm.bolt.JoinBolt.FieldSelector
-
Constructor.
- FieldSelector(String, String[]) - Constructor for class org.apache.storm.bolt.JoinBolt.FieldSelector
- FieldsGrouper(Fields, Grouping) - Constructor for class org.apache.storm.daemon.GrouperFactory.FieldsGrouper
- fieldsGrouping(String, String, Fields) - Method in interface org.apache.storm.topology.InputDeclarer
-
The stream is partitioned by the fields specified in the grouping.
- fieldsGrouping(String, String, Fields) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- fieldsGrouping(String, Fields) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- fieldsGrouping(String, Fields) - Method in interface org.apache.storm.topology.InputDeclarer
-
The stream is partitioned by the fields specified in the grouping.
- fieldsGrouping(String, Fields) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- fieldsGrouping(Fields) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- fieldsSubtract(Fields, Fields) - Static method in class org.apache.storm.trident.util.TridentUtils
- fieldsUnion(Fields...) - Static method in class org.apache.storm.trident.util.TridentUtils
- FIFOSchedulingPriorityStrategy - Class in org.apache.storm.scheduler.resource.strategies.priority
- FIFOSchedulingPriorityStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.priority.FIFOSchedulingPriorityStrategy
- FIFOSchedulingPriorityStrategy.FIFOSimulatedUser - Class in org.apache.storm.scheduler.resource.strategies.priority
- FIFOSimulatedUser(User, ISchedulingState) - Constructor for class org.apache.storm.scheduler.resource.strategies.priority.FIFOSchedulingPriorityStrategy.FIFOSimulatedUser
- file - Variable in class org.apache.storm.perf.spout.FileReadSpout.FileReader
- FILE_SEPARATOR - Static variable in class org.apache.storm.utils.ConfigUtils
- FILE_SEPARATOR - Static variable in class org.apache.storm.utils.ServerConfigUtils
- FileBasedEventLogger - Class in org.apache.storm.metric
- FileBasedEventLogger() - Constructor for class org.apache.storm.metric.FileBasedEventLogger
- FileBlobStoreImpl - Class in org.apache.storm.blobstore
-
Very basic blob store impl with no ACL handling.
- FileBlobStoreImpl(File, Map<String, Object>) - Constructor for class org.apache.storm.blobstore.FileBlobStoreImpl
- FileBlobStoreImpl.KeyInHashDirIterator - Class in org.apache.storm.blobstore
- FileConfigLoader - Class in org.apache.storm.scheduler.utils
-
Scheduler configuration loader which loads configs from a file.
- FileConfigLoader(Map<String, Object>) - Constructor for class org.apache.storm.scheduler.utils.FileConfigLoader
- FileConfigLoaderFactory - Class in org.apache.storm.scheduler.utils
-
Factory class for FileConfigLoader.
- FileConfigLoaderFactory() - Constructor for class org.apache.storm.scheduler.utils.FileConfigLoaderFactory
- fileExists(File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Check if a file exists or not.
- fileExists(File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Check if a file exists or not.
- fileExists(Path) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Check if a file exists or not.
- fileExists(Path) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Check if a file exists or not.
- FileLock - Class in org.apache.storm.hdfs.spout
-
Facility to synchronize access to HDFS files.
- FileLock.LogEntry - Class in org.apache.storm.hdfs.spout
- fileNameFormat - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- fileNameFormat - Variable in class org.apache.storm.hdfs.trident.HdfsState.Options
- FileNameFormat - Interface in org.apache.storm.hdfs.bolt.format
-
Formatter interface for determining HDFS file names.
- FileNameFormat - Interface in org.apache.storm.hdfs.trident.format
-
Formatter interface for determining HDFS file names.
- FileNotAvailableException - Exception in org.apache.storm.dependency
- FileNotAvailableException(String) - Constructor for exception org.apache.storm.dependency.FileNotAvailableException
- FileNotAvailableException(String, Throwable) - Constructor for exception org.apache.storm.dependency.FileNotAvailableException
- fileOffset - Variable in class org.apache.storm.hdfs.spout.FileLock.LogEntry
- filePath - Variable in class org.apache.storm.hdfs.common.AbstractHDFSWriter
- FileReader(String) - Constructor for class org.apache.storm.perf.spout.FileReadSpout.FileReader
- FileReadSpout - Class in org.apache.storm.perf.spout
- FileReadSpout(String) - Constructor for class org.apache.storm.perf.spout.FileReadSpout
- FileReadSpout.FileReader - Class in org.apache.storm.perf.spout
- FileReadWordCountTopo - Class in org.apache.storm.perf
-
This topo helps measure speed of word count.
- FileReadWordCountTopo() - Constructor for class org.apache.storm.perf.FileReadWordCountTopo
- fileRetryCount - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- FileRotationPolicy - Interface in org.apache.storm.hdfs.bolt.rotation
-
Used by the HdfsBolt to decide when to rotate files.
- FileRotationPolicy - Interface in org.apache.storm.hdfs.trident.rotation
-
Used by the HdfsBolt to decide when to rotate files.
- FileSizeRotationPolicy - Class in org.apache.storm.hdfs.bolt.rotation
-
File rotation policy that will rotate files when a certain file size is reached.
- FileSizeRotationPolicy - Class in org.apache.storm.hdfs.trident.rotation
-
File rotation policy that will rotate files when a certain file size is reached.
- FileSizeRotationPolicy(float, FileSizeRotationPolicy.Units) - Constructor for class org.apache.storm.hdfs.bolt.rotation.FileSizeRotationPolicy
- FileSizeRotationPolicy(float, FileSizeRotationPolicy.Units) - Constructor for class org.apache.storm.hdfs.trident.rotation.FileSizeRotationPolicy
- FileSizeRotationPolicy(long) - Constructor for class org.apache.storm.hdfs.bolt.rotation.FileSizeRotationPolicy
- FileSizeRotationPolicy.Units - Enum Class in org.apache.storm.hdfs.bolt.rotation
- FileSizeRotationPolicy.Units - Enum Class in org.apache.storm.hdfs.trident.rotation
- FileWatcher - Class in org.apache.storm.daemon.common
- FileWatcher(Path, FileWatcher.Callback) - Constructor for class org.apache.storm.daemon.common.FileWatcher
- FileWatcher(Path, FileWatcher.Callback, List<WatchEvent.Kind<Path>>) - Constructor for class org.apache.storm.daemon.common.FileWatcher
- FileWatcher.Callback - Interface in org.apache.storm.daemon.common
- FillBuff() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
- fillHadoopConfiguration(Map, String, Configuration) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- filter(ContainerRequestContext) - Method in class org.apache.storm.daemon.ui.filters.AuthorizedUserFilter
- filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.apache.storm.daemon.ui.filters.HeaderResponseFilter
- filter(String) - Method in interface org.apache.storm.blobstore.KeyFilter
- filter(Predicate<? super Pair<K, V>>) - Method in class org.apache.storm.streams.PairStream
-
Returns a stream consisting of the elements of this stream that matches the given filter.
- filter(Predicate<? super T>) - Method in class org.apache.storm.streams.Stream
-
Returns a stream consisting of the elements of this stream that matches the given filter.
- filter(Filter) - Method in class org.apache.storm.trident.Stream
-
Returns a stream consisting of the elements of this stream that match the given filter.
- filter(Fields, Filter) - Method in class org.apache.storm.trident.Stream
-
Returns a stream consisting of the elements of this stream that match the given filter.
- Filter - Interface in org.apache.storm.trident.operation
-
Filters take in a tuple as input and decide whether or not to keep that tuple or not.
- FILTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- filterAndListKeys(KeyFilter<R>) - Method in class org.apache.storm.blobstore.BlobStore
-
Filters keys based on the KeyFilter passed as the argument.
- filterAuthorized(String, Collection<String>) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- FilterByMetricName - Class in org.apache.storm.metric.filter
- FilterByMetricName(List<String>, List<String>) - Constructor for class org.apache.storm.metric.filter.FilterByMetricName
- FilterConfiguration - Class in org.apache.storm.daemon.ui
- FilterConfiguration(String, String, Map<String, String>) - Constructor for class org.apache.storm.daemon.ui.FilterConfiguration
-
FilterConfiguration.
- FilterConfiguration(String, Map<String, String>) - Constructor for class org.apache.storm.daemon.ui.FilterConfiguration
-
FilterConfiguration.
- FilterExecutor - Class in org.apache.storm.trident.operation.impl
- FilterExecutor(Filter) - Constructor for class org.apache.storm.trident.operation.impl.FilterExecutor
- FilterNull - Class in org.apache.storm.trident.operation.builtin
-
Simple `Filter` implementation that filters out any tuples that have fields with a value of `null`.
- FilterNull() - Constructor for class org.apache.storm.trident.operation.builtin.FilterNull
- filterOldTopologies(long) - Method in class org.apache.storm.utils.LocalState
-
Remove topologies from local state which are older than cutOffAge.
- FilterOptions - Class in org.apache.storm.metricstore
-
FilterOptions provides a method to select various filtering options for doing a scan of the metrics database.
- FilterOptions() - Constructor for class org.apache.storm.metricstore.FilterOptions
- FilterProcessor<T> - Class in org.apache.storm.streams.processors
- FilterProcessor(Predicate<T>) - Constructor for class org.apache.storm.streams.processors.FilterProcessor
- FilterWords() - Constructor for class org.apache.storm.starter.BlobStoreAPIWordCountTopology.FilterWords
- FINAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FINAL_BOLT - Static variable in class org.apache.storm.jms.example.ExampleJmsTopology
- finalize() - Method in class org.apache.storm.blobstore.NimbusBlobStore
- findAndReadConfigFile(String) - Static method in class org.apache.storm.utils.Utils
- findAndReadConfigFile(String, boolean) - Static method in class org.apache.storm.utils.Utils
- findByName(String) - Static method in enum class org.apache.storm.generated.AccessControl._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.AlreadyAliveException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Assignment._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.AuthorizationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.BeginDownloadResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Bolt._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.BoltAggregateStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.BoltStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ClusterSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ClusterWorkerHeartbeat._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.CommonAggregateStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ComponentAggregateStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ComponentCommon._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ComponentObject._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ComponentPageInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Credentials._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DebugOptions._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DRPCExecutionException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.DRPCRequest._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ErrorInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ExecutorAggregateStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ExecutorInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ExecutorSpecificStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ExecutorStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ExecutorSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.GetInfoOptions._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.GlobalStreamId._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Grouping._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBAuthorizationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBExecutionException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBMessage._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBMessageData._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBNodes._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBPulse._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.HBRecords._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.IllegalStateException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.InvalidTopologyException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.JavaObject._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.JavaObjectArg._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.KeyAlreadyExistsException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.KeyNotFoundException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.KillOptions._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ListBlobsResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LocalAssignment._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LocalStateData._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LogConfig._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LogLevel._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LSApprovedWorkers._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LSSupervisorAssignments._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LSSupervisorId._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LSTopoHistory._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LSTopoHistoryList._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.LSWorkerHeartbeat._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.activate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.deactivate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.deleteBlob_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.downloadChunk_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.downloadChunk_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getLeader_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getLeader_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getLogConfig_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getLogConfig_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopology_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getUserTopology_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.killTopology_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.listBlobs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.listBlobs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.rebalance_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.setLogConfig_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.setLogConfig_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopology_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.uploadChunk_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.uploadChunk_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.NimbusSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.NodeInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.NotAliveException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.NullStruct._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.PrivateWorkerKey._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ProfileRequest._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ReadableBlobMeta._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.RebalanceOptions._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SettableBlobMeta._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SharedMemory._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ShellComponent._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SpecificAggregateStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SpoutAggregateStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SpoutSpec._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SpoutStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.StateSpoutSpec._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.StormBase._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.StormTopology._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.StreamInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SubmitOptions._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SupervisorAssignments._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SupervisorInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SupervisorPageInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SupervisorSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeat._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.ThriftSerializedObject._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.TopologyActionOptions._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.TopologyHistoryInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.TopologyInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.TopologyPageInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.TopologyStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.TopologySummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerMetricList._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerMetrics._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerResources._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerToken._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum class org.apache.storm.generated.WorkerTokenInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.AccessControl._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.AlreadyAliveException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Assignment._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.AuthorizationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.BeginDownloadResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Bolt._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.BoltAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.BoltStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ClusterSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ClusterWorkerHeartbeat._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.CommonAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ComponentAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ComponentCommon._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ComponentObject._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ComponentPageInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Credentials._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DebugOptions._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DRPCExecutionException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.DRPCRequest._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ErrorInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ExecutorAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ExecutorInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ExecutorSpecificStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ExecutorStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ExecutorSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.GetInfoOptions._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.GlobalStreamId._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Grouping._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBAuthorizationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBExecutionException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBMessage._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBMessageData._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBNodes._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBPulse._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.HBRecords._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.IllegalStateException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.InvalidTopologyException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.JavaObject._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.JavaObjectArg._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.KeyAlreadyExistsException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.KeyNotFoundException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.KillOptions._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ListBlobsResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LocalAssignment._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LocalStateData._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LogConfig._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LogLevel._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LSApprovedWorkers._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LSSupervisorAssignments._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LSSupervisorId._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LSTopoHistory._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LSTopoHistoryList._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.LSWorkerHeartbeat._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.activate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.deactivate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.deleteBlob_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadChunk_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadChunk_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLeader_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLeader_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLogConfig_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLogConfig_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopology_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getUserTopology_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopology_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.listBlobs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.listBlobs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.rebalance_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.setLogConfig_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.setLogConfig_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopology_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadChunk_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadChunk_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.NimbusSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.NodeInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.NotAliveException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.NullStruct._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.PrivateWorkerKey._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ProfileRequest._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ReadableBlobMeta._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.RebalanceOptions._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SettableBlobMeta._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SharedMemory._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ShellComponent._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SpecificAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SpoutAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SpoutSpec._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SpoutStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.StateSpoutSpec._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.StormBase._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.StormTopology._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.StreamInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SubmitOptions._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SupervisorAssignments._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SupervisorInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SupervisorPageInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SupervisorSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeat._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.ThriftSerializedObject._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.TopologyActionOptions._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.TopologyHistoryInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.TopologyInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.TopologyPageInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.TopologyStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.TopologySummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerMetricList._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerMetrics._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerResources._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerToken._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum class org.apache.storm.generated.WorkerTokenInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.AccessControl._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.AlreadyAliveException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Assignment._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.AuthorizationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.BeginDownloadResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Bolt._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.BoltAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.BoltStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ClusterSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ClusterWorkerHeartbeat._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.CommonAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ComponentAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ComponentCommon._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ComponentObject._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ComponentPageInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Credentials._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DebugOptions._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DRPCExecutionException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.DRPCRequest._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ErrorInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ExecutorAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ExecutorInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ExecutorSpecificStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ExecutorStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ExecutorSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.GetInfoOptions._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.GlobalStreamId._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Grouping._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBAuthorizationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBExecutionException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBMessage._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBMessageData._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBNodes._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBPulse._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.HBRecords._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.IllegalStateException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.InvalidTopologyException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.JavaObject._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.JavaObjectArg._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.KeyAlreadyExistsException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.KeyNotFoundException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.KillOptions._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ListBlobsResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LocalAssignment._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LocalStateData._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LogConfig._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LogLevel._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LSApprovedWorkers._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LSSupervisorAssignments._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LSSupervisorId._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LSTopoHistory._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LSTopoHistoryList._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.LSWorkerHeartbeat._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.activate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.deactivate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.deleteBlob_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadChunk_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.downloadChunk_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLeader_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLeader_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLogConfig_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getLogConfig_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopology_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getUserTopology_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopology_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.listBlobs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.listBlobs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.rebalance_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.setLogConfig_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.setLogConfig_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopology_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadChunk_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadChunk_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.NimbusSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.NodeInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.NotAliveException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.NullStruct._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.PrivateWorkerKey._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ProfileRequest._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ReadableBlobMeta._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.RebalanceOptions._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SettableBlobMeta._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SharedMemory._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ShellComponent._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SpecificAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SpoutAggregateStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SpoutSpec._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SpoutStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.StateSpoutSpec._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.StormBase._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.StormTopology._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.StreamInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SubmitOptions._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SupervisorAssignments._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SupervisorInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SupervisorPageInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SupervisorSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeat._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.ThriftSerializedObject._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.TopologyActionOptions._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.TopologyHistoryInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.TopologyInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.TopologyPageInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.TopologyStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.TopologySummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerMetricList._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerMetrics._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerResources._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerToken._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum class org.apache.storm.generated.WorkerTokenInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByValue(int) - Static method in enum class org.apache.storm.generated.AccessControlType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.ComponentType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.DRPCExceptionType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.HBServerMessageType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.LogLevelAction
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.NumErrorsChoice
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.ProfileAction
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.TopologyInitialStatus
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.TopologyStatus
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum class org.apache.storm.generated.WorkerTokenServiceType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findClass(String) - Method in class org.apache.storm.sql.javac.CompilingClassLoader
-
Override ClassLoader's class resolving method.
- findComponentCycles(StormTopology, String) - Static method in class org.apache.storm.utils.Utils
-
Find and return components cycles in the topology graph when starting from spout.
- findNextCommitOffset(String) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
-
An offset can only be committed when all emitted records with lower offset have been acked.
- findOne(IPredicate<T>, Collection<T>) - Static method in class org.apache.storm.utils.Utils
-
Find the first item of coll for which pred.test(...) returns true.
- findOne(IPredicate<T>, Map<U, T>) - Static method in class org.apache.storm.utils.Utils
- findResources(String) - Static method in class org.apache.storm.utils.Utils
- findWorkerToken(Subject, WorkerTokenServiceType) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Find a worker token in a given subject with a given token type.
- findWorkerTokenInSubject(ThriftConnectionType) - Static method in class org.apache.storm.security.auth.workertoken.WorkerTokenClientCallbackHandler
-
Look in the current subject for a WorkerToken.
- finish() - Method in class org.apache.storm.streams.processors.AggregateByKeyProcessor
- finish() - Method in class org.apache.storm.streams.processors.AggregateProcessor
- finish() - Method in class org.apache.storm.streams.processors.MapValuesProcessor
-
This is triggered to signal the end of the current batch of values.
- finish() - Method in class org.apache.storm.streams.processors.CoGroupByKeyProcessor
- finish() - Method in class org.apache.storm.streams.processors.JoinProcessor
- finish() - Method in class org.apache.storm.streams.processors.MergeAggregateByKeyProcessor
- finish() - Method in class org.apache.storm.streams.processors.MergeAggregateProcessor
- finish() - Method in class org.apache.storm.streams.processors.ReduceByKeyProcessor
- finish() - Method in class org.apache.storm.streams.processors.ReduceProcessor
- finishBatch() - Method in interface org.apache.storm.coordination.IBatchBolt
- finishBatch() - Method in class org.apache.storm.starter.ReachTopology.CountAggregator
- finishBatch() - Method in class org.apache.storm.starter.ReachTopology.PartialUniquer
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.AggregateProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.EachProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.MapProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.MultiReducerProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.PartitionPersistProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.ProjectedProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.planner.processor.StateQueryProcessor
- finishBatch(ProcessorContext) - Method in interface org.apache.storm.trident.planner.TridentProcessor
- finishBatch(ProcessorContext) - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- finishBatch(BatchInfo) - Method in class org.apache.storm.trident.planner.SubtopologyBolt
- finishBatch(BatchInfo) - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
- finishBatch(BatchInfo) - Method in interface org.apache.storm.trident.topology.ITridentBatchBolt
- finishBlobUpload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.finishBlobUpload
- finishBlobUpload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.finishBlobUpload
- finishBlobUpload(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- finishBlobUpload(String) - Method in class org.apache.storm.generated.Nimbus.Client
- finishBlobUpload(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- finishBlobUpload(String) - Method in class org.apache.storm.LocalCluster
- finishBlobUpload(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- finishBlobUpload(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- finishBlobUpload_args() - Constructor for class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- finishBlobUpload_args(String) - Constructor for class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- finishBlobUpload_args(Nimbus.finishBlobUpload_args) - Constructor for class org.apache.storm.generated.Nimbus.finishBlobUpload_args
-
Performs a deep copy on other.
- finishBlobUpload_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.finishBlobUpload_call
- finishBlobUpload_result() - Constructor for class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- finishBlobUpload_result(AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- finishBlobUpload_result(Nimbus.finishBlobUpload_result) - Constructor for class org.apache.storm.generated.Nimbus.finishBlobUpload_result
-
Performs a deep copy on other.
- finishedId(Object) - Method in class org.apache.storm.clojure.ClojureBolt
- finishedId(Object) - Method in class org.apache.storm.coordination.BatchBoltExecutor
- finishedId(Object) - Method in interface org.apache.storm.coordination.CoordinatedBolt.FinishedCallback
- finishedId(Object) - Method in class org.apache.storm.drpc.KeyedFairBolt
- finishFileUpload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.finishFileUpload
- finishFileUpload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.finishFileUpload
- finishFileUpload(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- finishFileUpload(String) - Method in class org.apache.storm.generated.Nimbus.Client
- finishFileUpload(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- finishFileUpload(String) - Method in class org.apache.storm.LocalCluster
- finishFileUpload(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- finishFileUpload(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- finishFileUpload_args() - Constructor for class org.apache.storm.generated.Nimbus.finishFileUpload_args
- finishFileUpload_args(String) - Constructor for class org.apache.storm.generated.Nimbus.finishFileUpload_args
- finishFileUpload_args(Nimbus.finishFileUpload_args) - Constructor for class org.apache.storm.generated.Nimbus.finishFileUpload_args
-
Performs a deep copy on other.
- finishFileUpload_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.finishFileUpload_call
- finishFileUpload_result() - Constructor for class org.apache.storm.generated.Nimbus.finishFileUpload_result
- finishFileUpload_result(AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.finishFileUpload_result
- finishFileUpload_result(Nimbus.finishFileUpload_result) - Constructor for class org.apache.storm.generated.Nimbus.finishFileUpload_result
-
Performs a deep copy on other.
- first(List<T>) - Static method in class org.apache.storm.daemon.utils.ListFunctionalSupport
-
Get the first element in list.
- FIRST - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FIRST_OFFSET_KEY - Static variable in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutBatchMetadata
- FIRST_VALUE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FIRST_WINS - Static variable in class org.apache.storm.command.CLI
-
First occurrence on the command line is the resulting value.
- FirstN - Class in org.apache.storm.trident.operation.builtin
-
An
Assembly
implementation. - FirstN(int, String) - Constructor for class org.apache.storm.trident.operation.builtin.FirstN
- FirstN(int, String, boolean) - Constructor for class org.apache.storm.trident.operation.builtin.FirstN
- FirstN.FirstNAgg - Class in org.apache.storm.trident.operation.builtin
- FirstN.FirstNSortedAgg - Class in org.apache.storm.trident.operation.builtin
- FirstNAgg(int) - Constructor for class org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg
- FirstNSortedAgg(int, String, boolean) - Constructor for class org.apache.storm.trident.operation.builtin.FirstN.FirstNSortedAgg
- FirstPollOffsetStrategy - Enum Class in org.apache.storm.kafka.spout
-
Defines how the spout seeks the offset to be used in the first poll to Kafka upon topology deployment.
- FixedAvroSerializer - Class in org.apache.storm.hdfs.avro
-
A class to help (de)serialize a pre-defined set of Avro schemas.
- FixedAvroSerializer() - Constructor for class org.apache.storm.hdfs.avro.FixedAvroSerializer
- FixedBatchSpout - Class in org.apache.storm.hdfs.trident
- FixedBatchSpout - Class in org.apache.storm.trident.testing
- FixedBatchSpout(Fields, int, List<Object>...) - Constructor for class org.apache.storm.hdfs.trident.FixedBatchSpout
- FixedBatchSpout(Fields, int, List<Object>...) - Constructor for class org.apache.storm.trident.testing.FixedBatchSpout
- FixedGroupsMapping - Class in org.apache.storm.security.auth
- FixedGroupsMapping() - Constructor for class org.apache.storm.security.auth.FixedGroupsMapping
- FixedOrderWordSpout() - Constructor for class org.apache.storm.ExclamationTopology.FixedOrderWordSpout
- FixedTuple - Class in org.apache.storm.testing
- FixedTuple(String, List<Object>) - Constructor for class org.apache.storm.testing.FixedTuple
- FixedTuple(List<Object>) - Constructor for class org.apache.storm.testing.FixedTuple
- FixedTupleSpout - Class in org.apache.storm.testing
- FixedTupleSpout(List) - Constructor for class org.apache.storm.testing.FixedTupleSpout
- FixedTupleSpout(List, Fields) - Constructor for class org.apache.storm.testing.FixedTupleSpout
- flatMap(FlatMapFunction<? super T, ? extends R>) - Method in class org.apache.storm.streams.Stream
-
Returns a stream consisting of the results of replacing each value of this stream with the contents produced by applying the provided mapping function to each value.
- flatMap(FlatMapFunction) - Method in class org.apache.storm.trident.Stream
-
Returns a stream consisting of the results of replacing each value of this stream with the contents produced by applying the provided mapping function to each value.
- flatMap(FlatMapFunction, Fields) - Method in class org.apache.storm.trident.Stream
-
Returns a stream consisting of the results of replacing each value of this stream with the contents produced by applying the provided mapping function to each value.
- FlatMapFunction<T,
R> - Interface in org.apache.storm.streams.operations -
A function that accepts one argument and returns an
Iterable
of elements as its result. - FlatMapFunction - Interface in org.apache.storm.trident.operation
-
A one to many transformation function.
- FlatMapFunctionExecutor - Class in org.apache.storm.trident.operation.impl
- FlatMapFunctionExecutor(FlatMapFunction) - Constructor for class org.apache.storm.trident.operation.impl.FlatMapFunctionExecutor
- FlatMapProcessor<T,
R> - Class in org.apache.storm.streams.processors - FlatMapProcessor(FlatMapFunction<T, R>) - Constructor for class org.apache.storm.streams.processors.FlatMapProcessor
- flatMapToPair(PairFlatMapFunction<? super T, ? extends K, ? extends V>) - Method in class org.apache.storm.streams.Stream
-
Returns a stream consisting of the results of replacing each value of this stream with the key-value pairs produced by applying the provided mapping function to each value.
- flatMapValues(FlatMapFunction<? super V, ? extends R>) - Method in class org.apache.storm.streams.PairStream
-
Return a new stream by applying a
FlatMapFunction
function to the value of each key-value pairs in this stream. - FlatMapValuesProcessor<K,
V, R> - Class in org.apache.storm.streams.processors - FlatMapValuesProcessor(FlatMapFunction<V, R>) - Constructor for class org.apache.storm.streams.processors.FlatMapValuesProcessor
- FLOAT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- floatStr(Double) - Static method in class org.apache.storm.stats.StatsUtil
-
Convert a float to a string for display.
- floor(ZonedDateTime, int) - Static method in class org.apache.storm.st.utils.TimeUtil
- FLOOR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FloorCeilOptions(Span, boolean) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- flush() - Method in class org.apache.storm.coordination.BatchOutputCollector
-
Flush any buffered tuples (when batching is enabled).
- flush() - Method in class org.apache.storm.coordination.BatchOutputCollectorImpl
- flush() - Method in class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
- flush() - Method in class org.apache.storm.daemon.worker.WorkerTransfer
- flush() - Method in class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
- flush() - Method in class org.apache.storm.executor.Executor
- flush() - Method in class org.apache.storm.executor.ExecutorTransfer
- flush() - Method in class org.apache.storm.executor.spout.SpoutOutputCollectorImpl
- flush() - Method in interface org.apache.storm.spout.ISpoutOutputCollector
- flush() - Method in class org.apache.storm.spout.SpoutOutputCollector
- flush() - Method in interface org.apache.storm.task.IOutputCollector
- flush() - Method in class org.apache.storm.task.OutputCollector
- flush() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- flush() - Method in class org.apache.storm.trident.operation.impl.CaptureCollector
- flush() - Method in class org.apache.storm.trident.operation.impl.GroupCollector
- flush() - Method in interface org.apache.storm.trident.operation.TridentCollector
-
Flush any buffered tuples (when batching is enabled).
- flush() - Method in class org.apache.storm.trident.planner.BridgeReceiver
- flush() - Method in class org.apache.storm.trident.planner.processor.AggregateProcessor
- flush() - Method in class org.apache.storm.trident.planner.processor.AppendCollector
- flush() - Method in class org.apache.storm.trident.planner.processor.EachProcessor
- flush() - Method in class org.apache.storm.trident.planner.processor.FreshCollector
- flush() - Method in class org.apache.storm.trident.planner.processor.MapProcessor
- flush() - Method in class org.apache.storm.trident.planner.processor.MultiReducerProcessor
- flush() - Method in class org.apache.storm.trident.planner.processor.PartitionPersistProcessor
- flush() - Method in class org.apache.storm.trident.planner.processor.ProjectedProcessor
- flush() - Method in class org.apache.storm.trident.planner.processor.StateQueryProcessor
- flush() - Method in interface org.apache.storm.trident.planner.TupleReceiver
- flush() - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- flush() - Method in interface org.apache.storm.utils.JCQueue.Consumer
- flush() - Method in class org.apache.storm.utils.JCQueue
-
if(batchSz>1) : Blocking call.
- flushRemotes() - Method in class org.apache.storm.daemon.worker.WorkerState
- flushRemotes() - Method in class org.apache.storm.daemon.worker.WorkerTransfer
- Flux - Class in org.apache.storm.flux
-
Flux entry point.
- Flux() - Constructor for class org.apache.storm.flux.Flux
- FluxBuilder - Class in org.apache.storm.flux
- FluxBuilder() - Constructor for class org.apache.storm.flux.FluxBuilder
- FluxParser - Class in org.apache.storm.flux.parser
-
Static utility methods for parsing flux YAML.
- FluxShellBolt - Class in org.apache.storm.flux.wrappers.bolts
-
A generic `ShellBolt` implementation that allows you specify output fields and even streams without having to subclass `ShellBolt` to do so.
- FluxShellBolt(String[]) - Constructor for class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
-
Create a ShellBolt with command line arguments.
- FluxShellBolt(String[], String[]) - Constructor for class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
-
Create a ShellBolt with command line arguments and output fields Keep this constructor for backward compatibility.
- FluxShellSpout - Class in org.apache.storm.flux.wrappers.spouts
-
A generic `ShellSpout` implementation that allows you specify output fields and even streams without having to subclass `ShellSpout` to do so.
- FluxShellSpout(String[]) - Constructor for class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
-
Create a ShellSpout with command line arguments.
- FluxShellSpout(String[], String[]) - Constructor for class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
-
Create a ShellSpout with command line arguments and output fields
- FOLLOWERS_DB - Static variable in class org.apache.storm.starter.ReachTopology
- FOLLOWERS_DB - Static variable in class org.apache.storm.starter.trident.TridentReach
- FOLLOWING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FOR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- forceDelete(String) - Static method in class org.apache.storm.utils.Utils
-
Deletes a file or directory and its contents if it exists.
- forceDeleteImpl(String) - Method in class org.apache.storm.utils.Utils
- forceDeleteTopoDistDir(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- forceKill() - Method in class org.apache.storm.daemon.supervisor.Container
- forceKill() - Method in interface org.apache.storm.daemon.supervisor.Killable
-
Kill the processes in this container violently.
- forceKill(String, String) - Method in class org.apache.storm.container.DefaultResourceIsolationManager
- forceKill(String, String) - Method in class org.apache.storm.container.docker.DockerManager
- forceKill(String, String) - Method in class org.apache.storm.container.oci.RuncLibContainerManager
- forceKill(String, String) - Method in interface org.apache.storm.container.ResourceIsolationInterface
-
Kill the given worker forcefully.
- forceKillProcess(String) - Static method in class org.apache.storm.utils.ServerUtils
- forceMkdir(File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Makes a directory, including any necessary but nonexistent parent directories.
- forceMkdir(File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Makes a directory, including any necessary but nonexistent parent directories.
- forceMkdir(Path) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Makes a directory, including any necessary but nonexistent parent directories.
- forceMkdir(Path) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Makes a directory, including any necessary but nonexistent parent directories.
- forDaemon() - Method in class org.apache.storm.utils.NimbusClient.Builder
- forEach(Consumer<? super T>) - Method in class org.apache.storm.streams.Stream
-
Performs an action for each element of this stream.
- ForEachProcessor<T> - Class in org.apache.storm.streams.processors
- ForEachProcessor(Consumer<T>) - Constructor for class org.apache.storm.streams.processors.ForEachProcessor
- FOREIGN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FORMAL_COMMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- format - Variable in class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
- format(TridentTuple) - Method in class org.apache.storm.hdfs.trident.format.DelimitedRecordFormat
- format(TridentTuple) - Method in interface org.apache.storm.hdfs.trident.format.RecordFormat
- format(Tuple) - Method in class org.apache.storm.hdfs.bolt.format.DelimitedRecordFormat
- format(Tuple) - Method in interface org.apache.storm.hdfs.bolt.format.RecordFormat
- format(Tuple) - Method in class org.apache.storm.perf.KafkaClientHdfsTopo.LineWriter
- format(Tuple) - Method in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo.LineWriter
- forPath(PathAndBytesable<String>, String, byte[]) - Static method in class org.apache.storm.trident.topology.state.TransactionalState
- forTopic(String, Func<ConsumerRecord<K, V>, List<Object>>, Fields) - Method in class org.apache.storm.kafka.spout.ByTopicRecordTranslator
-
Configure a translator for a given topic with tuples to be emitted to the default stream.
- forTopic(String, Func<ConsumerRecord<K, V>, List<Object>>, Fields, String) - Method in class org.apache.storm.kafka.spout.ByTopicRecordTranslator
-
Configure a translator for a given topic.
- forTopic(String, RecordTranslator<K, V>) - Method in class org.apache.storm.kafka.spout.ByTopicRecordTranslator
-
Configure a translator for a given kafka topic.
- FORTRAN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- forward(T) - Method in class org.apache.storm.streams.processors.ChainedProcessorContext
- forward(T) - Method in class org.apache.storm.streams.processors.EmittingProcessorContext
- forward(T) - Method in class org.apache.storm.streams.processors.ForwardingProcessorContext
- forward(T) - Method in interface org.apache.storm.streams.processors.ProcessorContext
-
Forwards the input to all downstream processors.
- forward(T, String) - Method in class org.apache.storm.streams.processors.ChainedProcessorContext
- forward(T, String) - Method in class org.apache.storm.streams.processors.EmittingProcessorContext
- forward(T, String) - Method in class org.apache.storm.streams.processors.ForwardingProcessorContext
- forward(T, String) - Method in interface org.apache.storm.streams.processors.ProcessorContext
-
Forwards the input to downstream processors at specified stream.
- ForwardingMetricsConsumer - Class in org.apache.storm.testing
- ForwardingMetricsConsumer() - Constructor for class org.apache.storm.testing.ForwardingMetricsConsumer
- ForwardingProcessorContext<T> - Class in org.apache.storm.streams.processors
-
A context that emits the results to downstream processors which are in the same bolt.
- ForwardingProcessorContext(ProcessorNode, Multimap<String, ProcessorNode>) - Constructor for class org.apache.storm.streams.processors.ForwardingProcessorContext
- FOUND - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FRAC_SECOND - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FRAGMENTED_CPU - Enum constant in enum class org.apache.storm.generated.SupervisorSummary._Fields
- FRAGMENTED_MEM - Enum constant in enum class org.apache.storm.generated.SupervisorSummary._Fields
- FRAME_ROW - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- frameworkClasspath(SimpleVersion) - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- free(WorkerSlot) - Method in class org.apache.storm.scheduler.resource.RasNode
-
Frees a single slot in this node.
- free(WorkerSlot, Cluster, boolean) - Method in class org.apache.storm.scheduler.multitenant.Node
-
Frees a single slot in this node.
- FREE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FREE_NODE_COMPARATOR_DEC - Static variable in class org.apache.storm.scheduler.multitenant.Node
-
Used to sort a list of nodes so the node with the most free slots comes first.
- freeAllSlots() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Free all slots on this node.
- freeAllSlots(Cluster) - Method in class org.apache.storm.scheduler.multitenant.Node
-
Free all slots on this node.
- FREEBSD - Static variable in class org.apache.storm.utils.ShellUtils
- FreePool - Class in org.apache.storm.scheduler.multitenant
-
All of the machines that currently have nothing assigned to them.
- FreePool() - Constructor for class org.apache.storm.scheduler.multitenant.FreePool
- freeSingleExecutor(ExecutorDetails, TopologyDetails) - Method in class org.apache.storm.scheduler.resource.RasNode
-
frees a single executor.
- freeSlot(WorkerSlot) - Method in class org.apache.storm.scheduler.Cluster
-
Free the specified slot.
- freeSlots(Collection<WorkerSlot>) - Method in class org.apache.storm.scheduler.Cluster
-
free the slots.
- freeSlots(Collection<WorkerSlot>) - Method in class org.apache.storm.scheduler.resource.RasNodes
-
Free everything on the given slots.
- freeTopology(String, Cluster) - Method in class org.apache.storm.scheduler.multitenant.Node
-
Frees all the slots for a topology.
- freeWorkerSlotWithBoundAckers(RasNode, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Free the bound-ackers for the given node and workerSlot.
- freezer - Enum constant in enum class org.apache.storm.container.cgroup.SubSystemType
- FREEZER_STATE - Static variable in class org.apache.storm.container.cgroup.core.FreezerCore
- FreezerCore - Class in org.apache.storm.container.cgroup.core
- FreezerCore(String) - Constructor for class org.apache.storm.container.cgroup.core.FreezerCore
- FreezerCore.State - Enum Class in org.apache.storm.container.cgroup.core
- freezing - Enum constant in enum class org.apache.storm.container.cgroup.core.FreezerCore.State
- FreshCollector - Class in org.apache.storm.trident.planner.processor
- FreshCollector(TridentContext) - Constructor for class org.apache.storm.trident.planner.processor.FreshCollector
- FreshOutputFactory(Fields) - Constructor for class org.apache.storm.trident.tuple.TridentTupleView.FreshOutputFactory
- from(Tuple) - Static method in class org.apache.storm.starter.tools.RankableObjectWithFields
-
Construct a new instance based on the provided
Tuple
. - FROM - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FromClause() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses the FROM clause for a SELECT.
- fromComponent - Variable in class org.apache.storm.loadgen.InputStream
- fromCompressedJsonConf(byte[]) - Static method in class org.apache.storm.utils.Utils
- fromConf(File) - Static method in class org.apache.storm.loadgen.TopologyLoadConf
-
Parse the TopologyLoadConf from a file in YAML format.
- fromConf(String) - Static method in enum class org.apache.storm.loadgen.GroupingType
-
Parse a String config value and covert it into the enum.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.loadgen.InputStream
-
Create an output stream from a config.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.loadgen.LoadCompConf
-
Parse the LoadCompConf from a config Map.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.loadgen.NormalDistStats
-
Read the stats from a config.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.loadgen.OutputStream
-
Create an output stream from a config.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.loadgen.SlowExecutorPattern
-
Creates a SlowExecutorPattern from a Map config.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.loadgen.TopologyLoadConf
-
Parse the TopologyLoadConf from a config map.
- fromConf(Map<String, Object>) - Static method in class org.apache.storm.nimbus.NimbusInfo
- fromConf(Map<String, Object>, Double) - Static method in class org.apache.storm.loadgen.NormalDistStats
-
Read the stats from a config.
- fromInt(int) - Static method in enum class org.apache.storm.multilang.ShellMsg.ShellLogLevel
- fromJson(String) - Method in interface org.apache.storm.st.topology.window.data.FromJson
- fromJson(String) - Static method in class org.apache.storm.st.topology.window.data.TimeData
- fromJson(String) - Static method in class org.apache.storm.st.topology.window.data.TimeDataWindow
- FromJson<T> - Interface in org.apache.storm.st.topology.window.data
- fromMap(Map<String, Object>) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutBatchMetadata
-
Constructs a metadata object from a Map in the format produced by
KafkaTridentSpoutBatchMetadata.toMap()
. - fromMap(Map<String, Object>) - Method in class org.apache.storm.kafka.spout.trident.TopicPartitionSerializer
-
Deserializes the given map into a TopicPartition.
- fromString(String) - Static method in class org.apache.storm.loadgen.SlowExecutorPattern
-
Parses a string (command line) representation of "<SLOWNESS>(:<COUNT>)?".
- fromTuple(Tuple) - Static method in class org.apache.storm.st.topology.window.data.TimeData
- frozen - Enum constant in enum class org.apache.storm.container.cgroup.core.FreezerCore.State
- fs - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- fs - Variable in class org.apache.storm.hdfs.trident.HdfsState.Options
- fsUrl - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- fsUrl - Variable in class org.apache.storm.hdfs.trident.HdfsState.Options
- FULL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FULL_CLASS_NAME - Enum constant in enum class org.apache.storm.generated.JavaObject._Fields
- fullCleanup(long) - Method in class org.apache.storm.blobstore.FileBlobStoreImpl
- fullCleanup(long) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- fullCleanup(long) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- fullCleanup(long) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- fullOuterJoin(PairStream<K, V1>) - Method in class org.apache.storm.streams.PairStream
-
Does a full outer join of the values of this stream with the values having the same key from the other stream.
- fullOuterJoin(PairStream<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - Method in class org.apache.storm.streams.PairStream
-
Does a full outer join of the values of this stream with the values having the same key from the other stream.
- func - Variable in class org.apache.storm.StormTimer.QueueEntry
- Func<V,
R> - Interface in org.apache.storm.kafka.spout -
A simple interface to allow compatibility with non java 8 code bases.
- FUNC_ARGS - Enum constant in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
- FUNC_ARGS - Enum constant in enum class org.apache.storm.generated.DRPCRequest._Fields
- Function<T,
R> - Interface in org.apache.storm.streams.operations -
Represents a function that accepts one argument and produces a result.
- Function - Interface in org.apache.storm.trident.operation
-
A function takes in a set of input fields and emits zero or more tuples as output.
- FUNCTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- FUNCTION_KEY - Static variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
- FUNCTION_NAME - Enum constant in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
- FUNCTION_NAME - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args._Fields
- FUNCTION_NAME - Static variable in class org.apache.storm.security.auth.authorizer.DRPCAuthorizerBase
-
A key name for the function requested to be executed by a user.
- functionName() - Method in class org.apache.storm.sql.parser.SqlCreateFunction
- FunctionName() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses the name of a function (either a compound identifier or a reserved word which can be used as a function name).
- FunctionParameterList(SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses function parameter lists including DISTINCT keyword recognition, DEFAULT, and named argument assignment.
- FUSION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- fv(Class, boolean) - Static method in class org.apache.storm.validation.ConfigValidationUtils
-
Returns a new NestableFieldValidator for a given class.
G
- G - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GAIN_LEADERSHIP - Enum constant in enum class org.apache.storm.daemon.nimbus.TopologyActions
- gauge(String, Gauge<T>, String, Integer) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- gauge(String, Gauge<T>, String, String, Integer, Integer) - Method in class org.apache.storm.metrics2.StormMetricRegistry
-
Deprecated.
- gauge(String, Gauge<T>, String, String, String, Integer, Integer) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- gauge(String, Gauge<T>, TopologyContext) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- gauge(T, String, String, String, Integer, Integer) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- GB - Enum constant in enum class org.apache.storm.hdfs.bolt.rotation.FileSizeRotationPolicy.Units
- GB - Enum constant in enum class org.apache.storm.hdfs.trident.rotation.FileSizeRotationPolicy.Units
- GE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GENERAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GeneralTopologyContext - Class in org.apache.storm.task
- GeneralTopologyContext(StormTopology, Map<String, Object>, Map<Integer, String>, Map<String, List<Integer>>, Map<String, Map<String, Fields>>, String) - Constructor for class org.apache.storm.task.GeneralTopologyContext
- GENERATED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- generateDependencyBlobKey(String) - Static method in class org.apache.storm.dependency.DependencyBlobStoreUtils
- generateId(Random) - Static method in class org.apache.storm.tuple.MessageId
- generateParseException() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Generate ParseException.
- generateSecret() - Method in class org.apache.storm.security.auth.workertoken.WorkerTokenManager
-
Generate a new random secret key.
- generateSupervisorId() - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
- generateTriggerKey() - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor.TriggerInfo
- generateWindowTriggerKey(String, int) - Static method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- GENERIC_RAS - Enum constant in enum class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.NodeSortType
-
Deprecated.used by GenericResourceAwareStrategyOld only. Use {link #COMMON} instead.
- GenericAvroSerializer - Class in org.apache.storm.hdfs.avro
-
A default implementation of the AvroSerializer that will just pass literal schemas back and forth.
- GenericAvroSerializer() - Constructor for class org.apache.storm.hdfs.avro.GenericAvroSerializer
- GenericBolt - Class in org.apache.storm.jms.example
-
A generic
org.apache.storm.topology.IRichBolt
implementation for testing/debugging the Storm JMS Spout and example topologies. - GenericBolt(String, boolean, boolean) - Constructor for class org.apache.storm.jms.example.GenericBolt
- GenericBolt(String, boolean, boolean, Fields) - Constructor for class org.apache.storm.jms.example.GenericBolt
-
Constructs a new
GenericBolt
instance. - GenericResourceAwareSchedulingPriorityStrategy - Class in org.apache.storm.scheduler.resource.strategies.priority
- GenericResourceAwareSchedulingPriorityStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy
- GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser - Class in org.apache.storm.scheduler.resource.strategies.priority
- GenericResourceAwareStrategy - Class in org.apache.storm.scheduler.resource.strategies.scheduling
- GenericResourceAwareStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.GenericResourceAwareStrategy
- GenericResourceAwareStrategyOld - Class in org.apache.storm.scheduler.resource.strategies.scheduling
- GenericResourceAwareStrategyOld() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.GenericResourceAwareStrategyOld
- GenLoad - Class in org.apache.storm.loadgen
-
Generate a simulated load.
- GenLoad() - Constructor for class org.apache.storm.loadgen.GenLoad
- GEO - Enum constant in enum class org.apache.storm.redis.common.mapper.RedisDataTypeDescription.RedisDataType
- geoadd(String, double, double, String) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- geoadd(String, double, double, String) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- geoadd(String, double, double, String) - Method in class org.apache.storm.redis.common.container.JedisContainer
- GEOMETRY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- geopos(String, String...) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- geopos(String, String...) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- geopos(String, String...) - Method in class org.apache.storm.redis.common.container.JedisContainer
- get() - Method in class org.apache.storm.scheduler.utils.SchedulerConfigCache
-
Get the scheduler config from cache.
- get() - Method in class org.apache.storm.trident.state.map.SnapshottableMap
- get() - Method in interface org.apache.storm.trident.state.snapshot.ReadOnlySnapshottable
- get() - Method in class org.apache.storm.trident.testing.LRUMemoryMapState
- get() - Method in class org.apache.storm.trident.testing.MemoryMapState
- get() - Method in class org.apache.storm.utils.MutableInt
- get() - Method in class org.apache.storm.utils.MutableLong
- get() - Method in interface org.apache.storm.windowing.Event
-
Returns the wrapped object, E.g.
- get() - Method in class org.apache.storm.windowing.EventImpl
- get() - Method in class org.apache.storm.windowing.TupleWindowImpl
- get() - Method in class org.apache.storm.windowing.TupleWindowIterImpl
- get() - Method in interface org.apache.storm.windowing.Window
-
Gets the list of events in the window.
- get(int) - Method in class org.apache.storm.grouping.LoadMapping
- get(int) - Method in class org.apache.storm.trident.tuple.ComboList
- get(int) - Method in class org.apache.storm.trident.tuple.ConsList
- get(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- get(int) - Method in class org.apache.storm.tuple.Fields
-
Gets the field at position index in the collection.
- get(int) - Method in class org.apache.storm.utils.ListDelegate
- get(Long) - Method in class org.apache.storm.trident.state.OpaqueValue
- get(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- get(Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
- get(String) - Method in interface org.apache.storm.metricstore.rocksdb.ReadOnlyStringMetadataCache
-
Get the string metadata from the cache.
- get(String) - Method in class org.apache.storm.metricstore.rocksdb.StringMetadataCache
-
Get the string metadata from the cache.
- get(String) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- get(String) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- get(String) - Method in class org.apache.storm.redis.common.container.JedisContainer
- get(String) - Method in class org.apache.storm.sql.runtime.calcite.StormDataContext
- get(String) - Method in class org.apache.storm.trident.windowing.InMemoryWindowsStore
- get(String) - Method in interface org.apache.storm.trident.windowing.WindowsStore
- get(String) - Method in class org.apache.storm.utils.LocalState
- get(String, HttpServletRequest) - Method in class org.apache.storm.daemon.drpc.webapp.DRPCResource
- get(String, String, HttpServletRequest) - Method in class org.apache.storm.daemon.drpc.webapp.DRPCResource
- get(List<String>) - Method in class org.apache.storm.trident.windowing.InMemoryWindowsStore
- get(List<String>) - Method in interface org.apache.storm.trident.windowing.WindowsStore
- get(Map<String, Object>, String, String) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Pull a the value given section and key from Configuration.
- get(Map<S, T>, S, T) - Static method in class org.apache.storm.utils.Utils
- get(K) - Method in class org.apache.storm.redis.state.RedisKeyValueState
- get(K) - Method in class org.apache.storm.state.InMemoryKeyValueState
- get(K) - Method in interface org.apache.storm.state.KeyValueState
-
Returns the value mapped to the key.
- get(K) - Method in class org.apache.storm.utils.RotatingMap
- get(K) - Method in class org.apache.storm.utils.TimeCacheMap
-
Deprecated.
- get(K) - Method in class org.apache.storm.windowing.persistence.SimpleWindowPartitionCache
- get(K) - Method in interface org.apache.storm.windowing.persistence.WindowPartitionCache
-
Get value from the cache or load the value.
- get(K, V) - Method in class org.apache.storm.redis.state.RedisKeyValueState
- get(K, V) - Method in class org.apache.storm.state.InMemoryKeyValueState
- get(K, V) - Method in interface org.apache.storm.state.KeyValueState
-
Returns the value mapped to the key or defaultValue if no mapping is found.
- get(ThriftConnectionType) - Method in class org.apache.storm.security.auth.MultiThriftServer
- GET - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- get_access() - Method in class org.apache.storm.generated.AccessControl
- get_acked() - Method in class org.apache.storm.generated.BoltStats
- get_acked() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_acked() - Method in class org.apache.storm.generated.SpoutStats
- get_acked_size() - Method in class org.apache.storm.generated.BoltStats
- get_acked_size() - Method in class org.apache.storm.generated.SpoutStats
- get_acl() - Method in class org.apache.storm.generated.SettableBlobMeta
- get_acl_iterator() - Method in class org.apache.storm.generated.SettableBlobMeta
- get_acl_size() - Method in class org.apache.storm.generated.SettableBlobMeta
- get_action() - Method in class org.apache.storm.generated.LogLevel
- get_action() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- get_action() - Method in class org.apache.storm.generated.ProfileRequest
- get_all() - Method in class org.apache.storm.generated.Grouping
- GET_ALL_NODES_FOR_PATH - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- GET_ALL_NODES_FOR_PATH_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- GET_ALL_PULSE_FOR_PATH - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- GET_ALL_PULSE_FOR_PATH_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- get_approved_workers() - Method in class org.apache.storm.generated.LSApprovedWorkers
- get_approved_workers_size() - Method in class org.apache.storm.generated.LSApprovedWorkers
- get_args_list() - Method in class org.apache.storm.generated.JavaObject
- get_args_list_iterator() - Method in class org.apache.storm.generated.JavaObject
- get_args_list_size() - Method in class org.apache.storm.generated.JavaObject
- get_assigned_cpu() - Method in class org.apache.storm.generated.TopologyInfo
- get_assigned_cpu() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_cpu() - Method in class org.apache.storm.generated.TopologySummary
- get_assigned_cpu() - Method in class org.apache.storm.generated.WorkerSummary
- get_assigned_generic_resources() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_generic_resources() - Method in class org.apache.storm.generated.TopologySummary
- get_assigned_generic_resources_size() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_generic_resources_size() - Method in class org.apache.storm.generated.TopologySummary
- get_assigned_memoffheap() - Method in class org.apache.storm.generated.TopologyInfo
- get_assigned_memoffheap() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_memoffheap() - Method in class org.apache.storm.generated.TopologySummary
- get_assigned_memoffheap() - Method in class org.apache.storm.generated.WorkerSummary
- get_assigned_memonheap() - Method in class org.apache.storm.generated.TopologyInfo
- get_assigned_memonheap() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_memonheap() - Method in class org.apache.storm.generated.TopologySummary
- get_assigned_memonheap() - Method in class org.apache.storm.generated.WorkerSummary
- get_assigned_off_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_assigned_on_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_assigned_regular_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_regular_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_shared_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assigned_shared_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_assignment_id() - Method in class org.apache.storm.generated.SupervisorInfo
- get_assignments() - Method in class org.apache.storm.generated.LSSupervisorAssignments
- get_assignments() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- get_assignments_size() - Method in class org.apache.storm.generated.LSSupervisorAssignments
- get_aze() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- get_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- get_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- get_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- get_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.activate_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.debug_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- get_aze() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- get_aze() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- get_aze() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- get_aze() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- get_binary_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- get_bits() - Method in class org.apache.storm.generated.ThriftSerializedObject
- get_blobKey() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- get_bolt() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- get_bolt() - Method in class org.apache.storm.generated.SpecificAggregateStats
- get_bolt_object() - Method in class org.apache.storm.generated.Bolt
- get_bolts() - Method in class org.apache.storm.generated.StormTopology
- get_bolts_size() - Method in class org.apache.storm.generated.StormTopology
- get_bool_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- get_boolval() - Method in class org.apache.storm.generated.HBMessageData
- get_capacity() - Method in class org.apache.storm.generated.BoltAggregateStats
- get_children(String, boolean) - Method in interface org.apache.storm.cluster.IStateStorage
-
Get a list of paths of all the child nodes which exist immediately under path.
- get_children(String, boolean) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- get_children(String, boolean) - Method in class org.apache.storm.cluster.ZKStateStorage
- get_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- get_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- get_common() - Method in class org.apache.storm.generated.Bolt
- get_common() - Method in class org.apache.storm.generated.SpoutSpec
- get_common() - Method in class org.apache.storm.generated.StateSpoutSpec
- get_common_stats() - Method in class org.apache.storm.generated.ComponentAggregateStats
- get_complete_latency_ms() - Method in class org.apache.storm.generated.SpoutAggregateStats
- get_complete_ms_avg() - Method in class org.apache.storm.generated.SpoutStats
- get_complete_ms_avg_size() - Method in class org.apache.storm.generated.SpoutStats
- get_component() - Method in class org.apache.storm.generated.Nimbus.debug_args
- get_component_debug() - Method in class org.apache.storm.generated.StormBase
- get_component_debug() - Method in class org.apache.storm.generated.TopologyInfo
- get_component_debug_size() - Method in class org.apache.storm.generated.StormBase
- get_component_debug_size() - Method in class org.apache.storm.generated.TopologyInfo
- get_component_executors() - Method in class org.apache.storm.generated.StormBase
- get_component_executors_size() - Method in class org.apache.storm.generated.StormBase
- get_component_id() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_component_id() - Method in class org.apache.storm.generated.ExecutorSummary
- get_component_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- get_component_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- get_component_to_num_tasks() - Method in class org.apache.storm.generated.WorkerSummary
- get_component_to_num_tasks_size() - Method in class org.apache.storm.generated.WorkerSummary
- get_component_to_shared_memory() - Method in class org.apache.storm.generated.StormTopology
- get_component_to_shared_memory_size() - Method in class org.apache.storm.generated.StormTopology
- get_component_type() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_componentId() - Method in class org.apache.storm.generated.GlobalStreamId
- get_componentId() - Method in class org.apache.storm.generated.WorkerMetricPoint
- get_config() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- get_cpu() - Method in class org.apache.storm.generated.WorkerResources
- get_cpu_guarantee() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_cpu_guarantee_remaining() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_cpu_usage() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_creds() - Method in class org.apache.storm.generated.Credentials
- get_creds() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- get_creds() - Method in class org.apache.storm.generated.SubmitOptions
- get_creds_size() - Method in class org.apache.storm.generated.Credentials
- get_custom_object() - Method in class org.apache.storm.generated.Grouping
- get_custom_serialized() - Method in class org.apache.storm.generated.Grouping
- get_data() - Method in class org.apache.storm.generated.HBMessage
- get_data(String, boolean) - Method in interface org.apache.storm.cluster.IStateStorage
-
Get the data from the node at path
- get_data(String, boolean) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- get_data(String, boolean) - Method in class org.apache.storm.cluster.ZKStateStorage
- get_data_size() - Method in class org.apache.storm.generated.BeginDownloadResult
- get_data_with_version(String, boolean) - Method in interface org.apache.storm.cluster.IStateStorage
-
Get the data at the node along with its version.
- get_data_with_version(String, boolean) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- get_data_with_version(String, boolean) - Method in class org.apache.storm.cluster.ZKStateStorage
- get_debug_options() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_debug_options() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_dependency_artifacts() - Method in class org.apache.storm.generated.StormTopology
- get_dependency_artifacts_iterator() - Method in class org.apache.storm.generated.StormTopology
- get_dependency_artifacts_size() - Method in class org.apache.storm.generated.StormTopology
- get_dependency_jars() - Method in class org.apache.storm.generated.StormTopology
- get_dependency_jars_iterator() - Method in class org.apache.storm.generated.StormTopology
- get_dependency_jars_size() - Method in class org.apache.storm.generated.StormTopology
- get_details() - Method in class org.apache.storm.generated.HBPulse
- get_direct() - Method in class org.apache.storm.generated.Grouping
- get_double_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- get_e() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- get_e() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- get_e() - Method in class org.apache.storm.generated.Nimbus.activate_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.debug_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- get_e() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- get_e() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- get_emitted() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_emitted() - Method in class org.apache.storm.generated.ExecutorStats
- get_emitted_size() - Method in class org.apache.storm.generated.ExecutorStats
- get_error() - Method in class org.apache.storm.generated.ErrorInfo
- get_error_time_secs() - Method in class org.apache.storm.generated.ErrorInfo
- get_errors() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_errors() - Method in class org.apache.storm.generated.TopologyInfo
- get_errors_iterator() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_errors_size() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_errors_size() - Method in class org.apache.storm.generated.TopologyInfo
- get_eventlog_host() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_eventlog_port() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_exec_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_exec_stats_iterator() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_exec_stats_size() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_exec_summary() - Method in class org.apache.storm.generated.ExecutorAggregateStats
- get_execute_latency_ms() - Method in class org.apache.storm.generated.BoltAggregateStats
- get_execute_ms_avg() - Method in class org.apache.storm.generated.BoltStats
- get_execute_ms_avg_size() - Method in class org.apache.storm.generated.BoltStats
- get_executed() - Method in class org.apache.storm.generated.BoltAggregateStats
- get_executed() - Method in class org.apache.storm.generated.BoltStats
- get_executed_size() - Method in class org.apache.storm.generated.BoltStats
- get_execution_command() - Method in class org.apache.storm.generated.ShellComponent
- get_executor_info() - Method in class org.apache.storm.generated.ExecutorSummary
- get_executor_node_port() - Method in class org.apache.storm.generated.Assignment
- get_executor_node_port_size() - Method in class org.apache.storm.generated.Assignment
- get_executor_start_time_secs() - Method in class org.apache.storm.generated.Assignment
- get_executor_start_time_secs_size() - Method in class org.apache.storm.generated.Assignment
- get_executor_stats() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- get_executor_stats_size() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- get_executorId() - Method in class org.apache.storm.generated.WorkerMetricPoint
- get_executors() - Method in class org.apache.storm.generated.LocalAssignment
- get_executors() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- get_executors() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- get_executors() - Method in class org.apache.storm.generated.TopologyInfo
- get_executors_iterator() - Method in class org.apache.storm.generated.LocalAssignment
- get_executors_iterator() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- get_executors_iterator() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- get_executors_iterator() - Method in class org.apache.storm.generated.TopologyInfo
- get_executors_size() - Method in class org.apache.storm.generated.LocalAssignment
- get_executors_size() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- get_executors_size() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- get_executors_size() - Method in class org.apache.storm.generated.TopologyInfo
- get_expirationTimeMillis() - Method in class org.apache.storm.generated.PrivateWorkerKey
- get_expirationTimeMillis() - Method in class org.apache.storm.generated.WorkerTokenInfo
- get_failed() - Method in class org.apache.storm.generated.BoltStats
- get_failed() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_failed() - Method in class org.apache.storm.generated.SpoutStats
- get_failed_size() - Method in class org.apache.storm.generated.BoltStats
- get_failed_size() - Method in class org.apache.storm.generated.SpoutStats
- get_fields() - Method in class org.apache.storm.generated.Grouping
- get_fragmented_cpu() - Method in class org.apache.storm.generated.SupervisorSummary
- get_fragmented_mem() - Method in class org.apache.storm.generated.SupervisorSummary
- get_full_class_name() - Method in class org.apache.storm.generated.JavaObject
- get_func_args() - Method in class org.apache.storm.generated.DRPCRequest
- get_funcArgs() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- get_function() - Method in class org.apache.storm.drpc.DRPCSpout
- get_functionName() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- get_functionName() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- get_groups() - Method in class org.apache.storm.generated.LSTopoHistory
- get_groups_iterator() - Method in class org.apache.storm.generated.LSTopoHistory
- get_groups_size() - Method in class org.apache.storm.generated.LSTopoHistory
- get_gsid_to_input_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_gsid_to_input_stats_size() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_heartbeat() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- get_heartbeats() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- get_heatbeat() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- get_host() - Method in class org.apache.storm.generated.ErrorInfo
- get_host() - Method in class org.apache.storm.generated.ExecutorSummary
- get_host() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- get_host() - Method in class org.apache.storm.generated.NimbusSummary
- get_host() - Method in class org.apache.storm.generated.SupervisorSummary
- get_host() - Method in class org.apache.storm.generated.WorkerSummary
- get_hostname() - Method in class org.apache.storm.generated.SupervisorInfo
- get_hostname() - Method in class org.apache.storm.generated.WorkerMetrics
- get_id() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- get_id() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- get_id() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- get_id() - Method in class org.apache.storm.generated.HBPulse
- get_id() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- get_id() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- get_id() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- get_id() - Method in class org.apache.storm.generated.TopologyInfo
- get_id() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_id() - Method in class org.apache.storm.generated.TopologySummary
- get_id_to_bolt_agg_stats() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_id_to_bolt_agg_stats_size() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_id_to_spout_agg_stats() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_id_to_spout_agg_stats_size() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_info() - Method in class org.apache.storm.generated.WorkerToken
- get_initial_status() - Method in class org.apache.storm.generated.SubmitOptions
- get_inputs() - Method in class org.apache.storm.generated.ComponentCommon
- get_inputs_size() - Method in class org.apache.storm.generated.ComponentCommon
- get_int_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- get_ise() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- get_isolated_node_guarantee() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_ite() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- get_ite() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- get_ite() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- get_ite() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- get_java_object() - Method in class org.apache.storm.generated.ComponentObject
- get_jdk_version() - Method in class org.apache.storm.generated.StormTopology
- get_json_conf() - Method in class org.apache.storm.generated.ComponentCommon
- get_jsonConf() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- get_jsonConf() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- get_kae() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- get_key() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- get_key() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- get_key() - Method in class org.apache.storm.generated.PrivateWorkerKey
- get_keys() - Method in class org.apache.storm.generated.ListBlobsResult
- get_keys_iterator() - Method in class org.apache.storm.generated.ListBlobsResult
- get_keys_size() - Method in class org.apache.storm.generated.ListBlobsResult
- get_kill_options() - Method in class org.apache.storm.generated.TopologyActionOptions
- get_knf() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- get_knf() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- get_knf() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- get_knf() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- get_knf() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- get_knf() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- get_knf() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- get_last_error() - Method in class org.apache.storm.generated.ComponentAggregateStats
- get_launch_time_secs() - Method in class org.apache.storm.generated.StormBase
- get_local_or_shuffle() - Method in class org.apache.storm.generated.Grouping
- get_location() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- get_location() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- get_long_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- get_master_code_dir() - Method in class org.apache.storm.generated.Assignment
- get_mem_off_heap() - Method in class org.apache.storm.generated.WorkerResources
- get_mem_on_heap() - Method in class org.apache.storm.generated.WorkerResources
- get_memory_guarantee() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_memory_guarantee_remaining() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_memory_usage() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_message_blob() - Method in class org.apache.storm.generated.HBMessageData
- get_message_id() - Method in class org.apache.storm.generated.HBMessage
- get_meta() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- get_meta() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- get_meta() - Method in class org.apache.storm.generated.SupervisorInfo
- get_meta_iterator() - Method in class org.apache.storm.generated.SupervisorInfo
- get_meta_size() - Method in class org.apache.storm.generated.SupervisorInfo
- get_metricList() - Method in class org.apache.storm.generated.WorkerMetrics
- get_metricName() - Method in class org.apache.storm.generated.WorkerMetricPoint
- get_metrics() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- get_metrics() - Method in class org.apache.storm.generated.WorkerMetricList
- get_metrics_iterator() - Method in class org.apache.storm.generated.WorkerMetricList
- get_metrics_size() - Method in class org.apache.storm.generated.WorkerMetricList
- get_metricValue() - Method in class org.apache.storm.generated.WorkerMetricPoint
- get_msg() - Method in exception org.apache.storm.generated.AlreadyAliveException
- get_msg() - Method in exception org.apache.storm.generated.AuthorizationException
- get_msg() - Method in exception org.apache.storm.generated.DRPCExecutionException
- get_msg() - Method in exception org.apache.storm.generated.HBAuthorizationException
- get_msg() - Method in exception org.apache.storm.generated.HBExecutionException
- get_msg() - Method in exception org.apache.storm.generated.IllegalStateException
- get_msg() - Method in exception org.apache.storm.generated.InvalidTopologyException
- get_msg() - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- get_msg() - Method in exception org.apache.storm.generated.KeyNotFoundException
- get_msg() - Method in exception org.apache.storm.generated.NotAliveException
- get_name() - Method in class org.apache.storm.generated.AccessControl
- get_name() - Method in class org.apache.storm.generated.Nimbus.activate_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.debug_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- get_name() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- get_name() - Method in class org.apache.storm.generated.SharedMemory
- get_name() - Method in class org.apache.storm.generated.StormBase
- get_name() - Method in class org.apache.storm.generated.ThriftSerializedObject
- get_name() - Method in class org.apache.storm.generated.TopologyInfo
- get_name() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_name() - Method in class org.apache.storm.generated.TopologySummary
- get_named_logger_level() - Method in class org.apache.storm.generated.LogConfig
- get_named_logger_level_size() - Method in class org.apache.storm.generated.LogConfig
- get_nimbuses() - Method in class org.apache.storm.generated.ClusterSummary
- get_nimbuses_iterator() - Method in class org.apache.storm.generated.ClusterSummary
- get_nimbuses_size() - Method in class org.apache.storm.generated.ClusterSummary
- get_node() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- get_node() - Method in class org.apache.storm.generated.NodeInfo
- get_node_host() - Method in class org.apache.storm.generated.Assignment
- get_node_host_size() - Method in class org.apache.storm.generated.Assignment
- get_nodeInfo() - Method in class org.apache.storm.generated.ProfileRequest
- get_nodes() - Method in class org.apache.storm.generated.HBMessageData
- get_none() - Method in class org.apache.storm.generated.Grouping
- get_num_err_choice() - Method in class org.apache.storm.generated.GetInfoOptions
- get_num_executors() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_num_executors() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_num_executors() - Method in class org.apache.storm.generated.RebalanceOptions
- get_num_executors() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_num_executors() - Method in class org.apache.storm.generated.TopologySummary
- get_num_executors() - Method in class org.apache.storm.generated.WorkerSummary
- get_num_executors_size() - Method in class org.apache.storm.generated.RebalanceOptions
- get_num_tasks() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_num_tasks() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_num_tasks() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_num_tasks() - Method in class org.apache.storm.generated.TopologySummary
- get_num_used_workers() - Method in class org.apache.storm.generated.SupervisorSummary
- get_num_workers() - Method in class org.apache.storm.generated.RebalanceOptions
- get_num_workers() - Method in class org.apache.storm.generated.StormBase
- get_num_workers() - Method in class org.apache.storm.generated.SupervisorSummary
- get_num_workers() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_num_workers() - Method in class org.apache.storm.generated.TopologySummary
- get_off_heap_node() - Method in class org.apache.storm.generated.SharedMemory
- get_off_heap_worker() - Method in class org.apache.storm.generated.SharedMemory
- get_on_heap() - Method in class org.apache.storm.generated.SharedMemory
- get_options() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- get_options() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- get_options() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- get_options() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- get_options() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- get_output_fields() - Method in class org.apache.storm.generated.StreamInfo
- get_output_fields_iterator() - Method in class org.apache.storm.generated.StreamInfo
- get_output_fields_size() - Method in class org.apache.storm.generated.StreamInfo
- get_owner() - Method in class org.apache.storm.generated.Assignment
- get_owner() - Method in class org.apache.storm.generated.LocalAssignment
- get_owner() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- get_owner() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_owner() - Method in class org.apache.storm.generated.StormBase
- get_owner() - Method in class org.apache.storm.generated.TopologyInfo
- get_owner() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_owner() - Method in class org.apache.storm.generated.TopologySummary
- get_owner() - Method in class org.apache.storm.generated.WorkerSummary
- get_parallelism_hint() - Method in class org.apache.storm.generated.ComponentCommon
- get_path() - Method in class org.apache.storm.generated.HBMessageData
- get_port() - Method in class org.apache.storm.generated.ErrorInfo
- get_port() - Method in class org.apache.storm.generated.ExecutorSummary
- get_port() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- get_port() - Method in class org.apache.storm.generated.NimbusSummary
- get_port() - Method in class org.apache.storm.generated.NodeInfo
- get_port() - Method in class org.apache.storm.generated.WorkerMetrics
- get_port() - Method in class org.apache.storm.generated.WorkerSummary
- get_port_iterator() - Method in class org.apache.storm.generated.NodeInfo
- get_port_size() - Method in class org.apache.storm.generated.NodeInfo
- get_prev_status() - Method in class org.apache.storm.generated.StormBase
- get_principal() - Method in class org.apache.storm.generated.RebalanceOptions
- get_principal() - Method in class org.apache.storm.generated.StormBase
- get_process_latency_ms() - Method in class org.apache.storm.generated.BoltAggregateStats
- get_process_ms_avg() - Method in class org.apache.storm.generated.BoltStats
- get_process_ms_avg_size() - Method in class org.apache.storm.generated.BoltStats
- get_profileRequest() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- get_pulse() - Method in class org.apache.storm.generated.HBMessageData
- GET_PULSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- GET_PULSE_RESPONSE - Enum constant in enum class org.apache.storm.generated.HBServerMessageType
- get_pulseIds() - Method in class org.apache.storm.generated.HBNodes
- get_pulseIds_iterator() - Method in class org.apache.storm.generated.HBNodes
- get_pulseIds_size() - Method in class org.apache.storm.generated.HBNodes
- get_pulses() - Method in class org.apache.storm.generated.HBRecords
- get_pulses_iterator() - Method in class org.apache.storm.generated.HBRecords
- get_pulses_size() - Method in class org.apache.storm.generated.HBRecords
- get_rate() - Method in class org.apache.storm.generated.ExecutorStats
- get_rebalance_options() - Method in class org.apache.storm.generated.TopologyActionOptions
- get_records() - Method in class org.apache.storm.generated.HBMessageData
- get_replication() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- get_replication_count() - Method in class org.apache.storm.generated.TopologyInfo
- get_replication_count() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_replication_count() - Method in class org.apache.storm.generated.TopologySummary
- get_replication_factor() - Method in class org.apache.storm.generated.SettableBlobMeta
- get_request_id() - Method in class org.apache.storm.generated.DRPCRequest
- get_requested_cpu() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_requested_cpu() - Method in class org.apache.storm.generated.TopologyInfo
- get_requested_cpu() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_cpu() - Method in class org.apache.storm.generated.TopologySummary
- get_requested_cpu() - Method in class org.apache.storm.generated.WorkerSummary
- get_requested_generic_resources() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_generic_resources() - Method in class org.apache.storm.generated.TopologySummary
- get_requested_generic_resources_size() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_generic_resources_size() - Method in class org.apache.storm.generated.TopologySummary
- get_requested_memoffheap() - Method in class org.apache.storm.generated.TopologyInfo
- get_requested_memoffheap() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_memoffheap() - Method in class org.apache.storm.generated.TopologySummary
- get_requested_memoffheap() - Method in class org.apache.storm.generated.WorkerSummary
- get_requested_memonheap() - Method in class org.apache.storm.generated.TopologyInfo
- get_requested_memonheap() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_memonheap() - Method in class org.apache.storm.generated.TopologySummary
- get_requested_memonheap() - Method in class org.apache.storm.generated.WorkerSummary
- get_requested_off_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_requested_on_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_requested_regular_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_regular_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_shared_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_shared_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_requested_total_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_reset_log_level() - Method in class org.apache.storm.generated.LogLevel
- get_reset_log_level_timeout_epoch() - Method in class org.apache.storm.generated.LogLevel
- get_reset_log_level_timeout_secs() - Method in class org.apache.storm.generated.LogLevel
- get_resources() - Method in class org.apache.storm.generated.LocalAssignment
- get_resources() - Method in class org.apache.storm.generated.WorkerResources
- get_resources_map() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_resources_map() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_resources_map() - Method in class org.apache.storm.generated.SupervisorInfo
- get_resources_map_size() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_resources_map_size() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_resources_map_size() - Method in class org.apache.storm.generated.SupervisorInfo
- get_resources_size() - Method in class org.apache.storm.generated.WorkerResources
- get_result() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- get_samplingpct() - Method in class org.apache.storm.generated.DebugOptions
- get_samplingPercentage() - Method in class org.apache.storm.generated.Nimbus.debug_args
- get_sched_status() - Method in class org.apache.storm.generated.TopologyInfo
- get_sched_status() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_sched_status() - Method in class org.apache.storm.generated.TopologySummary
- get_scheduler_meta() - Method in class org.apache.storm.generated.SupervisorInfo
- get_scheduler_meta_size() - Method in class org.apache.storm.generated.SupervisorInfo
- get_script() - Method in class org.apache.storm.generated.ShellComponent
- get_secretVersion() - Method in class org.apache.storm.generated.WorkerTokenInfo
- get_serialized_java() - Method in class org.apache.storm.generated.ComponentObject
- get_serialized_parts() - Method in class org.apache.storm.generated.LocalStateData
- get_serialized_parts_size() - Method in class org.apache.storm.generated.LocalStateData
- get_server_port() - Method in class org.apache.storm.generated.SupervisorInfo
- get_serviceType() - Method in class org.apache.storm.generated.WorkerToken
- get_session() - Method in class org.apache.storm.generated.BeginDownloadResult
- get_session() - Method in class org.apache.storm.generated.ListBlobsResult
- get_session() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- get_session() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- get_session() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- get_session() - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- get_session() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- get_settable() - Method in class org.apache.storm.generated.ReadableBlobMeta
- get_shared_mem_off_heap() - Method in class org.apache.storm.generated.WorkerResources
- get_shared_mem_on_heap() - Method in class org.apache.storm.generated.WorkerResources
- get_shared_memory() - Method in class org.apache.storm.generated.StormTopology
- get_shared_memory_size() - Method in class org.apache.storm.generated.StormTopology
- get_shared_resources() - Method in class org.apache.storm.generated.WorkerResources
- get_shared_resources_size() - Method in class org.apache.storm.generated.WorkerResources
- get_shell() - Method in class org.apache.storm.generated.ComponentObject
- get_shuffle() - Method in class org.apache.storm.generated.Grouping
- get_sid_to_output_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_sid_to_output_stats_size() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_signature() - Method in class org.apache.storm.generated.WorkerToken
- get_specific() - Method in class org.apache.storm.generated.ExecutorStats
- get_specific_stats() - Method in class org.apache.storm.generated.ComponentAggregateStats
- get_spout() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- get_spout() - Method in class org.apache.storm.generated.SpecificAggregateStats
- get_spout_object() - Method in class org.apache.storm.generated.SpoutSpec
- get_spouts() - Method in class org.apache.storm.generated.StormTopology
- get_spouts_size() - Method in class org.apache.storm.generated.StormTopology
- get_state_spout_object() - Method in class org.apache.storm.generated.StateSpoutSpec
- get_state_spouts() - Method in class org.apache.storm.generated.StormTopology
- get_state_spouts_size() - Method in class org.apache.storm.generated.StormTopology
- get_stats() - Method in class org.apache.storm.generated.ExecutorAggregateStats
- get_stats() - Method in class org.apache.storm.generated.ExecutorSummary
- get_status() - Method in class org.apache.storm.generated.StormBase
- get_status() - Method in class org.apache.storm.generated.TopologyInfo
- get_status() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_status() - Method in class org.apache.storm.generated.TopologySummary
- get_storm_assignment() - Method in class org.apache.storm.generated.SupervisorAssignments
- get_storm_assignment_size() - Method in class org.apache.storm.generated.SupervisorAssignments
- get_storm_id() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- get_storm_id() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- get_storm_version() - Method in class org.apache.storm.generated.StormTopology
- get_storm_version() - Method in class org.apache.storm.generated.TopologyInfo
- get_storm_version() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_storm_version() - Method in class org.apache.storm.generated.TopologySummary
- get_streamId() - Method in class org.apache.storm.generated.GlobalStreamId
- get_streamId() - Method in class org.apache.storm.generated.WorkerMetricPoint
- get_streams() - Method in class org.apache.storm.generated.ComponentCommon
- get_streams_size() - Method in class org.apache.storm.generated.ComponentCommon
- get_string_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- get_success() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- get_success() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- get_success() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- get_success() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- get_success_iterator() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- get_success_iterator() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- get_success_iterator() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- get_success_size() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- get_success_size() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- get_success_size() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- get_supervisor_id() - Method in class org.apache.storm.generated.LSSupervisorId
- get_supervisor_id() - Method in class org.apache.storm.generated.SupervisorSummary
- get_supervisor_id() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- get_supervisor_id() - Method in class org.apache.storm.generated.WorkerSummary
- get_supervisor_summaries() - Method in class org.apache.storm.generated.SupervisorPageInfo
- get_supervisor_summaries_iterator() - Method in class org.apache.storm.generated.SupervisorPageInfo
- get_supervisor_summaries_size() - Method in class org.apache.storm.generated.SupervisorPageInfo
- get_supervisors() - Method in class org.apache.storm.generated.ClusterSummary
- get_supervisors_iterator() - Method in class org.apache.storm.generated.ClusterSummary
- get_supervisors_size() - Method in class org.apache.storm.generated.ClusterSummary
- get_target_log_level() - Method in class org.apache.storm.generated.LogLevel
- get_task_end() - Method in class org.apache.storm.generated.ExecutorInfo
- get_task_start() - Method in class org.apache.storm.generated.ExecutorInfo
- get_time_secs() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- get_time_secs() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- get_time_secs() - Method in class org.apache.storm.generated.SupervisorInfo
- get_time_secs() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- get_time_secs() - Method in class org.apache.storm.generated.WorkerSummary
- get_time_stamp() - Method in class org.apache.storm.generated.LSTopoHistory
- get_time_stamp() - Method in class org.apache.storm.generated.ProfileRequest
- get_timestamp() - Method in class org.apache.storm.generated.WorkerMetricPoint
- get_tlsPort() - Method in class org.apache.storm.generated.NimbusSummary
- get_topo_history() - Method in class org.apache.storm.generated.LSTopoHistoryList
- get_topo_history_iterator() - Method in class org.apache.storm.generated.LSTopoHistoryList
- get_topo_history_size() - Method in class org.apache.storm.generated.LSTopoHistoryList
- get_topo_ids() - Method in class org.apache.storm.generated.TopologyHistoryInfo
- get_topo_ids_iterator() - Method in class org.apache.storm.generated.TopologyHistoryInfo
- get_topo_ids_size() - Method in class org.apache.storm.generated.TopologyHistoryInfo
- get_topologies() - Method in class org.apache.storm.generated.ClusterSummary
- get_topologies_iterator() - Method in class org.apache.storm.generated.ClusterSummary
- get_topologies_size() - Method in class org.apache.storm.generated.ClusterSummary
- get_topology() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- get_topology() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- get_topology_action_options() - Method in class org.apache.storm.generated.StormBase
- get_topology_conf() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_topology_conf_overrides() - Method in class org.apache.storm.generated.RebalanceOptions
- get_topology_id() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_topology_id() - Method in class org.apache.storm.generated.LocalAssignment
- get_topology_id() - Method in class org.apache.storm.generated.LSTopoHistory
- get_topology_id() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- get_topology_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- get_topology_id() - Method in class org.apache.storm.generated.WorkerSummary
- get_topology_name() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_topology_name() - Method in class org.apache.storm.generated.WorkerSummary
- get_topology_resources_overrides() - Method in class org.apache.storm.generated.RebalanceOptions
- get_topology_resources_overrides_size() - Method in class org.apache.storm.generated.RebalanceOptions
- get_topology_stats() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_topology_status() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_topology_version() - Method in class org.apache.storm.generated.StormBase
- get_topology_version() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_topology_version() - Method in class org.apache.storm.generated.TopologySummary
- get_topologyId() - Method in class org.apache.storm.generated.WorkerMetrics
- get_topologyId() - Method in class org.apache.storm.generated.WorkerTokenInfo
- get_topoOwner() - Method in class org.apache.storm.generated.Credentials
- get_total_executors() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_total_node_shared() - Method in class org.apache.storm.generated.LocalAssignment
- get_total_resources() - Method in class org.apache.storm.generated.SupervisorSummary
- get_total_resources_size() - Method in class org.apache.storm.generated.SupervisorSummary
- get_total_shared_off_heap() - Method in class org.apache.storm.generated.Assignment
- get_total_shared_off_heap_size() - Method in class org.apache.storm.generated.Assignment
- get_total_tasks() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_total_topologies() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_total_workers() - Method in class org.apache.storm.generated.OwnerResourceSummary
- get_transferred() - Method in class org.apache.storm.generated.CommonAggregateStats
- get_transferred() - Method in class org.apache.storm.generated.ExecutorStats
- get_transferred_size() - Method in class org.apache.storm.generated.ExecutorStats
- get_type() - Method in class org.apache.storm.generated.AccessControl
- get_type() - Method in class org.apache.storm.generated.ComponentAggregateStats
- get_type() - Method in exception org.apache.storm.generated.DRPCExecutionException
- get_type() - Method in class org.apache.storm.generated.HBMessage
- get_uploadedJarLocation() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- get_uploadedJarLocation() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- get_uptime_secs() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- get_uptime_secs() - Method in class org.apache.storm.generated.ExecutorSummary
- get_uptime_secs() - Method in class org.apache.storm.generated.NimbusSummary
- get_uptime_secs() - Method in class org.apache.storm.generated.SupervisorInfo
- get_uptime_secs() - Method in class org.apache.storm.generated.SupervisorSummary
- get_uptime_secs() - Method in class org.apache.storm.generated.TopologyInfo
- get_uptime_secs() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_uptime_secs() - Method in class org.apache.storm.generated.TopologySummary
- get_uptime_secs() - Method in class org.apache.storm.generated.WorkerSummary
- get_used_cpu() - Method in class org.apache.storm.generated.SupervisorSummary
- get_used_generic_resources() - Method in class org.apache.storm.generated.SupervisorSummary
- get_used_generic_resources_size() - Method in class org.apache.storm.generated.SupervisorSummary
- get_used_mem() - Method in class org.apache.storm.generated.SupervisorSummary
- get_used_ports() - Method in class org.apache.storm.generated.SupervisorInfo
- get_used_ports_iterator() - Method in class org.apache.storm.generated.SupervisorInfo
- get_used_ports_size() - Method in class org.apache.storm.generated.SupervisorInfo
- get_user() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- get_userName() - Method in class org.apache.storm.generated.PrivateWorkerKey
- get_userName() - Method in class org.apache.storm.generated.WorkerTokenInfo
- get_users() - Method in class org.apache.storm.generated.LSTopoHistory
- get_users_iterator() - Method in class org.apache.storm.generated.LSTopoHistory
- get_users_size() - Method in class org.apache.storm.generated.LSTopoHistory
- get_version() - Method in class org.apache.storm.generated.BeginDownloadResult
- get_version() - Method in class org.apache.storm.generated.NimbusSummary
- get_version() - Method in class org.apache.storm.generated.ReadableBlobMeta
- get_version() - Method in class org.apache.storm.generated.SupervisorInfo
- get_version() - Method in class org.apache.storm.generated.SupervisorSummary
- get_version(String, boolean) - Method in interface org.apache.storm.cluster.IStateStorage
-
Gets the 'version' of the node at a path.
- get_version(String, boolean) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- get_version(String, boolean) - Method in class org.apache.storm.cluster.ZKStateStorage
- get_wait_secs() - Method in class org.apache.storm.generated.KillOptions
- get_wait_secs() - Method in class org.apache.storm.generated.RebalanceOptions
- get_window() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- get_window() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- get_window_to_acked() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_acked_size() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_complete_latencies_ms() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_complete_latencies_ms_size() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_emitted() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_emitted_size() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_failed() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_failed_size() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_window_to_stats_size() - Method in class org.apache.storm.generated.ComponentPageInfo
- get_window_to_transferred() - Method in class org.apache.storm.generated.TopologyStats
- get_window_to_transferred_size() - Method in class org.apache.storm.generated.TopologyStats
- get_worker_hb(String, boolean) - Method in interface org.apache.storm.cluster.IStateStorage
-
Get the heartbeat from the node at path
- get_worker_hb(String, boolean) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- get_worker_hb(String, boolean) - Method in class org.apache.storm.cluster.ZKStateStorage
- get_worker_hb_children(String, boolean) - Method in interface org.apache.storm.cluster.IStateStorage
-
Get a list of paths of all the child nodes which exist immediately under path.
- get_worker_hb_children(String, boolean) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
- get_worker_hb_children(String, boolean) - Method in class org.apache.storm.cluster.ZKStateStorage
- get_worker_heartbeats() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- get_worker_heartbeats_iterator() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- get_worker_heartbeats_size() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- get_worker_hooks() - Method in class org.apache.storm.generated.StormTopology
- get_worker_hooks_iterator() - Method in class org.apache.storm.generated.StormTopology
- get_worker_hooks_size() - Method in class org.apache.storm.generated.StormTopology
- get_worker_resources() - Method in class org.apache.storm.generated.Assignment
- get_worker_resources_size() - Method in class org.apache.storm.generated.Assignment
- get_worker_summaries() - Method in class org.apache.storm.generated.SupervisorPageInfo
- get_worker_summaries_iterator() - Method in class org.apache.storm.generated.SupervisorPageInfo
- get_worker_summaries_size() - Method in class org.apache.storm.generated.SupervisorPageInfo
- get_workers() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_workers_iterator() - Method in class org.apache.storm.generated.TopologyPageInfo
- get_workers_size() - Method in class org.apache.storm.generated.TopologyPageInfo
- getAcceptedIssuers() - Method in class org.apache.storm.security.auth.tls.ReloadableX509TrustManager
- getAccessesFlag(int) - Static method in class org.apache.storm.container.cgroup.core.DevicesCore.Record
- getAcked() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getAcked() - Method in class org.apache.storm.stats.CommonStats
- getAckedPerSec() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getAckVal() - Method in class org.apache.storm.tuple.TupleImpl
- getActiveAction(ProfileRequest, Map, String) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getActiveAction.
- getActiveProfileActions(Nimbus.Iface, String, String, Map) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getActiveProfileActions.
- getAdditionalKey() - Method in class org.apache.storm.redis.common.mapper.RedisDataTypeDescription
-
Returns defined additional key.
- getAgg() - Method in class org.apache.storm.trident.state.CombinerValueUpdater
- getAggLevel() - Method in class org.apache.storm.metricstore.Metric
- getAggLevels() - Method in class org.apache.storm.metricstore.FilterOptions
-
Get the aggregation levels to search for.
- getAliveAssignedWorkerSlotExecutors(Cluster, String) - Static method in class org.apache.storm.scheduler.EvenScheduler
- getAliveExecutors(String, Set<List<Integer>>, Assignment, int) - Method in class org.apache.storm.daemon.nimbus.HeartbeatCache
-
Get all of the alive executors for a given topology.
- getAliveIds(int) - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Retrieve the set of alive worker IDs.
- getAliveWorkerDirs() - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return a sorted set of paths that were written by workers that are now active.
- getAllAssignmentsFromNumaSupervisors(Nimbus.Iface, String) - Method in class org.apache.storm.daemon.supervisor.timer.SynchronizeAssignments
- getAllEmittedAggregate() - Method in class org.apache.storm.loadgen.LoadCompConf
-
Compute the total amount of all messages emitted in all streams per second.
- getAllEmittedAggregate() - Method in class org.apache.storm.loadgen.TopologyLoadConf
-
Get the messages emitted per second in aggregate across all streams in the topology.
- getAllGroups() - Method in class org.apache.storm.trident.graph.GraphGrouper
- getAllIds() - Method in class org.apache.storm.scheduler.Topologies
- getAllKeys() - Method in class org.apache.storm.trident.windowing.InMemoryWindowsStore
- getAllKeys() - Method in interface org.apache.storm.trident.windowing.WindowsStore
- getAllLogsForRootDir() - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return a list of all log files from worker directories in root log directory.
- getAllNimbuses() - Method in interface org.apache.storm.nimbus.ILeaderElector
-
Get list of current nimbus addresses.
- getAllNimbuses() - Method in class org.apache.storm.testing.MockLeaderElector
- getAllNimbuses() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
- getAllNodesFrom(Cluster) - Static method in class org.apache.storm.scheduler.multitenant.Node
- getAllNodesFrom(Cluster) - Static method in class org.apache.storm.scheduler.resource.RasNodes
- getAllowedStrategies() - Method in exception org.apache.storm.utils.DisallowedStrategyException
- getAllPids(String) - Method in class org.apache.storm.container.cgroup.CgroupManager
-
Get all of the pids that are a part of this container.
- getAllPids(String) - Method in class org.apache.storm.container.DefaultResourceIsolationManager
-
Get all the pids that are a part of the container.
- getAllPorts() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getAllProcessHandles() - Static method in class org.apache.storm.ProcessSimulator
-
Get all process handles.
- getAllScheduledResourcesForNode(String) - Method in class org.apache.storm.scheduler.Cluster
- getAllScheduledResourcesForNode(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all scheduled resources for node.
- getAllSubscribedPartitions(Consumer<?, ?>) - Method in class org.apache.storm.kafka.spout.subscription.NamedTopicFilter
- getAllSubscribedPartitions(Consumer<?, ?>) - Method in class org.apache.storm.kafka.spout.subscription.PatternTopicFilter
- getAllSubscribedPartitions(Consumer<?, ?>) - Method in interface org.apache.storm.kafka.spout.subscription.TopicFilter
-
Get the Kafka TopicPartitions subscribed to by this set of spouts.
- getAllTopologiesSummary(List<TopologySummary>, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getAllTopologiesSummary.
- getAllVersions() - Method in class org.apache.storm.utils.VersionedStore
-
Sorted from most recent to oldest.
- getAllWorkerDirs() - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return a set of all worker directories in all topology directories in root log directory.
- getAlternativeVersionsMap(Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
-
Get a mapping of the configured supported versions of storm to their actual versions.
- getAnchors() - Method in class org.apache.storm.multilang.ShellMsg
- getAnchors() - Method in class org.apache.storm.tuple.MessageId
- getAnchorsToIds() - Method in class org.apache.storm.tuple.MessageId
- getAndClearResults() - Method in class org.apache.storm.testing.TupleCaptureBolt
- getAndRemoveResults() - Method in class org.apache.storm.testing.TupleCaptureBolt
- getAnnotations() - Method in class org.apache.storm.container.oci.ImageManifest
- getAnnotations() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getApprovedWorkers() - Method in class org.apache.storm.utils.LocalState
- getApproximateResources(Set<ExecutorDetails>) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get approximate resources for given topology executors.
- getApproximateTotalResources() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get an approximate total resources needed for this topology.
- getArg() - Method in class org.apache.storm.trident.state.CombinerValueUpdater
- getArgs() - Method in class org.apache.storm.flux.model.ConfigMethodDef
- getArgs() - Method in class org.apache.storm.flux.model.GroupingDef
- getAssignablePorts(SupervisorDetails) - Method in class org.apache.storm.scheduler.Cluster
- getAssignablePorts(SupervisorDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the ports that are not blacklisted.
- getAssignableSlots() - Method in class org.apache.storm.scheduler.Cluster
- getAssignableSlots() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all non-blacklisted slots in the cluster.
- getAssignableSlots(SupervisorDetails) - Method in class org.apache.storm.scheduler.Cluster
- getAssignableSlots(SupervisorDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Return all non-blacklisted slots on this supervisor.
- getAssignedCpu() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedGenericResources() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedMemOffHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedMemOnHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedMemoryForSlot(Map<String, Object>) - Static method in class org.apache.storm.scheduler.Cluster
-
Get heap memory usage for a worker's main process and logwriter process.
- getAssignedNonSharedMemOffHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedNonSharedMemOnHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedNumWorkers(TopologyDetails) - Method in class org.apache.storm.scheduler.Cluster
- getAssignedNumWorkers(TopologyDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the number of workers assigned to a topology.
- getAssignedRacks(String...) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Determine the list of racks on which topologyIds have been assigned.
- getAssignedSharedMemOffHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedSharedMemOnHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getAssignedWorkerCount(String) - Method in class org.apache.storm.daemon.supervisor.ContainerMemoryTracker
-
Gets the number of worker ports assigned to the given topology id on this supervisor.
- getAssignment() - Method in interface org.apache.storm.localizer.PortAndAssignment
- getAssignment() - Method in class org.apache.storm.localizer.TimePortAndAssignment
- getAssignment(String) - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
Get assignment as
Assignment
for a storm. - getAssignment(String) - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- getAssignmentById(String) - Method in class org.apache.storm.scheduler.Cluster
- getAssignmentById(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
get the current assignment for the topology.
- getAssignmentId() - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
- getAssignmentId() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getAssignmentId() - Method in interface org.apache.storm.scheduler.ISupervisor
-
The id used in assignments.
- getAssignmentId() - Method in class org.apache.storm.task.WorkerTopologyContext
- getAssignments() - Method in class org.apache.storm.scheduler.Cluster
- getAssignments() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all the assignments.
- getAssignmentsFromMaster(Map, IStormClusterState, String) - Method in class org.apache.storm.daemon.supervisor.timer.SynchronizeAssignments
-
Used by
Supervisor
to fetch assignments when start up. - getAssignmentsSnapshot(IStormClusterState) - Method in class org.apache.storm.daemon.supervisor.ReadClusterState
- getAssignmentVersions() - Method in class org.apache.storm.daemon.worker.WorkerState
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.storm.generated.DistributedRPC.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.storm.generated.Nimbus.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.storm.generated.Supervisor.AsyncClient.Factory
- getAttemptedClass() - Method in exception org.apache.storm.utils.DisallowedStrategyException
- getAttemptId() - Method in class org.apache.storm.transactional.TransactionAttempt
-
Deprecated.
- getAttemptId() - Method in interface org.apache.storm.trident.spout.IBatchID
- getAttemptId() - Method in class org.apache.storm.trident.spout.RichSpoutBatchId
- getAttemptId() - Method in class org.apache.storm.trident.topology.TransactionAttempt
- getAuthorizationID() - Method in class org.apache.storm.security.auth.plain.SaslPlainServer
-
Deprecated.
- getAutoCredentials() - Method in class org.apache.storm.daemon.worker.WorkerState
- getAutoCredentials(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Get all of the configured AutoCredential Plugins.
- getAvailableCpu() - Method in class org.apache.storm.scheduler.SupervisorResources
- getAvailableCpuResources() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Gets the available cpu resources for this node.
- getAvailableMem() - Method in class org.apache.storm.scheduler.SupervisorResources
- getAvailableMemoryResources() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Gets the available memory resources for this node.
- getAvailablePort() - Static method in class org.apache.storm.utils.Utils
-
Shortcut to calling
Utils.getAvailablePort(int)
with 0 as the preferred port. - getAvailablePort(int) - Static method in class org.apache.storm.utils.Utils
-
Gets an available port.
- getAvailablePorts(SupervisorDetails) - Method in class org.apache.storm.scheduler.Cluster
- getAvailablePorts(SupervisorDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Return the available ports of this supervisor.
- getAvailableResources(SupervisorDetails) - Method in class org.apache.storm.scheduler.Cluster
- getAvailableResources(SupervisorDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the resources on the supervisor that are available to be scheduled.
- getAvailableResourcesOverall() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesSummary
- getAvailableSlots() - Method in class org.apache.storm.scheduler.Cluster
- getAvailableSlots() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all the available worker slots in the cluster.
- getAvailableSlots(SupervisorDetails) - Method in class org.apache.storm.scheduler.Cluster
- getAvailableSlots(SupervisorDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Return all the available slots on this supervisor.
- getBackend(Map<String, Object>) - Static method in class org.apache.storm.assignments.LocalAssignmentsBackendFactory
- getBackpressureState(Integer) - Method in class org.apache.storm.daemon.worker.BackPressureTracker
- getBasePathForNextFile(Tuple) - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- getBatchSize() - Method in class org.apache.storm.utils.BatchHelper
- getBatchTuples() - Method in class org.apache.storm.utils.BatchHelper
- getBatchTxnId(Object) - Method in class org.apache.storm.trident.windowing.InMemoryTridentWindowManager
- getBatchTxnId(Object) - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
- getBatchTxnId(Object) - Static method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- getBeginColumn() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Get token beginning column number.
- getBeginLine() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Get token beginning line number.
- getBinary(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getBinary(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the byte array at position i in the tuple.
- getBinary(int) - Method in class org.apache.storm.tuple.TupleImpl
- getBinaryByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getBinaryByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Byte array field with a specific name.
- getBinaryByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getBlacklist(List<Map<String, Set<Integer>>>, List<Map<String, Integer>>, Cluster, Topologies) - Method in class org.apache.storm.scheduler.blacklist.strategies.DefaultBlacklistStrategy
- getBlacklist(List<Map<String, Set<Integer>>>, List<Map<String, Integer>>, Cluster, Topologies) - Method in interface org.apache.storm.scheduler.blacklist.strategies.IBlacklistStrategy
-
Get blacklist by blacklist strategy.
- getBlacklistedHosts() - Method in class org.apache.storm.scheduler.Cluster
- getBlacklistedHosts() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all of the hosts that are blacklisted.
- getBlacklistSupervisorIds() - Method in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
- getBlkioSectors() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getBlkioTime() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getBlkioWeight() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getBlkioWeightDevice() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getBlob(String) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to read a blob.
- getBlob(String) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- getBlob(String) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- getBlob(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- getBlob(String, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Gets the InputStream to read the blob details.
- getBlob(String, Subject) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- getBlob(String, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- getBlobMeta() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobMeta
- getBlobMeta() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getBlobMeta
- getBlobMeta(String) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to read the metadata information.
- getBlobMeta(String) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- getBlobMeta(String) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- getBlobMeta(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getBlobMeta(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getBlobMeta(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getBlobMeta(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- getBlobMeta(String) - Method in class org.apache.storm.LocalCluster
- getBlobMeta(String, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Gets the current version of metadata for a blob to be viewed by the user or downloaded by the supervisor.
- getBlobMeta(String, Subject) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- getBlobMeta(String, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- getBlobMeta(String, AsyncMethodCallback<ReadableBlobMeta>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getBlobMeta(String, AsyncMethodCallback<ReadableBlobMeta>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getBlobMeta_args() - Constructor for class org.apache.storm.generated.Nimbus.getBlobMeta_args
- getBlobMeta_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getBlobMeta_args
- getBlobMeta_args(Nimbus.getBlobMeta_args) - Constructor for class org.apache.storm.generated.Nimbus.getBlobMeta_args
-
Performs a deep copy on other.
- getBlobMeta_call(String, AsyncMethodCallback<ReadableBlobMeta>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getBlobMeta_call
- getBlobMeta_result() - Constructor for class org.apache.storm.generated.Nimbus.getBlobMeta_result
- getBlobMeta_result(Nimbus.getBlobMeta_result) - Constructor for class org.apache.storm.generated.Nimbus.getBlobMeta_result
-
Performs a deep copy on other.
- getBlobMeta_result(ReadableBlobMeta, AuthorizationException, KeyNotFoundException) - Constructor for class org.apache.storm.generated.Nimbus.getBlobMeta_result
- getBlobName() - Method in class org.apache.storm.localizer.LocalResource
- getBlobReplication() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobReplication
- getBlobReplication() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getBlobReplication
- getBlobReplication(String) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to read the replication of a blob.
- getBlobReplication(String) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- getBlobReplication(String) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- getBlobReplication(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getBlobReplication(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getBlobReplication(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getBlobReplication(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- getBlobReplication(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- getBlobReplication(String) - Method in class org.apache.storm.LocalCluster
- getBlobReplication(String, Subject) - Method in class org.apache.storm.blobstore.BlobStore
-
Gets the replication factor of the blob.
- getBlobReplication(String, Subject) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
- getBlobReplication(String, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- getBlobReplication(String, AsyncMethodCallback<Integer>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getBlobReplication(String, AsyncMethodCallback<Integer>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getBlobReplication_args() - Constructor for class org.apache.storm.generated.Nimbus.getBlobReplication_args
- getBlobReplication_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getBlobReplication_args
- getBlobReplication_args(Nimbus.getBlobReplication_args) - Constructor for class org.apache.storm.generated.Nimbus.getBlobReplication_args
-
Performs a deep copy on other.
- getBlobReplication_call(String, AsyncMethodCallback<Integer>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getBlobReplication_call
- getBlobReplication_result() - Constructor for class org.apache.storm.generated.Nimbus.getBlobReplication_result
- getBlobReplication_result(int, AuthorizationException, KeyNotFoundException) - Constructor for class org.apache.storm.generated.Nimbus.getBlobReplication_result
- getBlobReplication_result(Nimbus.getBlobReplication_result) - Constructor for class org.apache.storm.generated.Nimbus.getBlobReplication_result
-
Performs a deep copy on other.
- getBlobstoreHDFSPrincipal(Map) - Static method in class org.apache.storm.Config
-
Deprecated.
- getBlobStoreKeySet() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreSynchronizer
- getBlobStoreSubtree() - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- getBlobToLastKnownVersion() - Method in class org.apache.storm.daemon.worker.WorkerState
- getBlobToLastKnownVersion() - Method in class org.apache.storm.task.TopologyContext
- getBolt() - Method in class org.apache.storm.Thrift.BoltDetails
- getBolt(String) - Method in class org.apache.storm.flux.model.ExecutionContext
- getBoltDef(String) - Method in class org.apache.storm.flux.model.TopologyDef
- getBoltExecutors() - Method in interface org.apache.storm.st.topology.TestableTopology
- getBoltExecutors() - Method in class org.apache.storm.st.topology.window.SlidingTimeCorrectness
- getBoltExecutors() - Method in class org.apache.storm.st.topology.window.SlidingWindowCorrectness
- getBoltExecutors() - Method in class org.apache.storm.st.topology.window.TumblingTimeCorrectness
- getBoltExecutors() - Method in class org.apache.storm.st.topology.window.TumblingWindowCorrectness
- getBoltExecutors(List<ExecutorSummary>, StormTopology, boolean) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getBoltExecutors.
- getBoltLoad() - Method in class org.apache.storm.grouping.Load
-
Get bolt load.
- getBoltName() - Method in interface org.apache.storm.st.topology.TestableTopology
- getBoltName() - Method in class org.apache.storm.st.topology.window.SlidingTimeCorrectness
- getBoltName() - Method in class org.apache.storm.st.topology.window.SlidingWindowCorrectness
- getBoltName() - Method in class org.apache.storm.st.topology.window.TumblingTimeCorrectness
- getBoltName() - Method in class org.apache.storm.st.topology.window.TumblingWindowCorrectness
- getBoltResources(StormTopology, Map<String, Object>, String) - Static method in class org.apache.storm.scheduler.resource.ResourceUtils
- getBolts() - Method in class org.apache.storm.flux.model.TopologyDef
-
Returns bolt definitions.
- getBoltsResources(StormTopology, Map<String, Object>) - Static method in class org.apache.storm.scheduler.resource.ResourceUtils
- getBoolean(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getBoolean(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Boolean at position i in the tuple.
- getBoolean(int) - Method in class org.apache.storm.tuple.TupleImpl
- getBoolean(Object, boolean) - Static method in class org.apache.storm.utils.ObjectReader
- getBooleanByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getBooleanByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Boolean field with a specific name.
- getBooleanByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getBootStrapBrokers() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- getBoundAckers() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getBranch() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the SCM branch of the build.
- getBranch() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the SCM branch of the build.
- getBuildVersion() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get a descriptive representation of the build meant for human consumption.
- getBuildVersion() - Static method in class org.apache.storm.utils.VersionInfo
-
Get a descriptive representation of the build meant for human consumption.
- getBuildVisualization(Nimbus.Iface, Map<String, Object>, String, String, boolean) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getBuildVisualization.
- getById(String) - Method in class org.apache.storm.scheduler.Topologies
-
Get a topology given an ID.
- getByName(String) - Method in class org.apache.storm.scheduler.Topologies
-
Get a topology given a topology name.
- getByte(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getByte(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Byte at position i in the tuple.
- getByte(int) - Method in class org.apache.storm.tuple.TupleImpl
- getByteByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getByteByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Byte field with a specific name.
- getByteByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getByteCount() - Method in enum class org.apache.storm.hdfs.bolt.rotation.FileSizeRotationPolicy.Units
- getByteCount() - Method in enum class org.apache.storm.hdfs.trident.rotation.FileSizeRotationPolicy.Units
- getCachedNodeToPortSocket() - Method in class org.apache.storm.daemon.worker.WorkerState
- getCapacity() - Method in class org.apache.storm.grouping.LoadAwareShuffleGrouping
- getCertificateChain(String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- getCgroupCloneChildren() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getCgroupCloneChildren() - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
get the cgroup.clone_children config.
- getCgroupRootDir(Map<String, Object>) - Static method in class org.apache.storm.DaemonConfig
- getCgroupsNum() - Method in class org.apache.storm.container.cgroup.SubSystem
- getCgroupStormHierarchyDir(Map<String, Object>) - Static method in class org.apache.storm.DaemonConfig
- getCgroupStormHierarchyName(Map<String, Object>) - Static method in class org.apache.storm.DaemonConfig
- getCgroupStormResources(Map<String, Object>) - Static method in class org.apache.storm.DaemonConfig
-
Get the cgroup resources from the conf.
- getChildren() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getChildren() - Method in class org.apache.storm.scheduler.Component
- getChildren(CuratorFramework, String, boolean) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- getChildren(DirectedGraph<Node, Edge>, Node) - Static method in class org.apache.storm.streams.StreamUtil
- getChildren(DirectedGraph, T) - Static method in class org.apache.storm.trident.util.TridentUtils
- getClasses() - Method in class org.apache.storm.sql.javac.CompilingClassLoader
- getClassId() - Method in class org.apache.storm.container.cgroup.core.NetClsCore
- getClassLoaders() - Method in class org.apache.storm.sql.AbstractStreamsProcessor
-
Return the list of Classloaders which need to be compiled and included to the jar.
- getClassLoaders() - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- getClassName() - Method in class org.apache.storm.flux.model.ObjectDef
- getClassName(StreamsRel) - Static method in class org.apache.storm.sql.planner.StormRelUtils
- getClassPaths() - Static method in class org.apache.storm.debug.DebugHelper
- getCleanupState() - Method in class org.apache.storm.testing.CompleteTopologyParam
- getClient() - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- getClient() - Method in class org.apache.storm.utils.DRPCClient
- getClient() - Method in class org.apache.storm.utils.NimbusClient
-
Get the underlying thrift client.
- getClient(TProtocol) - Method in class org.apache.storm.generated.DistributedRPC.Client.Factory
- getClient(TProtocol) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Client.Factory
- getClient(TProtocol) - Method in class org.apache.storm.generated.Nimbus.Client.Factory
- getClient(TProtocol) - Method in class org.apache.storm.generated.Supervisor.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.storm.generated.DistributedRPC.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.storm.generated.Nimbus.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.storm.generated.Supervisor.Client.Factory
- getClientAliases(String, Principal[]) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- getClientBlobStore() - Method in class org.apache.storm.localizer.AsyncLocalizer
- getClientBlobStore(Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
- getClientBlobStoreForSupervisor(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerUtils
- getClientCertPath(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getClientKeyPath(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getClientKeyStorePassword(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getClientKeyStorePath(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getClientTrustStorePassword(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getClientTrustStorePath(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getCluster() - Method in class org.apache.storm.testing.TrackedTopology
- getClusterConfiguration(String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/cluster/configuration -> nimbus configuration.
- getClusterInfo() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getClusterInfo
- getClusterInfo() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getClusterInfo
- getClusterInfo() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getClusterInfo() - Method in class org.apache.storm.generated.Nimbus.Client
- getClusterInfo() - Method in interface org.apache.storm.generated.Nimbus.Iface
- getClusterInfo() - Method in interface org.apache.storm.ILocalCluster
-
Get cluster information.
- getClusterInfo() - Method in class org.apache.storm.LocalCluster
- getClusterInfo(AsyncMethodCallback<ClusterSummary>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getClusterInfo(AsyncMethodCallback<ClusterSummary>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getClusterInfo_args() - Constructor for class org.apache.storm.generated.Nimbus.getClusterInfo_args
- getClusterInfo_args(Nimbus.getClusterInfo_args) - Constructor for class org.apache.storm.generated.Nimbus.getClusterInfo_args
-
Performs a deep copy on other.
- getClusterInfo_call(AsyncMethodCallback<ClusterSummary>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getClusterInfo_call
- getClusterInfo_result() - Constructor for class org.apache.storm.generated.Nimbus.getClusterInfo_result
- getClusterInfo_result(ClusterSummary, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getClusterInfo_result
- getClusterInfo_result(Nimbus.getClusterInfo_result) - Constructor for class org.apache.storm.generated.Nimbus.getClusterInfo_result
-
Performs a deep copy on other.
- getClusterState() - Method in interface org.apache.storm.ILocalCluster
-
This is intended for internal testing only.
- getClusterState() - Method in class org.apache.storm.LocalCluster
- getClusterSummary(String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/cluster/summary -> cluster summary.
- getClusterSummary(ClusterSummary, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Converts thrift call result into map fit for UI/api.
- getClusterTotalCpuResource() - Method in class org.apache.storm.scheduler.Cluster
- getClusterTotalCpuResource() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the total amount of CPU resources in cluster.
- getClusterTotalGenericResources() - Method in class org.apache.storm.scheduler.Cluster
- getClusterTotalGenericResources() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the total amount of generic resources (excluding CPU and memory) in cluster.
- getClusterTotalMemoryResource() - Method in class org.apache.storm.scheduler.Cluster
- getClusterTotalMemoryResource() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the total amount of memory resources in cluster.
- getCodeDir() - Method in class org.apache.storm.task.WorkerTopologyContext
-
Gets the location of the external resources for this worker on the local filesystem.
- getCollector() - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- getColumn() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Deprecated.
- getColumnName() - Method in class org.apache.storm.jdbc.common.Column
- getColumns(ITuple) - Method in interface org.apache.storm.jdbc.mapper.JdbcMapper
-
Get columns.
- getColumns(ITuple) - Method in class org.apache.storm.jdbc.mapper.SimpleJdbcMapper
- getColumnSchema(String) - Method in class org.apache.storm.jdbc.common.JdbcClient
- getCommand() - Method in class org.apache.storm.multilang.ShellMsg
- getCommand() - Method in class org.apache.storm.multilang.SpoutMsg
- getCommandOption() - Method in class org.apache.storm.container.docker.DockerCommand
-
Returns the docker sub-command string being used, e.g 'run'.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerCommand
-
Get the full command.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerExecCommand
-
Get the full command.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerInspectCommand
-
Get the full command.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerRmCommand
-
Get the full command.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Get the full command.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerStopCommand
-
Get the full command.
- getCommandWithArguments() - Method in class org.apache.storm.container.docker.DockerWaitCommand
-
Get the full command.
- getCommitMetadata() - Method in class org.apache.storm.kafka.spout.internal.CommitMetadataManager
- getCommitPosition() - Method in class org.apache.storm.hdfs.spout.ProgressTracker
- getCommittedOffset() - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
- getComp() - Method in class org.apache.storm.multilang.BoltMsg
- getCompAssignmentCntMapForWorker(WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Get a map of component to count for the specified worker slot.
- getCompatibleVersion(NavigableMap<SimpleVersion, T>, SimpleVersion, String, T) - Static method in class org.apache.storm.utils.Utils
- getCompleted() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getCompleted() - Method in class org.apache.storm.testing.FixedTupleSpout
- getCompletedPerSec() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getCompleteLatencies() - Method in class org.apache.storm.stats.SpoutExecutorStats
- getComponent() - Method in class org.apache.storm.metric.IEventLogger.EventInfo
- getComponent() - Method in class org.apache.storm.testing.MkTupleParam
- getComponent(String) - Method in class org.apache.storm.flux.model.ExecutionContext
- getComponent(String) - Method in class org.apache.storm.flux.model.TopologyDef
- getComponentCntOnNode(RasNode, String) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getComponentCommon(Object) - Static method in class org.apache.storm.daemon.StormCommon
- getComponentCommon(String) - Method in class org.apache.storm.task.GeneralTopologyContext
- getComponentCommon(StormTopology, String) - Static method in class org.apache.storm.utils.ThriftTopologyUtils
- getComponentCommon(StormTopology, String) - Static method in class org.apache.storm.utils.Utils
- getComponentConfiguration() - Method in class org.apache.storm.clojure.ClojureBolt
- getComponentConfiguration() - Method in class org.apache.storm.clojure.ClojureSpout
- getComponentConfiguration() - Method in class org.apache.storm.clojure.RichShellBolt
- getComponentConfiguration() - Method in class org.apache.storm.clojure.RichShellSpout
- getComponentConfiguration() - Method in class org.apache.storm.coordination.BatchBoltExecutor
- getComponentConfiguration() - Method in class org.apache.storm.coordination.CoordinatedBolt
- getComponentConfiguration() - Method in class org.apache.storm.drpc.KeyedFairBolt
- getComponentConfiguration() - Method in class org.apache.storm.flux.examples.WordCounter
- getComponentConfiguration() - Method in class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
- getComponentConfiguration() - Method in class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
- getComponentConfiguration() - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- getComponentConfiguration() - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
- getComponentConfiguration() - Method in class org.apache.storm.jdbc.spout.UserSpout
- getComponentConfiguration() - Method in class org.apache.storm.jms.spout.JmsSpout
- getComponentConfiguration() - Method in class org.apache.storm.jms.trident.TridentJmsSpout
- getComponentConfiguration() - Method in class org.apache.storm.kafka.spout.KafkaSpout
- getComponentConfiguration() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutOpaque
- getComponentConfiguration() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTransactional
- getComponentConfiguration() - Method in class org.apache.storm.redis.topology.WordCounter
- getComponentConfiguration() - Method in class org.apache.storm.redis.topology.WordSpout
- getComponentConfiguration() - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
- getComponentConfiguration() - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.SplitSentence
- getComponentConfiguration() - Method in class org.apache.storm.starter.bolt.AbstractRankerBolt
- getComponentConfiguration() - Method in class org.apache.storm.starter.bolt.RollingCountBolt
- getComponentConfiguration() - Method in class org.apache.storm.starter.MultiThreadWordCountTopology.MultiThreadedSplitSentence
- getComponentConfiguration() - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
- getComponentConfiguration() - Method in class org.apache.storm.starter.WordCountTopology.SplitSentence
- getComponentConfiguration() - Method in class org.apache.storm.starter.WordCountTopologyNode.RandomSentence
- getComponentConfiguration() - Method in class org.apache.storm.starter.WordCountTopologyNode.SplitSentence
- getComponentConfiguration() - Method in class org.apache.storm.testing.BoltTracker
- getComponentConfiguration() - Method in class org.apache.storm.testing.FeederSpout
- getComponentConfiguration() - Method in class org.apache.storm.testing.FixedTupleSpout
- getComponentConfiguration() - Method in class org.apache.storm.testing.PythonShellMetricsBolt
- getComponentConfiguration() - Method in class org.apache.storm.testing.PythonShellMetricsSpout
- getComponentConfiguration() - Method in class org.apache.storm.testing.TestConfBolt
- getComponentConfiguration() - Method in class org.apache.storm.testing.TestPlannerSpout
- getComponentConfiguration() - Method in class org.apache.storm.testing.TestWordSpout
- getComponentConfiguration() - Method in class org.apache.storm.testing.TupleCaptureBolt
- getComponentConfiguration() - Method in class org.apache.storm.topology.base.BaseComponent
- getComponentConfiguration() - Method in class org.apache.storm.topology.base.BaseStatefulBolt
- getComponentConfiguration() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
- getComponentConfiguration() - Method in class org.apache.storm.topology.BasicBoltExecutor
- getComponentConfiguration() - Method in class org.apache.storm.topology.CheckpointTupleForwarder
- getComponentConfiguration() - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
-
return the current component configuration.
- getComponentConfiguration() - Method in interface org.apache.storm.topology.IComponent
-
Declare configuration specific to this component.
- getComponentConfiguration() - Method in class org.apache.storm.topology.StatefulBoltExecutor
- getComponentConfiguration() - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
-
return the current component configuration.
- getComponentConfiguration() - Method in class org.apache.storm.topology.WindowedBoltExecutor
- getComponentConfiguration() - Method in class org.apache.storm.trident.planner.SubtopologyBolt
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor
- getComponentConfiguration() - Method in interface org.apache.storm.trident.spout.IBatchSpout
- getComponentConfiguration() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout
- getComponentConfiguration() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout
- getComponentConfiguration() - Method in interface org.apache.storm.trident.spout.ITridentSpout
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.PartitionedTridentSpoutExecutor
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.RichSpoutBatchExecutor
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.TridentSpoutCoordinator
- getComponentConfiguration() - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
- getComponentConfiguration() - Method in class org.apache.storm.trident.testing.FeederBatchSpout
- getComponentConfiguration() - Method in class org.apache.storm.trident.testing.FeederCommitterBatchSpout
- getComponentConfiguration() - Method in class org.apache.storm.trident.testing.FixedBatchSpout
- getComponentConfiguration() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- getComponentConfiguration() - Method in class org.apache.storm.trident.topology.TridentBoltExecutor
- getComponentFromExecutor(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
- getComponentId() - Method in class org.apache.storm.daemon.Task
- getComponentId() - Method in class org.apache.storm.executor.Executor
- getComponentId() - Method in class org.apache.storm.metricstore.FilterOptions
- getComponentId() - Method in class org.apache.storm.metricstore.Metric
- getComponentId(int) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the component id for the specified task id.
- getComponentIds() - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets a list of all component ids in this topology.
- getComponentIds(StormTopology) - Static method in class org.apache.storm.utils.ThriftTopologyUtils
- getComponentName() - Method in class org.apache.storm.utils.ShellProcess
- getComponentOutputFields(String, String) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the declared output fields for the specified component/stream.
- getComponentOutputFields(GlobalStreamId) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the declared output fields for the specified global stream id.
- getComponentPage(Nimbus.Iface, String, String, String, boolean, String, Map) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getComponentPage.
- getComponentPageInfo() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPageInfo
- getComponentPageInfo() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getComponentPageInfo
- getComponentPageInfo(String, String, String, boolean) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getComponentPageInfo(String, String, String, boolean) - Method in class org.apache.storm.generated.Nimbus.Client
- getComponentPageInfo(String, String, String, boolean) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getComponentPageInfo(String, String, String, boolean) - Method in class org.apache.storm.LocalCluster
- getComponentPageInfo(String, String, String, boolean, AsyncMethodCallback<ComponentPageInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getComponentPageInfo(String, String, String, boolean, AsyncMethodCallback<ComponentPageInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getComponentPageInfo_args() - Constructor for class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- getComponentPageInfo_args(String, String, String, boolean) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- getComponentPageInfo_args(Nimbus.getComponentPageInfo_args) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
-
Performs a deep copy on other.
- getComponentPageInfo_call(String, String, String, boolean, AsyncMethodCallback<ComponentPageInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getComponentPageInfo_call
- getComponentPageInfo_result() - Constructor for class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- getComponentPageInfo_result(ComponentPageInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- getComponentPageInfo_result(Nimbus.getComponentPageInfo_result) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
-
Performs a deep copy on other.
- getComponentParallelism(Map<String, Object>, Object) - Static method in class org.apache.storm.utils.ServerUtils
- getComponentParallelism(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.utils.ServerUtils
- getComponentPendingProfileActions() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPendingProfileActions
- getComponentPendingProfileActions() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getComponentPendingProfileActions
- getComponentPendingProfileActions(String, String, ProfileAction) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getComponentPendingProfileActions(String, String, ProfileAction) - Method in class org.apache.storm.generated.Nimbus.Client
- getComponentPendingProfileActions(String, String, ProfileAction) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getComponentPendingProfileActions(String, String, ProfileAction) - Method in class org.apache.storm.LocalCluster
- getComponentPendingProfileActions(String, String, ProfileAction, AsyncMethodCallback<List<ProfileRequest>>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getComponentPendingProfileActions(String, String, ProfileAction, AsyncMethodCallback<List<ProfileRequest>>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getComponentPendingProfileActions_args() - Constructor for class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- getComponentPendingProfileActions_args(String, String, ProfileAction) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- getComponentPendingProfileActions_args(Nimbus.getComponentPendingProfileActions_args) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
-
Performs a deep copy on other.
- getComponentPendingProfileActions_call(String, String, ProfileAction, AsyncMethodCallback<List<ProfileRequest>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getComponentPendingProfileActions_call
- getComponentPendingProfileActions_result() - Constructor for class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- getComponentPendingProfileActions_result(List<ProfileRequest>) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- getComponentPendingProfileActions_result(Nimbus.getComponentPendingProfileActions_result) - Constructor for class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
-
Performs a deep copy on other.
- getComponents() - Method in class org.apache.storm.flux.model.TopologyDef
-
Returns a list of all component definitions.
- getComponentStreams(String) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the set of streams declared for the specified component.
- getComponentTasks(String) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the task ids allocated for the given component id.
- getComponentToExecutors() - Method in class org.apache.storm.scheduler.TopologyDetails
- getComponentToSortedTasks() - Method in class org.apache.storm.daemon.worker.WorkerState
- getComponentToStreamToFields() - Method in class org.apache.storm.daemon.worker.WorkerState
- getConf() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getConf() - Method in class org.apache.storm.daemon.worker.WorkerState
- getConf() - Method in class org.apache.storm.nimbus.AssignmentDistributionService
- getConf() - Method in class org.apache.storm.scheduler.Cluster
- getConf() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the nimbus configuration.
- getConf() - Method in class org.apache.storm.scheduler.TopologyDetails
- getConf() - Method in class org.apache.storm.security.auth.ThriftServer
- getConf() - Method in class org.apache.storm.task.GeneralTopologyContext
- getConf() - Method in class org.apache.storm.Thrift.BoltDetails
- getConf() - Method in class org.apache.storm.Thrift.SpoutDetails
- getConf() - Method in class org.apache.storm.topology.ConfigurableTopology
- getConfig() - Method in class org.apache.storm.container.oci.ImageManifest
- getConfig() - Method in class org.apache.storm.flux.model.TopologyDef
- getConfig() - Method in class org.apache.storm.kafka.spout.KafkaSpoutTopologyMainNamedTopics
- getConfig() - Method in class org.apache.storm.messaging.netty.Client
- getConfigClasses() - Static method in class org.apache.storm.validation.ConfigValidation
- getConfigFromClasspath(List<String>, Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
- getConfigKeys(Map<String, Object>) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- getConfigKeyString() - Method in class org.apache.storm.common.AbstractHadoopAutoCreds
-
The lookup key for the config key string.
- getConfigKeyString() - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
-
The lookup key for the config key string.
- getConfigKeyString() - Method in class org.apache.storm.hbase.security.AutoHBase
- getConfigKeyString() - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- getConfigKeyString() - Method in class org.apache.storm.hdfs.security.AutoHDFS
- getConfigKeyString() - Method in class org.apache.storm.hdfs.security.AutoHDFSNimbus
- getConfigMethods() - Method in class org.apache.storm.flux.model.ObjectDef
- getConfigResource(ImageManifest) - Method in class org.apache.storm.container.oci.HdfsManifestToResourcesPlugin
- getConfigResource(ImageManifest) - Method in interface org.apache.storm.container.oci.OciManifestToResourcesPluginInterface
-
Get the image config information from the manifest.
- getConfiguration(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Construct a JAAS configuration object per storm configuration file.
- getConfiguredClass(Map<String, Object>, Object) - Static method in class org.apache.storm.utils.Utils
-
Return a new instance of a pluggable specified in the conf.
- getConfiguredClasspathVersions(Map<String, Object>, List<String>) - Static method in class org.apache.storm.utils.Utils
-
Get a map of version to classpath from the conf Config.SUPERVISOR_WORKER_VERSION_CLASSPATH_MAP
- getConfiguredClient(Map<String, Object>) - Static method in class org.apache.storm.utils.DRPCClient
- getConfiguredClient(Map<String, Object>) - Static method in class org.apache.storm.utils.NimbusClient
-
Deprecated.use
#build()
instead. - getConfiguredClient(Map<String, Object>, Integer) - Static method in class org.apache.storm.utils.NimbusClient
-
Deprecated.use
#build()
instead. - getConfiguredClient(Map, String) - Static method in class org.apache.storm.utils.SupervisorClient
-
Deprecated.use
#createSupervisorClient()
instead. - getConfiguredClient(Map, String, int) - Static method in class org.apache.storm.utils.SupervisorClient
-
Deprecated.use
#createSupervisorClient()
instead. - getConfiguredClientAs(Map<String, Object>, String) - Static method in class org.apache.storm.utils.NimbusClient
-
Deprecated.use
#build()
instead. - getConfiguredClientAs(Map<String, Object>, String, Integer) - Static method in class org.apache.storm.utils.NimbusClient
-
Deprecated.use
#build()
instead. - getConfiguredClientAs(Map, String, int, String) - Static method in class org.apache.storm.utils.SupervisorClient
-
Deprecated.use
#createSupervisorClient()
instead. - getConfiguredWorkerLogWriterVersions(Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
-
Get a map of version to worker log writer from the conf Config.SUPERVISOR_WORKER_VERSION_LOGWRITER_MAP
- getConfiguredWorkerMainVersions(Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
-
Get a map of version to worker main from the conf Config.SUPERVISOR_WORKER_VERSION_MAIN_MAP
- getCongested() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getConnection() - Method in interface org.apache.storm.jdbc.common.ConnectionProvider
-
Get connection.
- getConnection() - Method in class org.apache.storm.jdbc.common.HikariCPConnectionProvider
- getConnectionLoad() - Method in class org.apache.storm.grouping.Load
-
Get connection load.
- getConstructorArgs() - Method in class org.apache.storm.flux.model.ObjectDef
- getConsumer() - Method in interface org.apache.storm.sql.runtime.ISqlStreamsDataSource
-
Provides instance of IRichBolt which can be used as consumer in topology.
- getConsumerCommittedOffset() - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- getConsumerCommittedOffset() - Method in class org.apache.storm.kafka.monitor.KafkaPartitionOffsetLag
- getConsumerGroupId() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- getConsumerGroupId() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getConsumerPropertiesFileName() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- getContainerId() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getContainerScriptPath() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getContext() - Method in interface org.apache.storm.tuple.Tuple
-
Gets the topology context associated with the tuple.
- getContext() - Method in class org.apache.storm.tuple.TupleImpl
- getContext() - Method in class org.apache.storm.windowing.CountEvictionPolicy
- getContext() - Method in interface org.apache.storm.windowing.EvictionPolicy
-
Returns the current context that is part of this eviction policy.
- getContext() - Method in class org.apache.storm.windowing.TimeEvictionPolicy
- getContext() - Method in class org.apache.storm.windowing.WatermarkCountEvictionPolicy
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.jms.trident.TridentJmsSpout
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.ITridentSpout
-
The coordinator for a TransactionalSpout runs in a single thread and indicates when batches of tuples should be emitted.
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.PartitionedTridentSpoutExecutor
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.RichSpoutBatchExecutor
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.testing.FeederBatchSpout
- getCoordinator(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.testing.FeederCommitterBatchSpout
- getCoordinator(Map<String, Object>, TopologyContext) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutOpaque
- getCoordinator(Map<String, Object>, TopologyContext) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTransactional
- getCoordinator(Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout
- getCoordinator(Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout
- getCores() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getCorrespondingLegacyResourceName(String) - Static method in class org.apache.storm.scheduler.resource.ResourceUtils
- getCount() - Method in class org.apache.storm.metricstore.Metric
- getCount() - Method in interface org.apache.storm.starter.tools.Rankable
- getCount() - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
- getCount(T, int) - Method in class org.apache.storm.starter.tools.SlotBasedCounter
- getCounts() - Method in class org.apache.storm.starter.tools.SlotBasedCounter
- getCountsThenAdvanceWindow() - Method in class org.apache.storm.starter.tools.SlidingWindowCounter
-
Return the current (total) counts of all tracked objects, then advance the window.
- getCpuCfsPeriodUs() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getCpuCfsQuotaUs() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getCpuLoad() - Method in class org.apache.storm.flux.model.VertexDef
- getCpuResourceGuaranteed() - Method in class org.apache.storm.scheduler.resource.User
- getCpuResourcePoolUtilization(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getCpuResourceRequest(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getCpuResourceUsedByUser(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getCpuRtPeriodUs() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getCpuRtRuntimeUs() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getCpus() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- getCpuShares() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getCpuStat() - Method in class org.apache.storm.container.cgroup.core.CpuacctCore
- getCpuStat() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getCpuUsage() - Method in class org.apache.storm.container.cgroup.core.CpuacctCore
- getCredentialKey(String) - Method in interface org.apache.storm.common.CredentialKeyProvider
-
The lookup key for the config key string.
- getCredentialKey(String) - Method in class org.apache.storm.hbase.security.AutoHBase
- getCredentialKey(String) - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- getCredentialKey(String) - Method in class org.apache.storm.hdfs.security.AutoHDFS
- getCredentialKey(String) - Method in class org.apache.storm.hdfs.security.AutoHDFSNimbus
- getCredentialRenewers(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Get all of the configured Credential Renewer Plugins.
- getCredentials() - Method in class org.apache.storm.daemon.worker.WorkerState
- getCredentials(Map<String, String>) - Method in class org.apache.storm.common.AbstractHadoopAutoCreds
- getCredentials(Map<String, String>, List<String>) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- getCsvLogDir(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.MetricsUtils
- getCurr() - Method in class org.apache.storm.trident.state.OpaqueValue
- getCurrAssignment() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getCurrentBlobVersions() - Method in class org.apache.storm.daemon.worker.Worker
- getCurrentCount() - Method in class org.apache.storm.windowing.DefaultEvictionContext
- getCurrentCount() - Method in interface org.apache.storm.windowing.EvictionContext
-
Returns the current count of events in the queue up to the reference time based on which count based evictions can be performed.
- getCurrentOffset() - Method in class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
- getCurrentOffset() - Method in class org.apache.storm.hdfs.trident.HdfsState.SequenceFileOptions
- getCurrentScope() - Method in class org.apache.storm.grouping.LoadAwareShuffleGrouping
- getCurrentSecret() - Method in class org.apache.storm.security.auth.workertoken.WorkerTokenManager
-
Get the secret that should be used to sign a token.
- getCurrentThroughput() - Method in class org.apache.storm.perf.ThroughputMeter
- getCurrentTxId() - Method in class org.apache.storm.trident.windowing.WindowsState
- getCurrStatus() - Method in class org.apache.storm.daemon.worker.BackPressureTracker
- getCurrTxid() - Method in class org.apache.storm.trident.state.OpaqueValue
- getCustomClass() - Method in class org.apache.storm.flux.model.GroupingDef
- getDaemonConf() - Method in class org.apache.storm.LocalCluster
-
Get daemon configuration.
- getDaemonConf() - Method in class org.apache.storm.testing.MkClusterParam
- getDaemonType() - Method in class org.apache.storm.cluster.ClusterStateContext
- getData() - Method in class org.apache.storm.cluster.VersionedData
- getData() - Method in class org.apache.storm.testing.MockedSources
- getData(String) - Method in class org.apache.storm.trident.topology.state.TransactionalState
- getData(CuratorFramework, String, boolean) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- getDatabase() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig
-
Returns database index.
- getDataContext() - Method in class org.apache.storm.sql.AbstractStreamsProcessor
-
Return DataContext instance which is used with execution of query.
- getDataContext() - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- getDataFrom(CgroupCore) - Method in class org.apache.storm.metric.cgroup.CGroupCpu
-
Deprecated.
- getDataFrom(CgroupCore) - Method in class org.apache.storm.metric.cgroup.CGroupCpuGuarantee
-
Deprecated.
- getDataFrom(CgroupCore) - Method in class org.apache.storm.metric.cgroup.CGroupCpuGuaranteeByCfsQuota
-
Deprecated.
- getDataFrom(CgroupCore) - Method in class org.apache.storm.metric.cgroup.CGroupMemoryLimit
-
Deprecated.
- getDataFrom(CgroupCore) - Method in class org.apache.storm.metric.cgroup.CGroupMemoryUsage
-
Deprecated.
- getDataFrom(CgroupCore) - Method in class org.apache.storm.metric.cgroup.CGroupMetricsBase
-
Deprecated.
- getDataSources() - Method in class org.apache.storm.sql.StormSqlContext
- getDataType() - Method in class org.apache.storm.redis.common.mapper.RedisDataTypeDescription
-
Returns defined data type.
- getDataTypeDescription() - Method in interface org.apache.storm.redis.common.mapper.RedisMapper
-
Returns descriptor which defines data type.
- getDataTypeDescription() - Method in class org.apache.storm.redis.trident.WordCountLookupMapper
- getDataTypeDescription() - Method in class org.apache.storm.redis.trident.WordCountStoreMapper
- getDataWithVersion(CuratorFramework, String, boolean) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
-
Get the data along with a version.
- getDate() - Method in class org.apache.storm.st.topology.window.data.TimeData
- getDate() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the date/time the build happened.
- getDate() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the date/time the build happened.
- getDefault() - Static method in class org.apache.storm.assignments.LocalAssignmentsBackendFactory
- getDefaultSerializer(Class) - Method in class org.apache.storm.serialization.DefaultKryoFactory.KryoSerializableDefault
- getDefaultSharedResources() - Method in class org.apache.storm.daemon.worker.WorkerState
- getDefaultSubject() - Method in class org.apache.storm.security.auth.SimpleTransportPlugin
-
Get default subject.
- getDefaultSubject() - Method in class org.apache.storm.testing.SingleUserSimpleTransport
- getDefaultZkAcls() - Method in class org.apache.storm.cluster.ClusterStateContext
- getDefaultZkAcls(Map<String, Object>) - Method in enum class org.apache.storm.cluster.DaemonType
-
Get the default ZK ACLs that should be used for a given daemon type.
- getDelegate() - Method in class org.apache.storm.utils.ListDelegate
- getDelegateCode() - Method in class org.apache.storm.sql.runtime.calcite.DebuggableExecutableExpression
- getDelegateCollector() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getDependencies() - Method in class org.apache.storm.localizer.LocallyCachedBlob
- getDependencyLocationsFor(Map<String, Object>, String, AdvancedFSOps, String) - Static method in class org.apache.storm.daemon.supervisor.BasicContainer
- getDescription() - Method in class org.apache.storm.st.topology.window.data.TimeDataWindow
- getDeserializedWorkerHooks() - Method in class org.apache.storm.daemon.worker.WorkerState
- getDest() - Method in class org.apache.storm.tuple.AddressedTuple
- getDimensions() - Method in interface org.apache.storm.metric.api.IMetric
-
Get dimension map.
- getDimensions() - Method in class org.apache.storm.metrics2.TaskMetricDimensions
- getDir() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getDir() - Method in class org.apache.storm.container.cgroup.Hierarchy
- getDir(String, String) - Static method in class org.apache.storm.container.cgroup.CgroupUtils
- getDiskUsage(File) - Static method in class org.apache.storm.utils.ServerUtils
-
Takes an input dir or file and returns the disk usage on that local directory.
- getDouble(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getDouble(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Double at position i in the tuple.
- getDouble(int) - Method in class org.apache.storm.tuple.TupleImpl
- getDouble(Object) - Static method in class org.apache.storm.utils.ObjectReader
- getDouble(Object, Double) - Static method in class org.apache.storm.utils.ObjectReader
- getDoubleByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getDoubleByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Double field with a specific name.
- getDoubleByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getDrpcHttpCredentialsPlugin(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ServerAuthUtils
-
Construct an HttpServletRequest credential plugin specified by the DRPC storm configuration.
- getDrpcInvokePort() - Method in class org.apache.storm.daemon.drpc.DRPCServer
-
The port the DRPC invoke server is listening on.
- getDrpcPort() - Method in class org.apache.storm.daemon.drpc.DRPCServer
-
The port the DRPC handler server is listening on.
- getDstAddress() - Method in class org.apache.storm.messaging.netty.Client
- getEarliestEventTs(long, long) - Method in class org.apache.storm.windowing.WindowManager
-
Scans the event queue and returns the next earliest event ts between the startTs and endTs.
- getEmitted() - Method in class org.apache.storm.stats.CommonStats
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.jms.trident.TridentJmsSpout
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.ICommitterTridentSpout
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.ITridentSpout
-
The emitter for a TransactionalSpout runs as many tasks across the cluster.
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.PartitionedTridentSpoutExecutor
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.spout.RichSpoutBatchExecutor
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.testing.FeederBatchSpout
- getEmitter(String, Map<String, Object>, TopologyContext) - Method in class org.apache.storm.trident.testing.FeederCommitterBatchSpout
- getEmitter(Map<String, Object>, TopologyContext) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutOpaque
- getEmitter(Map<String, Object>, TopologyContext) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTransactional
- getEmitter(Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout
- getEmitter(Map<String, Object>, TopologyContext) - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPC.AsyncProcessor.execute
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPC.Processor.execute
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequest
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequestV2
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.fetchRequest
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.result
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequest
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequestV2
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.fetchRequest
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.result
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.activate
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginBlobDownload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginCreateBlob
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginFileUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginUpdateBlob
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.cancelBlobUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.createStateInZookeeper
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.deactivate
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.debug
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.deleteBlob
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadBlobChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.finishBlobUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.finishFileUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobMeta
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobReplication
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getClusterInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPageInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPendingProfileActions
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getLeader
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getLogConfig
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getNimbusConf
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getOwnerResourceSummaries
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorAssignments
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorPageInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyConf
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyHistory
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByName
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByNameWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyPageInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaries
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummary
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaryByName
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getUserTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.isRemoteBlobExists
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.isTopologyNameAllowed
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.killTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.killTopologyWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.listBlobs
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.processWorkerMetrics
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.rebalance
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.sendSupervisorWorkerHeartbeat
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.sendSupervisorWorkerHeartbeats
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setBlobMeta
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setLogConfig
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setWorkerProfiler
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.submitTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.submitTopologyWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.updateBlobReplication
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadBlobChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadNewCredentials
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.activate
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.beginBlobDownload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.beginCreateBlob
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.beginFileUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.beginUpdateBlob
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.cancelBlobUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.createStateInZookeeper
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.deactivate
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.debug
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.deleteBlob
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.downloadBlobChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.downloadChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.finishBlobUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.finishFileUpload
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getBlobMeta
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getBlobReplication
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getClusterInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getComponentPageInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getComponentPendingProfileActions
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getLeader
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getLogConfig
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getNimbusConf
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getOwnerResourceSummaries
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getSupervisorAssignments
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getSupervisorPageInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyConf
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyHistory
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByName
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByNameWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyPageInfo
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummaries
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummary
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummaryByName
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.getUserTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.isRemoteBlobExists
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.isTopologyNameAllowed
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.killTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.killTopologyWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.listBlobs
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.processWorkerMetrics
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.rebalance
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.sendSupervisorWorkerHeartbeat
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.sendSupervisorWorkerHeartbeats
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.setBlobMeta
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.setLogConfig
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.setWorkerProfiler
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.submitTopology
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.submitTopologyWithOpts
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.updateBlobReplication
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.uploadBlobChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.uploadChunk
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Nimbus.Processor.uploadNewCredentials
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.getLocalAssignmentForStorm
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.sendSupervisorAssignments
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.sendSupervisorWorkerHeartbeat
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Supervisor.Processor.getLocalAssignmentForStorm
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Supervisor.Processor.sendSupervisorAssignments
- getEmptyArgsInstance() - Method in class org.apache.storm.generated.Supervisor.Processor.sendSupervisorWorkerHeartbeat
- getEndColumn() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Get token end column number.
- getEndLine() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Get token end line number.
- getEndTask() - Method in class org.apache.storm.scheduler.ExecutorDetails
- getEndTime() - Method in class org.apache.storm.metricstore.FilterOptions
-
Returns the end time if set, returns the current time otherwise.
- getEndTimestamp() - Method in class org.apache.storm.windowing.TupleWindowImpl
- getEndTimestamp() - Method in class org.apache.storm.windowing.TupleWindowIterImpl
- getEndTimestamp() - Method in interface org.apache.storm.windowing.Window
-
If processing based on event time, returns the window end time based on watermark otherwise returns the window end time based on processing time.
- getEntries(Configuration, String) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Get configurations for a section.
- getErrorMessage() - Method in class org.apache.storm.scheduler.resource.SchedulingResult
- GetErrors - Class in org.apache.storm.command
- GetErrors() - Constructor for class org.apache.storm.command.GetErrors
- getErrorsString() - Method in class org.apache.storm.utils.ShellProcess
- getEstimatedTotalHeapMemoryRequiredByTopo(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.utils.ServerUtils
- getEstimatedWorkerCountForRasTopo(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.utils.ServerUtils
- getEventCount(long) - Method in class org.apache.storm.windowing.WindowManager
-
Scans the event queue and returns number of events having timestamp less than or equal to the reference time.
- getEvents() - Method in class org.apache.storm.windowing.persistence.WindowState.WindowPartition
- getEvictedTopologiesMap() - Method in class org.apache.storm.scheduler.resource.ResourceAwareScheduler
-
Return eviction information as map {scheduled topo : evicted topos} NOTE this method returns the map of a completed scheduling round.
- getEvictionPolicy() - Method in class org.apache.storm.trident.windowing.strategy.SlidingCountWindowStrategy
-
Returns an
EvictionPolicy
instance which evicts elements after a count of given window length. - getEvictionPolicy() - Method in class org.apache.storm.trident.windowing.strategy.SlidingDurationWindowStrategy
-
Returns an
EvictionPolicy
instance which evicts elements after window duration is reached. - getEvictionPolicy() - Method in class org.apache.storm.trident.windowing.strategy.TumblingCountWindowStrategy
-
Returns an
EvictionPolicy
instance which evicts elements after a count of given window length. - getEvictionPolicy() - Method in class org.apache.storm.trident.windowing.strategy.TumblingDurationWindowStrategy
-
Returns an
EvictionPolicy
instance which evicts elements after given window duration. - getEvictionPolicy() - Method in interface org.apache.storm.trident.windowing.strategy.WindowStrategy
-
Returns an
EvictionPolicy
instance for this strategy with the given configuration. - getExecIndex() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getExecs() - Method in class org.apache.storm.scheduler.Component
- getExecSize() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getExecString() - Method in class org.apache.storm.utils.ShellUtils
-
return an array containing the command name & its parameters.
- getExecString() - Method in class org.apache.storm.utils.ShellUtils.ShellCommandExecutor
- getExecsWithBoundAckers() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getExecTime() - Method in class org.apache.storm.loadgen.InputStream.Builder
- getExecuted() - Method in class org.apache.storm.stats.BoltExecutorStats
- getExecuteLatencies() - Method in class org.apache.storm.stats.BoltExecutorStats
- getExecuteSampleStartTime() - Method in class org.apache.storm.tuple.TupleImpl
- getExecutorData(String) - Method in class org.apache.storm.task.TopologyContext
-
Fetches the executor-level data for the given name.
- getExecutorId() - Method in class org.apache.storm.executor.Executor
- getExecutorId() - Method in class org.apache.storm.executor.ExecutorShutdown
- getExecutorId() - Method in interface org.apache.storm.executor.IRunningExecutor
- getExecutorId() - Method in class org.apache.storm.metricstore.FilterOptions
- getExecutorId() - Method in class org.apache.storm.metricstore.Metric
- getExecutorReceiveQueueMap() - Method in class org.apache.storm.daemon.worker.WorkerState
- getExecutors() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getExecutors() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Get the set of all executors.
- getExecutors() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getExecutors() - Method in class org.apache.storm.scheduler.TopologyDetails
- getExecutorToComponent() - Method in class org.apache.storm.scheduler.TopologyDetails
- getExecutorToSlot() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Get the map of executor to WorkerSlot.
- getExecutorToSlot() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getExecutorTransfer() - Method in class org.apache.storm.executor.Executor
- getExitCode() - Method in class org.apache.storm.utils.ShellProcess
-
Get exit code.
- getExitCode() - Method in exception org.apache.storm.utils.ShellUtils.ExitCodeException
- getExitCode() - Method in class org.apache.storm.utils.ShellUtils
-
get the exit code.
- getExpired() - Method in class org.apache.storm.windowing.TupleWindowImpl
- getExpired() - Method in class org.apache.storm.windowing.TupleWindowIterImpl
- getExpired() - Method in interface org.apache.storm.windowing.Window
-
Get the list of events expired from the window since the last time the window was generated.
- getExtractionDir() - Method in enum class org.apache.storm.localizer.LocallyCachedTopologyBlob.TopologyBlobType
- getExtraSlowness(int) - Method in class org.apache.storm.loadgen.SlowExecutorPattern
- getFactory() - Method in class org.apache.storm.flux.model.ObjectDef
- getFactoryArgs() - Method in class org.apache.storm.flux.model.ObjectDef
- getFailed() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getFailed() - Method in class org.apache.storm.stats.CommonStats
- getField() - Method in class org.apache.storm.bolt.JoinBolt.FieldSelector
- getField(JoinBolt.FieldSelector) - Method in class org.apache.storm.bolt.JoinBolt.ResultRecord
- getFieldDesc(ComponentObject._Fields) - Method in class org.apache.storm.generated.ComponentObject
- getFieldDesc(ExecutorSpecificStats._Fields) - Method in class org.apache.storm.generated.ExecutorSpecificStats
- getFieldDesc(Grouping._Fields) - Method in class org.apache.storm.generated.Grouping
- getFieldDesc(HBMessageData._Fields) - Method in class org.apache.storm.generated.HBMessageData
- getFieldDesc(JavaObjectArg._Fields) - Method in class org.apache.storm.generated.JavaObjectArg
- getFieldDesc(SpecificAggregateStats._Fields) - Method in class org.apache.storm.generated.SpecificAggregateStats
- getFieldDesc(TopologyActionOptions._Fields) - Method in class org.apache.storm.generated.TopologyActionOptions
- getFieldIndex() - Method in interface org.apache.storm.trident.tuple.TridentTuple.Factory
- getFieldIndex() - Method in class org.apache.storm.trident.tuple.TridentTupleView.FreshOutputFactory
- getFieldIndex() - Method in class org.apache.storm.trident.tuple.TridentTupleView.OperationOutputFactory
- getFieldIndex() - Method in class org.apache.storm.trident.tuple.TridentTupleView.ProjectionFactory
- getFieldIndex() - Method in class org.apache.storm.trident.tuple.TridentTupleView.RootFactory
- getFieldName() - Method in enum class org.apache.storm.generated.AccessControl._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.AlreadyAliveException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Assignment._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.AuthorizationException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.BeginDownloadResult._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Bolt._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.BoltAggregateStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.BoltStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ClusterSummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ClusterWorkerHeartbeat._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.CommonAggregateStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ComponentAggregateStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ComponentCommon._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ComponentObject._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Credentials._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DebugOptions._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DRPCExecutionException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.DRPCRequest._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ErrorInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ExecutorAggregateStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ExecutorInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ExecutorSpecificStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ExecutorStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ExecutorSummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.GetInfoOptions._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.GlobalStreamId._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Grouping._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBAuthorizationException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBExecutionException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBMessage._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBMessageData._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBNodes._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBPulse._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.HBRecords._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.IllegalStateException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.InvalidTopologyException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.JavaObject._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.JavaObjectArg._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.KeyAlreadyExistsException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.KeyNotFoundException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.KillOptions._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ListBlobsResult._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LocalAssignment._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LocalStateData._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LogConfig._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LogLevel._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LSApprovedWorkers._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LSSupervisorAssignments._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LSSupervisorId._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LSTopoHistory._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LSTopoHistoryList._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.LSWorkerHeartbeat._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.activate_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.deactivate_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.deleteBlob_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.downloadChunk_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.downloadChunk_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getLeader_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getLeader_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getLogConfig_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getLogConfig_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopology_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getUserTopology_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.killTopology_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.listBlobs_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.listBlobs_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.rebalance_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.setLogConfig_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.setLogConfig_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.submitTopology_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.uploadChunk_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.uploadChunk_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.NimbusSummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.NodeInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.NotAliveException._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.NullStruct._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.PrivateWorkerKey._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ProfileRequest._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ReadableBlobMeta._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.RebalanceOptions._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SettableBlobMeta._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SharedMemory._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ShellComponent._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SpecificAggregateStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SpoutAggregateStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SpoutSpec._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SpoutStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.StateSpoutSpec._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.StormBase._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.StormTopology._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.StreamInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SubmitOptions._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SupervisorAssignments._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SupervisorInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SupervisorPageInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SupervisorSummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeat._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.ThriftSerializedObject._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.TopologyActionOptions._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.TopologyHistoryInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.TopologyInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.TopologyStats._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.TopologySummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerMetricList._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerMetrics._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerResources._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerSummary._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerToken._Fields
- getFieldName() - Method in enum class org.apache.storm.generated.WorkerTokenInfo._Fields
- getFieldNames(List<FieldInfo>) - Static method in class org.apache.storm.sql.runtime.utils.FieldInfoUtils
- getFields() - Static method in class org.apache.storm.st.topology.window.data.TimeData
- getFields() - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
-
Get fields.
- getFields() - Method in class org.apache.storm.testing.MkTupleParam
- getFields() - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getFields() - Method in interface org.apache.storm.tuple.ITuple
-
Gets the names of the fields in this tuple.
- getFields() - Method in class org.apache.storm.tuple.TupleImpl
- getFieldsDeclaration() - Method in class org.apache.storm.topology.OutputFieldsGetter
- getFieldsFor(String) - Method in class org.apache.storm.flux.examples.OnlyValueRecordTranslator
- getFieldsFor(String) - Method in class org.apache.storm.kafka.spout.ByTopicRecordTranslator
- getFieldsFor(String) - Method in class org.apache.storm.kafka.spout.DefaultRecordTranslator
- getFieldsFor(String) - Method in interface org.apache.storm.kafka.spout.RecordTranslator
-
Get the fields associated with a stream.
- getFieldsFor(String) - Method in class org.apache.storm.kafka.spout.SimpleRecordTranslator
- getFieldsFor(String) - Method in class org.apache.storm.sql.kafka.RecordTranslatorSchemeAdapter
- getFieldValue(AccessControl._Fields) - Method in class org.apache.storm.generated.AccessControl
- getFieldValue(AlreadyAliveException._Fields) - Method in exception org.apache.storm.generated.AlreadyAliveException
- getFieldValue(Assignment._Fields) - Method in class org.apache.storm.generated.Assignment
- getFieldValue(AuthorizationException._Fields) - Method in exception org.apache.storm.generated.AuthorizationException
- getFieldValue(BeginDownloadResult._Fields) - Method in class org.apache.storm.generated.BeginDownloadResult
- getFieldValue(Bolt._Fields) - Method in class org.apache.storm.generated.Bolt
- getFieldValue(BoltAggregateStats._Fields) - Method in class org.apache.storm.generated.BoltAggregateStats
- getFieldValue(BoltStats._Fields) - Method in class org.apache.storm.generated.BoltStats
- getFieldValue(ClusterSummary._Fields) - Method in class org.apache.storm.generated.ClusterSummary
- getFieldValue(ClusterWorkerHeartbeat._Fields) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- getFieldValue(CommonAggregateStats._Fields) - Method in class org.apache.storm.generated.CommonAggregateStats
- getFieldValue(ComponentAggregateStats._Fields) - Method in class org.apache.storm.generated.ComponentAggregateStats
- getFieldValue(ComponentCommon._Fields) - Method in class org.apache.storm.generated.ComponentCommon
- getFieldValue(ComponentPageInfo._Fields) - Method in class org.apache.storm.generated.ComponentPageInfo
- getFieldValue(Credentials._Fields) - Method in class org.apache.storm.generated.Credentials
- getFieldValue(DebugOptions._Fields) - Method in class org.apache.storm.generated.DebugOptions
- getFieldValue(DistributedRPC.execute_args._Fields) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- getFieldValue(DistributedRPC.execute_result._Fields) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- getFieldValue(DistributedRPCInvocations.failRequest_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- getFieldValue(DistributedRPCInvocations.failRequest_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- getFieldValue(DistributedRPCInvocations.failRequestV2_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- getFieldValue(DistributedRPCInvocations.failRequestV2_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- getFieldValue(DistributedRPCInvocations.fetchRequest_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- getFieldValue(DistributedRPCInvocations.fetchRequest_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- getFieldValue(DistributedRPCInvocations.result_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- getFieldValue(DistributedRPCInvocations.result_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- getFieldValue(DRPCExecutionException._Fields) - Method in exception org.apache.storm.generated.DRPCExecutionException
- getFieldValue(DRPCRequest._Fields) - Method in class org.apache.storm.generated.DRPCRequest
- getFieldValue(ErrorInfo._Fields) - Method in class org.apache.storm.generated.ErrorInfo
- getFieldValue(ExecutorAggregateStats._Fields) - Method in class org.apache.storm.generated.ExecutorAggregateStats
- getFieldValue(ExecutorInfo._Fields) - Method in class org.apache.storm.generated.ExecutorInfo
- getFieldValue(ExecutorStats._Fields) - Method in class org.apache.storm.generated.ExecutorStats
- getFieldValue(ExecutorSummary._Fields) - Method in class org.apache.storm.generated.ExecutorSummary
- getFieldValue(GetInfoOptions._Fields) - Method in class org.apache.storm.generated.GetInfoOptions
- getFieldValue(GlobalStreamId._Fields) - Method in class org.apache.storm.generated.GlobalStreamId
- getFieldValue(HBAuthorizationException._Fields) - Method in exception org.apache.storm.generated.HBAuthorizationException
- getFieldValue(HBExecutionException._Fields) - Method in exception org.apache.storm.generated.HBExecutionException
- getFieldValue(HBMessage._Fields) - Method in class org.apache.storm.generated.HBMessage
- getFieldValue(HBNodes._Fields) - Method in class org.apache.storm.generated.HBNodes
- getFieldValue(HBPulse._Fields) - Method in class org.apache.storm.generated.HBPulse
- getFieldValue(HBRecords._Fields) - Method in class org.apache.storm.generated.HBRecords
- getFieldValue(IllegalStateException._Fields) - Method in exception org.apache.storm.generated.IllegalStateException
- getFieldValue(InvalidTopologyException._Fields) - Method in exception org.apache.storm.generated.InvalidTopologyException
- getFieldValue(JavaObject._Fields) - Method in class org.apache.storm.generated.JavaObject
- getFieldValue(KeyAlreadyExistsException._Fields) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- getFieldValue(KeyNotFoundException._Fields) - Method in exception org.apache.storm.generated.KeyNotFoundException
- getFieldValue(KillOptions._Fields) - Method in class org.apache.storm.generated.KillOptions
- getFieldValue(ListBlobsResult._Fields) - Method in class org.apache.storm.generated.ListBlobsResult
- getFieldValue(LocalAssignment._Fields) - Method in class org.apache.storm.generated.LocalAssignment
- getFieldValue(LocalStateData._Fields) - Method in class org.apache.storm.generated.LocalStateData
- getFieldValue(LogConfig._Fields) - Method in class org.apache.storm.generated.LogConfig
- getFieldValue(LogLevel._Fields) - Method in class org.apache.storm.generated.LogLevel
- getFieldValue(LSApprovedWorkers._Fields) - Method in class org.apache.storm.generated.LSApprovedWorkers
- getFieldValue(LSSupervisorAssignments._Fields) - Method in class org.apache.storm.generated.LSSupervisorAssignments
- getFieldValue(LSSupervisorId._Fields) - Method in class org.apache.storm.generated.LSSupervisorId
- getFieldValue(LSTopoHistory._Fields) - Method in class org.apache.storm.generated.LSTopoHistory
- getFieldValue(LSTopoHistoryList._Fields) - Method in class org.apache.storm.generated.LSTopoHistoryList
- getFieldValue(LSWorkerHeartbeat._Fields) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- getFieldValue(Nimbus.activate_args._Fields) - Method in class org.apache.storm.generated.Nimbus.activate_args
- getFieldValue(Nimbus.activate_result._Fields) - Method in class org.apache.storm.generated.Nimbus.activate_result
- getFieldValue(Nimbus.beginBlobDownload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- getFieldValue(Nimbus.beginBlobDownload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- getFieldValue(Nimbus.beginCreateBlob_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- getFieldValue(Nimbus.beginCreateBlob_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- getFieldValue(Nimbus.beginFileUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- getFieldValue(Nimbus.beginFileUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- getFieldValue(Nimbus.beginUpdateBlob_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- getFieldValue(Nimbus.beginUpdateBlob_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- getFieldValue(Nimbus.cancelBlobUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- getFieldValue(Nimbus.cancelBlobUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- getFieldValue(Nimbus.createStateInZookeeper_args._Fields) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- getFieldValue(Nimbus.createStateInZookeeper_result._Fields) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- getFieldValue(Nimbus.deactivate_args._Fields) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- getFieldValue(Nimbus.deactivate_result._Fields) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- getFieldValue(Nimbus.debug_args._Fields) - Method in class org.apache.storm.generated.Nimbus.debug_args
- getFieldValue(Nimbus.debug_result._Fields) - Method in class org.apache.storm.generated.Nimbus.debug_result
- getFieldValue(Nimbus.deleteBlob_args._Fields) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- getFieldValue(Nimbus.deleteBlob_result._Fields) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- getFieldValue(Nimbus.downloadBlobChunk_args._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- getFieldValue(Nimbus.downloadBlobChunk_result._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- getFieldValue(Nimbus.downloadChunk_args._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- getFieldValue(Nimbus.downloadChunk_result._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- getFieldValue(Nimbus.finishBlobUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- getFieldValue(Nimbus.finishBlobUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- getFieldValue(Nimbus.finishFileUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- getFieldValue(Nimbus.finishFileUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- getFieldValue(Nimbus.getBlobMeta_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- getFieldValue(Nimbus.getBlobMeta_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- getFieldValue(Nimbus.getBlobReplication_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- getFieldValue(Nimbus.getBlobReplication_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- getFieldValue(Nimbus.getClusterInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- getFieldValue(Nimbus.getClusterInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- getFieldValue(Nimbus.getComponentPageInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- getFieldValue(Nimbus.getComponentPageInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- getFieldValue(Nimbus.getComponentPendingProfileActions_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- getFieldValue(Nimbus.getComponentPendingProfileActions_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- getFieldValue(Nimbus.getLeader_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- getFieldValue(Nimbus.getLeader_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- getFieldValue(Nimbus.getLogConfig_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- getFieldValue(Nimbus.getLogConfig_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- getFieldValue(Nimbus.getNimbusConf_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- getFieldValue(Nimbus.getNimbusConf_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- getFieldValue(Nimbus.getOwnerResourceSummaries_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- getFieldValue(Nimbus.getOwnerResourceSummaries_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- getFieldValue(Nimbus.getSupervisorAssignments_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- getFieldValue(Nimbus.getSupervisorAssignments_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- getFieldValue(Nimbus.getSupervisorPageInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- getFieldValue(Nimbus.getSupervisorPageInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- getFieldValue(Nimbus.getTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- getFieldValue(Nimbus.getTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- getFieldValue(Nimbus.getTopologyConf_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- getFieldValue(Nimbus.getTopologyConf_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- getFieldValue(Nimbus.getTopologyHistory_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- getFieldValue(Nimbus.getTopologyHistory_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- getFieldValue(Nimbus.getTopologyInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- getFieldValue(Nimbus.getTopologyInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- getFieldValue(Nimbus.getTopologyInfoByName_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- getFieldValue(Nimbus.getTopologyInfoByName_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- getFieldValue(Nimbus.getTopologyInfoByNameWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- getFieldValue(Nimbus.getTopologyInfoByNameWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- getFieldValue(Nimbus.getTopologyInfoWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- getFieldValue(Nimbus.getTopologyInfoWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- getFieldValue(Nimbus.getTopologyPageInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- getFieldValue(Nimbus.getTopologyPageInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- getFieldValue(Nimbus.getTopologySummaries_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- getFieldValue(Nimbus.getTopologySummaries_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- getFieldValue(Nimbus.getTopologySummary_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- getFieldValue(Nimbus.getTopologySummary_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- getFieldValue(Nimbus.getTopologySummaryByName_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- getFieldValue(Nimbus.getTopologySummaryByName_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- getFieldValue(Nimbus.getUserTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- getFieldValue(Nimbus.getUserTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- getFieldValue(Nimbus.isRemoteBlobExists_args._Fields) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- getFieldValue(Nimbus.isRemoteBlobExists_result._Fields) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- getFieldValue(Nimbus.isTopologyNameAllowed_args._Fields) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- getFieldValue(Nimbus.isTopologyNameAllowed_result._Fields) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- getFieldValue(Nimbus.killTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- getFieldValue(Nimbus.killTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- getFieldValue(Nimbus.killTopologyWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- getFieldValue(Nimbus.killTopologyWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- getFieldValue(Nimbus.listBlobs_args._Fields) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- getFieldValue(Nimbus.listBlobs_result._Fields) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- getFieldValue(Nimbus.processWorkerMetrics_args._Fields) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- getFieldValue(Nimbus.processWorkerMetrics_result._Fields) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- getFieldValue(Nimbus.rebalance_args._Fields) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- getFieldValue(Nimbus.rebalance_result._Fields) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- getFieldValue(Nimbus.sendSupervisorWorkerHeartbeat_args._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- getFieldValue(Nimbus.sendSupervisorWorkerHeartbeat_result._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- getFieldValue(Nimbus.sendSupervisorWorkerHeartbeats_args._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- getFieldValue(Nimbus.sendSupervisorWorkerHeartbeats_result._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- getFieldValue(Nimbus.setBlobMeta_args._Fields) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- getFieldValue(Nimbus.setBlobMeta_result._Fields) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- getFieldValue(Nimbus.setLogConfig_args._Fields) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- getFieldValue(Nimbus.setLogConfig_result._Fields) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- getFieldValue(Nimbus.setWorkerProfiler_args._Fields) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- getFieldValue(Nimbus.setWorkerProfiler_result._Fields) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- getFieldValue(Nimbus.submitTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- getFieldValue(Nimbus.submitTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- getFieldValue(Nimbus.submitTopologyWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- getFieldValue(Nimbus.submitTopologyWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- getFieldValue(Nimbus.updateBlobReplication_args._Fields) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- getFieldValue(Nimbus.updateBlobReplication_result._Fields) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- getFieldValue(Nimbus.uploadBlobChunk_args._Fields) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- getFieldValue(Nimbus.uploadBlobChunk_result._Fields) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- getFieldValue(Nimbus.uploadChunk_args._Fields) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- getFieldValue(Nimbus.uploadChunk_result._Fields) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- getFieldValue(Nimbus.uploadNewCredentials_args._Fields) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- getFieldValue(Nimbus.uploadNewCredentials_result._Fields) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- getFieldValue(NimbusSummary._Fields) - Method in class org.apache.storm.generated.NimbusSummary
- getFieldValue(NodeInfo._Fields) - Method in class org.apache.storm.generated.NodeInfo
- getFieldValue(NotAliveException._Fields) - Method in exception org.apache.storm.generated.NotAliveException
- getFieldValue(NullStruct._Fields) - Method in class org.apache.storm.generated.NullStruct
- getFieldValue(OwnerResourceSummary._Fields) - Method in class org.apache.storm.generated.OwnerResourceSummary
- getFieldValue(PrivateWorkerKey._Fields) - Method in class org.apache.storm.generated.PrivateWorkerKey
- getFieldValue(ProfileRequest._Fields) - Method in class org.apache.storm.generated.ProfileRequest
- getFieldValue(ReadableBlobMeta._Fields) - Method in class org.apache.storm.generated.ReadableBlobMeta
- getFieldValue(RebalanceOptions._Fields) - Method in class org.apache.storm.generated.RebalanceOptions
- getFieldValue(SettableBlobMeta._Fields) - Method in class org.apache.storm.generated.SettableBlobMeta
- getFieldValue(SharedMemory._Fields) - Method in class org.apache.storm.generated.SharedMemory
- getFieldValue(ShellComponent._Fields) - Method in class org.apache.storm.generated.ShellComponent
- getFieldValue(SpoutAggregateStats._Fields) - Method in class org.apache.storm.generated.SpoutAggregateStats
- getFieldValue(SpoutSpec._Fields) - Method in class org.apache.storm.generated.SpoutSpec
- getFieldValue(SpoutStats._Fields) - Method in class org.apache.storm.generated.SpoutStats
- getFieldValue(StateSpoutSpec._Fields) - Method in class org.apache.storm.generated.StateSpoutSpec
- getFieldValue(StormBase._Fields) - Method in class org.apache.storm.generated.StormBase
- getFieldValue(StormTopology._Fields) - Method in class org.apache.storm.generated.StormTopology
- getFieldValue(StreamInfo._Fields) - Method in class org.apache.storm.generated.StreamInfo
- getFieldValue(SubmitOptions._Fields) - Method in class org.apache.storm.generated.SubmitOptions
- getFieldValue(Supervisor.getLocalAssignmentForStorm_args._Fields) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- getFieldValue(Supervisor.getLocalAssignmentForStorm_result._Fields) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- getFieldValue(Supervisor.sendSupervisorAssignments_args._Fields) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- getFieldValue(Supervisor.sendSupervisorAssignments_result._Fields) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- getFieldValue(Supervisor.sendSupervisorWorkerHeartbeat_args._Fields) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- getFieldValue(Supervisor.sendSupervisorWorkerHeartbeat_result._Fields) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- getFieldValue(SupervisorAssignments._Fields) - Method in class org.apache.storm.generated.SupervisorAssignments
- getFieldValue(SupervisorInfo._Fields) - Method in class org.apache.storm.generated.SupervisorInfo
- getFieldValue(SupervisorPageInfo._Fields) - Method in class org.apache.storm.generated.SupervisorPageInfo
- getFieldValue(SupervisorSummary._Fields) - Method in class org.apache.storm.generated.SupervisorSummary
- getFieldValue(SupervisorWorkerHeartbeat._Fields) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- getFieldValue(SupervisorWorkerHeartbeats._Fields) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- getFieldValue(ThriftSerializedObject._Fields) - Method in class org.apache.storm.generated.ThriftSerializedObject
- getFieldValue(TopologyHistoryInfo._Fields) - Method in class org.apache.storm.generated.TopologyHistoryInfo
- getFieldValue(TopologyInfo._Fields) - Method in class org.apache.storm.generated.TopologyInfo
- getFieldValue(TopologyPageInfo._Fields) - Method in class org.apache.storm.generated.TopologyPageInfo
- getFieldValue(TopologyStats._Fields) - Method in class org.apache.storm.generated.TopologyStats
- getFieldValue(TopologySummary._Fields) - Method in class org.apache.storm.generated.TopologySummary
- getFieldValue(WorkerMetricList._Fields) - Method in class org.apache.storm.generated.WorkerMetricList
- getFieldValue(WorkerMetricPoint._Fields) - Method in class org.apache.storm.generated.WorkerMetricPoint
- getFieldValue(WorkerMetrics._Fields) - Method in class org.apache.storm.generated.WorkerMetrics
- getFieldValue(WorkerResources._Fields) - Method in class org.apache.storm.generated.WorkerResources
- getFieldValue(WorkerSummary._Fields) - Method in class org.apache.storm.generated.WorkerSummary
- getFieldValue(WorkerToken._Fields) - Method in class org.apache.storm.generated.WorkerToken
- getFieldValue(WorkerTokenInfo._Fields) - Method in class org.apache.storm.generated.WorkerTokenInfo
- getFile() - Method in class org.apache.storm.flux.model.IncludeDef
- getFile() - Method in class org.apache.storm.testing.TmpPath
- getFileLength() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
- getFileLength() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getFileLength() - Method in class org.apache.storm.blobstore.InputStreamWithMeta
- getFileLength() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getFileLength() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusDownloadInputStream
- getFileLength() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- getFileName() - Method in class org.apache.storm.container.oci.OciResource
- getFileName() - Method in enum class org.apache.storm.localizer.LocallyCachedTopologyBlob.TopologyBlobType
- getFileOffset() - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler.Matched
- getFileOffset() - Method in class org.apache.storm.hdfs.spout.SequenceFileReader
- getFileOffset() - Method in class org.apache.storm.hdfs.spout.TextFileReader
- getFileOwner(String) - Static method in class org.apache.storm.utils.ServerUtils
- getFilePath() - Method in interface org.apache.storm.hdfs.bolt.Writer
- getFilePath() - Method in class org.apache.storm.hdfs.common.AbstractHDFSWriter
- getFilePath() - Method in class org.apache.storm.hdfs.spout.TextFileReader
- getFilesForDir(Path) - Method in class org.apache.storm.daemon.logviewer.utils.DirectoryCleaner
-
Lists files in directory.
- getFilledStats(List<ExecutorSummary>) - Static method in class org.apache.storm.stats.StatsUtil
-
filter ExecutorSummary whose stats is null.
- getFilterClass() - Method in class org.apache.storm.daemon.ui.FilterConfiguration
- getFilterName() - Method in class org.apache.storm.daemon.ui.FilterConfiguration
- getFilterParams() - Method in class org.apache.storm.daemon.ui.FilterConfiguration
- getFingerprint(Schema) - Method in interface org.apache.storm.hdfs.avro.AvroSchemaRegistry
- getFingerprint(Schema) - Method in class org.apache.storm.hdfs.avro.FixedAvroSerializer
- getFingerprint(Schema) - Method in class org.apache.storm.hdfs.avro.GenericAvroSerializer
- getFirst() - Method in class org.apache.storm.streams.Pair
-
Returns the first value in a pair.
- getFirstOffset() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutBatchMetadata
- getFirstPollOffsetStrategy() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getFloat(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getFloat(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Float at position i in the tuple.
- getFloat(int) - Method in class org.apache.storm.tuple.TupleImpl
- getFloatByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getFloatByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Float field with a specific name.
- getFloatByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- GetFollowers() - Constructor for class org.apache.storm.starter.ReachTopology.GetFollowers
- getForcedScheduler() - Method in class org.apache.storm.daemon.nimbus.Nimbus.StandaloneINimbus
- getForcedScheduler() - Method in interface org.apache.storm.scheduler.INimbus
- getFreeSlots() - Method in class org.apache.storm.scheduler.resource.RasNode
- getFreeSlotsId() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Get the IDs of all free slots on this node.
- getFrom() - Method in class org.apache.storm.flux.model.StreamDef
- getFromCache(String) - Static method in class org.apache.storm.starter.ResourceAwareExampleTopology.ExclamationBolt
- getFromClasspath(String) - Static method in class org.apache.storm.utils.VersionInfo
-
Look for the version of storm defined by the given classpath.
- getFromClasspath(List<String>) - Static method in class org.apache.storm.utils.VersionInfo
-
Look for the version of storm defined by the given classpath.
- getFromComponent() - Method in class org.apache.storm.loadgen.InputStream.Builder
- getFunction() - Method in class org.apache.storm.daemon.drpc.OutstandingRequest
- getGc(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getGenericGuaranteed() - Method in class org.apache.storm.scheduler.resource.User
- getGlobalStreamId() - Method in class org.apache.storm.coordination.CoordinatedBolt.IdStreamSpec
- getGlobalStreamId(String, String) - Static method in class org.apache.storm.utils.Utils
- getGreyListedSupervisors() - Method in class org.apache.storm.scheduler.Cluster
- getGroupFields() - Method in class org.apache.storm.trident.fluent.GroupedStream
- getGrouping() - Method in class org.apache.storm.flux.model.StreamDef
- getGroupingType() - Method in class org.apache.storm.loadgen.InputStream.Builder
- getGroupMappingServiceProviderPlugin(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Construct a group mapping service provider plugin.
- getGroups(String) - Method in class org.apache.storm.security.auth.FixedGroupsMapping
-
Returns list of groups for a user.
- getGroups(String) - Method in interface org.apache.storm.security.auth.IGroupMappingServiceProvider
-
Get all various group memberships of a given user.
- getGroups(String) - Method in class org.apache.storm.security.auth.ShellBasedGroupsMapping
-
Returns list of groups for a user.
- getGroupsForUserCommand(String) - Static method in class org.apache.storm.utils.ShellUtils
-
a Unix command to get a given user's groups list.
- getGroupWhitelist() - Method in class org.apache.storm.daemon.logviewer.utils.ResourceAuthorizer.LogUserGroupWhitelist
- getHadoopCredentials(Map<String, Object>, String) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- getHadoopCredentials(Map<String, Object>, String) - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- getHadoopCredentials(Map<String, Object>, String) - Method in class org.apache.storm.hdfs.security.AutoHDFSNimbus
- getHadoopCredentials(Map<String, Object>, String, String) - Method in class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
- getHadoopCredentials(Map<String, Object>, String, String) - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- getHadoopCredentials(Map<String, Object>, String, String) - Method in class org.apache.storm.hdfs.security.AutoHDFSNimbus
- getHadoopCredentials(Map<String, Object>, Configuration, String) - Method in class org.apache.storm.hbase.security.AutoHBaseNimbus
- getHashFromImageTag(String) - Method in class org.apache.storm.container.oci.LocalOrHdfsImageTagToManifestPlugin
- getHashFromImageTag(String) - Method in interface org.apache.storm.container.oci.OciImageTagToManifestPluginInterface
- getHdfsKeytab(Map<String, Object>) - Static method in class org.apache.storm.Config
-
Get the hdfs keytab.
- getHdfsPrincipal(Map<String, Object>) - Static method in class org.apache.storm.Config
-
Get the hostname substituted hdfs principal.
- getHeartbeatExecutor() - Method in class org.apache.storm.daemon.supervisor.Supervisor
-
Get the executor service that is supposed to be used for heart-beats.
- getHeartbeatsCache() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getHierarchies() - Method in class org.apache.storm.container.cgroup.CgroupCenter
- getHierarchies() - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
Get a list of hierarchies.
- getHierarchy() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getHierarchyID() - Method in class org.apache.storm.container.cgroup.SubSystem
- getHierarchyWithSubSystem(SubSystemType) - Method in class org.apache.storm.container.cgroup.CgroupCenter
- getHierarchyWithSubSystem(SubSystemType) - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
get the first hierarchy that has a certain subsystem isMounted.
- getHierarchyWithSubSystems(List<SubSystemType>) - Method in class org.apache.storm.container.cgroup.CgroupCenter
- getHierarchyWithSubSystems(List<SubSystemType>) - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
get the first hierarchy that has a certain list of subsystems isMounted.
- getHistorySummary(String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/history/summary -> topo history.
- getHooks() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getHooks() - Method in class org.apache.storm.task.TopologyContext
- getHost() - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- getHost() - Method in class org.apache.storm.nimbus.NimbusInfo
- getHost() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig
-
Returns host.
- getHost() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getHost() - Method in class org.apache.storm.utils.DRPCClient
- getHost(String) - Method in class org.apache.storm.scheduler.Cluster
- getHost(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Map a supervisor to a given host.
- getHostId() - Method in class org.apache.storm.metricstore.FilterOptions
- getHostname() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getHostname() - Method in class org.apache.storm.metricstore.Metric
- getHostname() - Method in class org.apache.storm.scheduler.resource.RasNode
- getHostName() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getHostName(Map<String, SupervisorDetails>, String) - Method in class org.apache.storm.daemon.nimbus.Nimbus.StandaloneINimbus
- getHostName(Map<String, SupervisorDetails>, String) - Method in interface org.apache.storm.scheduler.INimbus
-
map from node id to supervisor details.
- getHostnameToNodes() - Method in class org.apache.storm.scheduler.resource.RasNodes
-
Get a map with list of RasNode for each hostname.
- getHosts() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getHostToRack() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get host -> rack map - the inverse of networkTopography.
- getHttpCredentialsPlugin(Map<String, Object>, String) - Static method in class org.apache.storm.security.auth.ServerAuthUtils
- getHttpServerPort() - Method in class org.apache.storm.daemon.drpc.DRPCServer
-
The port the HTTP server is listening on.
- getId() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getId() - Method in class org.apache.storm.flux.model.BeanDef
- getId() - Method in class org.apache.storm.flux.model.BeanReference
- getId() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTopicPartition
- getId() - Method in class org.apache.storm.loadgen.InputStream.Builder
- getId() - Method in class org.apache.storm.loadgen.LoadCompConf.Builder
- getId() - Method in class org.apache.storm.loadgen.OutputStream.Builder
- getId() - Method in class org.apache.storm.multilang.BoltMsg
- getId() - Method in class org.apache.storm.multilang.ShellMsg
- getId() - Method in class org.apache.storm.multilang.SpoutMsg
- getId() - Method in class org.apache.storm.scheduler.Component
- getId() - Method in class org.apache.storm.scheduler.multitenant.Node
- getId() - Method in class org.apache.storm.scheduler.resource.RasNode
- getId() - Method in class org.apache.storm.scheduler.resource.User
- getId() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getId() - Method in class org.apache.storm.scheduler.TopologyDetails
- getId() - Method in class org.apache.storm.scheduler.WorkerSlot
- getId() - Method in interface org.apache.storm.trident.spout.IBatchID
- getId() - Method in interface org.apache.storm.trident.spout.ISpoutPartition
-
This is used as a Zookeeper node path for storing metadata.
- getId() - Method in class org.apache.storm.trident.spout.RichSpoutBatchId
- getId() - Method in class org.apache.storm.trident.topology.TransactionAttempt
- getId() - Method in class org.apache.storm.windowing.persistence.WindowState.WindowPartition
- getIdFromBlobKey(String) - Static method in class org.apache.storm.utils.ConfigUtils
-
Returns the topology ID belonging to a blob key if it exists.
- getIds() - Method in class org.apache.storm.flux.model.BeanListReference
- getIdToExecutors() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getIface() - Method in class org.apache.storm.utils.SupervisorClient
- getIface() - Method in interface org.apache.storm.utils.SupervisorIfaceFactory
- getIfPrioMap() - Method in class org.apache.storm.container.cgroup.core.NetPrioCore
- GetImage() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Get token literal value.
- getImageName(Map<String, Object>) - Method in class org.apache.storm.container.oci.OciContainerManager
-
Get image name from topology Conf.
- getIncludes() - Method in class org.apache.storm.flux.model.TopologyDef
- getIncompatibleComponentSets() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverConfig
-
Return an object that maps component names to a set of other components which are incompatible and their executor instances cannot co-exist on the same worker.
- GetInfoOptions - Class in org.apache.storm.generated
- GetInfoOptions() - Constructor for class org.apache.storm.generated.GetInfoOptions
- GetInfoOptions(GetInfoOptions) - Constructor for class org.apache.storm.generated.GetInfoOptions
-
Performs a deep copy on other.
- GetInfoOptions._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- getINimbus() - Method in class org.apache.storm.scheduler.Cluster
- getInputMap(Map.Entry<GlobalStreamId, Grouping>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getInputMap.
- getInputs() - Method in class org.apache.storm.scheduler.Component
- getInputs() - Method in class org.apache.storm.Thrift.BoltDetails
- getInputStream() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getInputStream() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getInputStream() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- getInstance() - Static method in class org.apache.storm.container.cgroup.CgroupCenter
- getInstance() - Method in class org.apache.storm.redis.bolt.AbstractRedisBolt
-
Borrow JedisCommands instance from container.
- getInstance() - Method in class org.apache.storm.redis.common.container.RedisClusterContainer
-
Borrows instance from container.
- getInstance() - Method in interface org.apache.storm.redis.common.container.RedisCommandsInstanceContainer
-
Borrows instance from container.
- getInstance() - Method in class org.apache.storm.redis.common.container.RedisContainer
-
Borrows instance from container.
- getInstance(Map, INodeAssignmentSentCallBack) - Static method in class org.apache.storm.nimbus.AssignmentDistributionService
-
Factory method for initialize a instance.
- getInstance(Set<SubSystemType>, String) - Static method in class org.apache.storm.container.cgroup.CgroupCoreFactory
- getInstance(SubSystemType, String) - Static method in class org.apache.storm.container.cgroup.CgroupCoreFactory
- getInt(Object) - Static method in class org.apache.storm.utils.ObjectReader
- getInt(Object, Integer) - Static method in class org.apache.storm.utils.ObjectReader
- getInt(Map, Object, int) - Static method in class org.apache.storm.perf.KafkaClientHdfsTopo
- getInt(Map, Object, int) - Static method in class org.apache.storm.perf.utils.Helper
- getInteger(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getInteger(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Integer at position i in the tuple.
- getInteger(int) - Method in class org.apache.storm.tuple.TupleImpl
- getIntegerByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getIntegerByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Integer field with a specific name.
- getIntegerByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getInterface() - Method in enum class org.apache.storm.sql.planner.streams.rel.StreamsLogicalConvention
- getInterval() - Method in class org.apache.storm.hdfs.bolt.rotation.TimedRotationPolicy
- getInterval() - Method in class org.apache.storm.hdfs.trident.rotation.TimedRotationPolicy
- getIntervalToTaskToMetricToRegistry() - Method in class org.apache.storm.executor.Executor
- getIOMerged() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getIOQueued() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getIOServiceBytes() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getIOServiced() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getIOServiceTime() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getIOWaitTime() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getIsDebug() - Method in class org.apache.storm.executor.Executor
- getIsTopologyActive() - Method in class org.apache.storm.daemon.worker.WorkerState
- getiSupervisor() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getIsWorkerActive() - Method in class org.apache.storm.daemon.worker.WorkerState
- getIter() - Method in class org.apache.storm.windowing.TupleWindowIterImpl
- getIter() - Method in interface org.apache.storm.windowing.Window
-
Returns an iterator over the events in the window.
- getJaasConf(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
- getJavaType(int) - Static method in class org.apache.storm.jdbc.common.Util
- getJedis() - Method in class org.apache.storm.redis.trident.state.RedisState
-
Borrows Jedis instance from pool.
- getJedisCluster() - Method in class org.apache.storm.redis.trident.state.RedisClusterState
-
Borrows JedisCluster instance.
- getJmsAcknowledgeMode() - Method in class org.apache.storm.jms.spout.JmsSpout
-
Returns the JMS Session acknowledgement mode for the JMS session associated with this spout.
- getJmsID() - Method in class org.apache.storm.jms.spout.JmsMessageID
- getJoinField() - Method in class org.apache.storm.bolt.JoinBolt.JoinInfo
- getJoinType() - Method in class org.apache.storm.bolt.JoinBolt.JoinInfo
- getJsonResponseBody(Object, String, boolean) - Static method in class org.apache.storm.daemon.ui.UIHelpers
- getJsonResponseHeaders(String, Map) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getJsonResponseHeaders.
- getJsonWithUpdatedResources(String, Map<String, Double>) - Static method in class org.apache.storm.scheduler.resource.ResourceUtils
- getKafkaProps() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
- getKafkaProps() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
-
Gets the properties that will be passed to the KafkaConsumer.
- getKafkaSpoutConfig(String) - Method in class org.apache.storm.kafka.spout.KafkaSpoutTopologyMainNamedTopics
- getKafkaSpoutConfig(String) - Method in class org.apache.storm.kafka.spout.KafkaSpoutTopologyMainWildcardTopics
- getKerbTicketClient() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
- getKerbTicketClient() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModuleTest
- getKerbTicketFromCache() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
- getKerbTicketFromCache() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModuleTest
- getKey() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getKey() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getKey() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- getKey() - Method in class org.apache.storm.hdfs.common.HdfsUtils.Pair
- getKey() - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Get the key for this blob.
- getKey(String) - Method in enum class org.apache.storm.localizer.LocallyCachedTopologyBlob.TopologyBlobType
- getKeyDir(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- getKeyFactory() - Method in class org.apache.storm.redis.trident.state.AbstractRedisMapState
-
Returns KeyFactory which is used for converting state key -> Redis key.
- getKeyFactory() - Method in class org.apache.storm.redis.trident.state.RedisClusterMapState
-
Returns KeyFactory which is used for converting state key -> Redis key.
- getKeyFactory() - Method in class org.apache.storm.redis.trident.state.RedisMapState
-
Returns KeyFactory which is used for converting state key -> Redis key.
- getKeyFromTuple(TridentTuple) - Method in class org.apache.storm.kafka.trident.mapper.FieldNameBasedTupleToKafkaMapper
- getKeyFromTuple(TridentTuple) - Method in interface org.apache.storm.kafka.trident.mapper.TridentTupleToKafkaMapper
- getKeyFromTuple(ITuple) - Method in interface org.apache.storm.redis.common.mapper.TupleMapper
-
Extracts key from tuple.
- getKeyFromTuple(ITuple) - Method in class org.apache.storm.redis.trident.WordCountLookupMapper
- getKeyFromTuple(ITuple) - Method in class org.apache.storm.redis.trident.WordCountStoreMapper
- getKeyFromTuple(Tuple) - Method in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- getKeyFromTuple(Tuple) - Method in interface org.apache.storm.kafka.bolt.mapper.TupleToKafkaMapper
- getKeyListFromBlobStore(BlobStore) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- getKeySequenceNumber(CuratorFramework) - Method in class org.apache.storm.blobstore.KeySequenceNumber
- getKeySerializer() - Method in class org.apache.storm.state.DefaultStateEncoder
- getKeySetToDownload(Set<String>, Set<String>) - Method in class org.apache.storm.blobstore.LocalFsBlobStoreSynchronizer
- getKeyStore(String, String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- getKeyStoreFile(String) - Method in class org.apache.storm.security.auth.ThriftClient
-
Function to create a keystore and return the keystore file.
- getKryo(Map<String, Object>) - Method in class org.apache.storm.serialization.DefaultKryoFactory
- getKryo(Map<String, Object>) - Method in interface org.apache.storm.serialization.IKryoFactory
- getKryo(Map<String, Object>) - Static method in class org.apache.storm.serialization.SerializationFactory
- getLag() - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- getLag() - Method in class org.apache.storm.kafka.monitor.KafkaPartitionOffsetLag
- getLag() - Method in class org.apache.storm.streams.windowing.BaseWindow
- getLag() - Method in interface org.apache.storm.streams.windowing.Window
-
The maximum time lag of the tuple timestamp in milliseconds.
- getLastBlobUpdateTime() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- getLastBlobUpdateTime() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
-
Get the last update time of any blob.
- getLastClassLoader() - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- getLastEntry(FileSystem, Path) - Static method in class org.apache.storm.hdfs.spout.FileLock
-
returns the last log entry.
- getLastEntryIfStale(FileSystem, Path, long) - Static method in class org.apache.storm.hdfs.spout.FileLock
-
checks if lockFile is older than 'olderThan' UTC time by examining the modification time on file and (if necessary) the timestamp in last log entry in the file.
- getLastLogEntry() - Method in class org.apache.storm.hdfs.spout.FileLock
- getLastOffset() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutBatchMetadata
- getLastOverflowCount(BackPressureTracker.BackpressureState) - Method in class org.apache.storm.daemon.worker.BackPressureTracker
- getLastState() - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
- getLastUsed() - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Get the last time that this used for LRU calculations.
- getLatch() - Method in class org.apache.storm.localizer.GoodToGo
-
Get the latch and indicate that you want to block the blob being changed.
- getLatencyAtPercentile(double, TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getLatencyStdDeviation(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getLatestEmittedOffset() - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
- getLatestSequenceNumber(List<String>) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- getLateTupleStream() - Method in class org.apache.storm.streams.windowing.BaseWindow
- getLateTupleStream() - Method in interface org.apache.storm.streams.windowing.Window
-
The name of the stream where late arriving tuples should be emitted.
- getLaunchCommand(String, List<String>) - Method in class org.apache.storm.container.cgroup.CgroupManager
-
To compose launch command based on workerId and existing command.
- getLaunchTime() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get the timestamp of when this topology was launched.
- getLayerResources(ImageManifest) - Method in class org.apache.storm.container.oci.HdfsManifestToResourcesPlugin
- getLayerResources(ImageManifest) - Method in interface org.apache.storm.container.oci.OciManifestToResourcesPluginInterface
-
Get the layers information from the manifest.
- getLayers() - Method in class org.apache.storm.container.oci.ImageManifest
- getLayers() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getLeader() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getLeader
- getLeader() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getLeader
- getLeader() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getLeader() - Method in class org.apache.storm.generated.Nimbus.Client
- getLeader() - Method in interface org.apache.storm.generated.Nimbus.Iface
- getLeader() - Method in class org.apache.storm.LocalCluster
- getLeader() - Method in interface org.apache.storm.nimbus.ILeaderElector
-
Get the current leader's address.
- getLeader() - Method in class org.apache.storm.testing.MockLeaderElector
- getLeader() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
- getLeader(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get leader info from state store, which was written when a master gains leadership.
- getLeader(Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- getLeader(AsyncMethodCallback<NimbusSummary>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getLeader(AsyncMethodCallback<NimbusSummary>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getLeader_args() - Constructor for class org.apache.storm.generated.Nimbus.getLeader_args
- getLeader_args(Nimbus.getLeader_args) - Constructor for class org.apache.storm.generated.Nimbus.getLeader_args
-
Performs a deep copy on other.
- getLeader_call(AsyncMethodCallback<NimbusSummary>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getLeader_call
- getLeader_result() - Constructor for class org.apache.storm.generated.Nimbus.getLeader_result
- getLeader_result(Nimbus.getLeader_result) - Constructor for class org.apache.storm.generated.Nimbus.getLeader_result
-
Performs a deep copy on other.
- getLeader_result(NimbusSummary, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getLeader_result
- getLeftStream() - Method in class org.apache.storm.streams.processors.JoinProcessor
- getLine() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Deprecated.
- getLinux() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getList() - Method in class org.apache.storm.container.cgroup.core.DevicesCore
- getLoad() - Method in class org.apache.storm.grouping.Load
-
Get load.
- getLoad(int) - Method in class org.apache.storm.grouping.LoadMapping
- getLoad(Collection<Integer>) - Method in interface org.apache.storm.messaging.IConnection
-
Get the current load for the given tasks.
- getLoad(Collection<Integer>) - Method in class org.apache.storm.messaging.netty.Client
- getLoadMapping() - Method in class org.apache.storm.daemon.worker.WorkerState
- getLocalAssignmentForStorm() - Constructor for class org.apache.storm.generated.Supervisor.AsyncProcessor.getLocalAssignmentForStorm
- getLocalAssignmentForStorm() - Constructor for class org.apache.storm.generated.Supervisor.Processor.getLocalAssignmentForStorm
- getLocalAssignmentForStorm(String) - Method in class org.apache.storm.generated.Supervisor.Client
- getLocalAssignmentForStorm(String) - Method in interface org.apache.storm.generated.Supervisor.Iface
-
Get local assignment for a storm
- getLocalAssignmentForStorm(String, AsyncMethodCallback<Assignment>) - Method in class org.apache.storm.generated.Supervisor.AsyncClient
- getLocalAssignmentForStorm(String, AsyncMethodCallback<Assignment>) - Method in interface org.apache.storm.generated.Supervisor.AsyncIface
- getLocalAssignmentForStorm_args() - Constructor for class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- getLocalAssignmentForStorm_args(String) - Constructor for class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- getLocalAssignmentForStorm_args(Supervisor.getLocalAssignmentForStorm_args) - Constructor for class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
-
Performs a deep copy on other.
- getLocalAssignmentForStorm_call(String, AsyncMethodCallback<Assignment>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Supervisor.AsyncClient.getLocalAssignmentForStorm_call
- getLocalAssignmentForStorm_result() - Constructor for class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- getLocalAssignmentForStorm_result(Assignment, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- getLocalAssignmentForStorm_result(Supervisor.getLocalAssignmentForStorm_result) - Constructor for class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
-
Performs a deep copy on other.
- getLocalAssignmentsMap() - Method in class org.apache.storm.utils.LocalState
- getLocalCluster(Map<String, Object>) - Static method in class org.apache.storm.Testing
-
Deprecated.use ``` try (LocalCluster cluster = new LocalCluster.Builder()....build()) { ... } ```
- getLocalExecutors() - Method in class org.apache.storm.daemon.worker.WorkerState
- getLocalizerUpdateBlobInterval(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerConfigUtils
- getLocalNimbus() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getLocalQueue(AddressedTuple) - Method in class org.apache.storm.executor.ExecutorTransfer
- getLocalReceiveQueues() - Method in class org.apache.storm.daemon.worker.WorkerState
- getLocalTaskIds() - Method in class org.apache.storm.daemon.worker.WorkerState
- getLocalVersion() - Method in class org.apache.storm.localizer.LocalizedResource
- getLocalVersion() - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Get the version of the blob cached locally.
- getLocalVersion() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- getLockDirPath() - Method in class org.apache.storm.hdfs.spout.HdfsSpout
- getLockFile() - Method in class org.apache.storm.hdfs.spout.DirLock
- getLockFile() - Method in class org.apache.storm.hdfs.spout.FileLock
- getLogConfig() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getLogConfig
- getLogConfig() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getLogConfig
- getLogConfig(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getLogConfig(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getLogConfig(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getLogConfig(String) - Method in class org.apache.storm.LocalCluster
- getLogConfig(String, AsyncMethodCallback<LogConfig>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getLogConfig(String, AsyncMethodCallback<LogConfig>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getLogConfig_args() - Constructor for class org.apache.storm.generated.Nimbus.getLogConfig_args
- getLogConfig_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getLogConfig_args
- getLogConfig_args(Nimbus.getLogConfig_args) - Constructor for class org.apache.storm.generated.Nimbus.getLogConfig_args
-
Performs a deep copy on other.
- getLogConfig_call(String, AsyncMethodCallback<LogConfig>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getLogConfig_call
- getLogConfig_result() - Constructor for class org.apache.storm.generated.Nimbus.getLogConfig_result
- getLogConfig_result(LogConfig) - Constructor for class org.apache.storm.generated.Nimbus.getLogConfig_result
- getLogConfig_result(Nimbus.getLogConfig_result) - Constructor for class org.apache.storm.generated.Nimbus.getLogConfig_result
-
Performs a deep copy on other.
- getLogDir() - Static method in class org.apache.storm.utils.ConfigUtils
- getLogDirs(Set<Path>, Predicate<String>) - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Finds directories for specific worker ids that can be cleaned up.
- getLoggerLevels() - Method in class org.apache.storm.daemon.worker.LogConfigManager
- getLogHandler(Map<String, Object>) - Static method in class org.apache.storm.utils.ShellUtils
- getLogHeadOffset() - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- getLogHeadOffset() - Method in class org.apache.storm.kafka.monitor.KafkaPartitionOffsetLag
- getLoginContextName() - Method in class org.apache.storm.messaging.netty.Login
- getLogLevel() - Method in class org.apache.storm.multilang.ShellMsg
- getLogMetaDataFile(String) - Static method in class org.apache.storm.utils.ServerConfigUtils
- getLogMetaDataFile(Map<String, Object>, String, Integer) - Static method in class org.apache.storm.utils.ServerConfigUtils
- getLogUserGroupWhitelist(String) - Method in class org.apache.storm.daemon.logviewer.utils.ResourceAuthorizer
-
Get the whitelist of users and groups for given file.
- getLogviewerLink(String, String, Map<String, Object>, int) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getLogviewerLink.
- getLogviewerPort(Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get logviewer port depending on whether the logviewer is secure or not.
- getLong(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getLong(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Long at position i in the tuple.
- getLong(int) - Method in class org.apache.storm.tuple.TupleImpl
- getLong(Object) - Static method in class org.apache.storm.utils.ObjectReader
- getLong(Object, Long) - Static method in class org.apache.storm.utils.ObjectReader
- getLongByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getLongByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Long field with a specific name.
- getLongByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getMajor() - Method in class org.apache.storm.utils.SimpleVersion
- getManagedSpoutIds() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
- getManifestFromImageTag(String) - Method in class org.apache.storm.container.oci.LocalOrHdfsImageTagToManifestPlugin
- getManifestFromImageTag(String) - Method in interface org.apache.storm.container.oci.OciImageTagToManifestPluginInterface
- getMap() - Method in class org.apache.storm.clojure.ClojureTuple
- getMap() - Method in class org.apache.storm.clojure.IndifferentAccessMap
- getMapByKey(Map, String) - Static method in class org.apache.storm.stats.ClientStatsUtil
-
Get a sub-map by a given key.
- getMasterDeclarer() - Method in class org.apache.storm.coordination.BatchSubtopologyBuilder
- getMatches() - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler.Matched
- getMax() - Method in class org.apache.storm.metricstore.Metric
- getMaxBufferSize(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getMaxBytes() - Method in class org.apache.storm.hdfs.trident.rotation.FileSizeRotationPolicy
- getMaxLatency(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getMaxNodeCoLocationCnts() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverConfig
-
Return an object that maps component names to a numeric maximum limit of executor instances (of that component) that can exist on any node.
- getMaxNumericPrecision() - Method in class org.apache.storm.sql.planner.StormRelDataTypeSystem
- getMaxNumericScale() - Method in class org.apache.storm.sql.planner.StormRelDataTypeSystem
- getMaxPhysicalUsage() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getMaxRedirections() - Method in class org.apache.storm.redis.common.config.JedisClusterConfig
-
Returns limit of redirection.
- getMaxStateSearchFromTopoConf(Map<String, Object>) - Static method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- getMaxUncommittedOffsets() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getMaxWithSwapUsage() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getMeanLatency(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getMeasured() - Method in class org.apache.storm.metric.timed.Timed
- getMechanismName() - Method in class org.apache.storm.security.auth.plain.SaslPlainServer
-
Deprecated.
- getMechanismNames(Map<String, ?>) - Method in class org.apache.storm.security.auth.plain.SaslPlainServer.SaslPlainServerFactory
-
Deprecated.
- getMediaType() - Method in class org.apache.storm.container.oci.ImageManifest
- getMediaType() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciLayer
- getMemInfoFreeMb() - Static method in class org.apache.storm.utils.ServerUtils
-
Get system free memory in megabytes.
- getMemMb() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getMemoryReservationMb() - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- getMemoryReservationMb() - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the current memory reservation of this container.
- getMemoryResourceGuaranteed() - Method in class org.apache.storm.scheduler.resource.User
- getMemoryResourcePoolUtilization(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getMemoryResourceRequest(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getMemoryResourceUsedByUser(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getMemoryUsage(String, String, int) - Method in class org.apache.storm.container.cgroup.CgroupManager
- getMemoryUsage(String, String, int) - Method in class org.apache.storm.container.DefaultResourceIsolationManager
- getMemoryUsage(String, String, int) - Method in class org.apache.storm.container.docker.DockerManager
- getMemoryUsage(String, String, int) - Method in class org.apache.storm.container.oci.RuncLibContainerManager
- getMemoryUsage(String, String, int) - Method in interface org.apache.storm.container.ResourceIsolationInterface
-
Get the current memory usage of the a given worker.
- getMemoryUsageMb() - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- getMemoryUsageMb() - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the current memory usage of this container.
- getMemPressure() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- getMems() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- getMessage() - Method in class org.apache.storm.scheduler.resource.SchedulingResult
- getMessage() - Method in error org.apache.storm.sql.parser.impl.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessage() - Method in exception org.apache.storm.utils.WrappedAlreadyAliveException
- getMessage() - Method in exception org.apache.storm.utils.WrappedAuthorizationException
- getMessage() - Method in exception org.apache.storm.utils.WrappedDRPCExecutionException
- getMessage() - Method in exception org.apache.storm.utils.WrappedHBExecutionException
- getMessage() - Method in exception org.apache.storm.utils.WrappedIllegalStateException
- getMessage() - Method in exception org.apache.storm.utils.WrappedInvalidTopologyException
- getMessage() - Method in exception org.apache.storm.utils.WrappedKeyAlreadyExistsException
- getMessage() - Method in exception org.apache.storm.utils.WrappedKeyNotFoundException
- getMessage() - Method in exception org.apache.storm.utils.WrappedNotAliveException
- getMessageFromTuple(TridentTuple) - Method in class org.apache.storm.kafka.trident.mapper.FieldNameBasedTupleToKafkaMapper
- getMessageFromTuple(TridentTuple) - Method in interface org.apache.storm.kafka.trident.mapper.TridentTupleToKafkaMapper
- getMessageFromTuple(Tuple) - Method in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
- getMessageFromTuple(Tuple) - Method in interface org.apache.storm.kafka.bolt.mapper.TupleToKafkaMapper
- getMessageId() - Method in class org.apache.storm.executor.TupleInfo
- getMessageId() - Method in class org.apache.storm.metric.IEventLogger.EventInfo
- getMessageId() - Method in interface org.apache.storm.tuple.Tuple
-
Gets the message id that associated with this tuple.
- getMessageId() - Method in class org.apache.storm.tuple.TupleImpl
- getMessageId(TopicPartition, long) - Method in class org.apache.storm.kafka.spout.KafkaSpoutRetryExponentialBackoff
- getMessageId(TopicPartition, long) - Method in interface org.apache.storm.kafka.spout.KafkaSpoutRetryService
-
Gets the
KafkaSpoutMessageId
for the record on the given topic partition and offset. - getMeta() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getMetadata() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getMetadata() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getMetadata() - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
- getMetadata() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- getMetadata() - Method in interface org.apache.storm.scheduler.ISupervisor
- getMetadata() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- getMetadataFileForWorkerLogDir(Path) - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return a metadata file (worker.yaml) for given worker log directory.
- getMetadataString(Integer) - Method in interface org.apache.storm.metricstore.rocksdb.ReadOnlyStringMetadataCache
-
Returns the string matching the string Id if in the cache.
- getMetadataString(Integer) - Method in class org.apache.storm.metricstore.rocksdb.StringMetadataCache
-
Returns the string matching the string Id if in the cache.
- getMeter(String) - Method in class org.apache.storm.metric.StormMetricsRegistry
- getMethodName() - Method in class org.apache.storm.flux.model.TopologySourceDef
- getMetricName() - Method in class org.apache.storm.metricstore.FilterOptions
- getMetricName() - Method in class org.apache.storm.metricstore.Metric
- getMetricName() - Method in class org.apache.storm.multilang.ShellMsg
- getMetricParams() - Method in class org.apache.storm.multilang.ShellMsg
- getMetricRegistry() - Method in class org.apache.storm.daemon.worker.WorkerState
- getMetricRegistry() - Method in class org.apache.storm.LocalCluster
-
Reference to metrics registry.
- getMetrics() - Method in class org.apache.storm.kafka.spout.metrics2.KafkaOffsetPartitionMetrics
- getMetrics() - Method in class org.apache.storm.kafka.spout.metrics2.KafkaOffsetTopicMetrics
- getMetricsDurationUnit(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.ClientMetricsUtils
- getMetricsDurationUnit(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.MetricsUtils
- getMetricsFilter(Map<String, Object>) - Static method in class org.apache.storm.metrics2.reporters.ScheduledStormReporter
- getMetricsJmxDomain(Map) - Static method in class org.apache.storm.metrics2.reporters.JmxStormReporter
- getMetricsRateUnit(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.ClientMetricsUtils
- getMetricsRateUnit(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.MetricsUtils
- getMetricsRegistry() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getMetricsReporterLocale(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.ClientMetricsUtils
- getMetricsReporterLocale(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.MetricsUtils
- getMetricsTimeBucketSizeInSecs() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getMilliSeconds() - Method in enum class org.apache.storm.hdfs.bolt.rotation.TimedRotationPolicy.TimeUnit
- getMilliSeconds() - Method in enum class org.apache.storm.hdfs.trident.rotation.TimedRotationPolicy.TimeUnit
- getMin() - Method in class org.apache.storm.metricstore.Metric
- getMinLatency(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getMinor() - Method in class org.apache.storm.utils.SimpleVersion
- getMinWorkerCpu() - Method in class org.apache.storm.scheduler.Cluster
- getMockedSources() - Method in class org.apache.storm.testing.CompleteTopologyParam
- getModTime() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getModTime() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getModTime() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- getMounts() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getMsg() - Method in class org.apache.storm.multilang.ShellMsg
- getN() - Method in class org.apache.storm.utils.StormBoundedExponentialBackoffRetry
- getName() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getName() - Method in class org.apache.storm.container.cgroup.Hierarchy
- getName() - Method in class org.apache.storm.flux.model.ConfigMethodDef
- getName() - Method in class org.apache.storm.flux.model.PropertyDef
- getName() - Method in class org.apache.storm.flux.model.StreamDef
- getName() - Method in class org.apache.storm.flux.model.TopologyDef
- getName() - Method in class org.apache.storm.metric.api.DataPoint
- getName() - Method in class org.apache.storm.perf.ThroughputMeter
- getName() - Method in class org.apache.storm.scheduler.TopologyDetails
- getName() - Method in class org.apache.storm.security.auth.NimbusPrincipal
- getName() - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin.User
-
Get the full name of the user.
- getName() - Method in class org.apache.storm.security.auth.SingleUserPrincipal
- getName() - Method in enum class org.apache.storm.sql.planner.streams.rel.StreamsLogicalConvention
- getName() - Method in class org.apache.storm.trident.Stream
-
Returns the label applied to the stream.
- getName(long, long) - Method in class org.apache.storm.hdfs.bolt.format.DefaultFileNameFormat
- getName(long, long) - Method in interface org.apache.storm.hdfs.bolt.format.FileNameFormat
-
Returns the filename the HdfsBolt will create.
- getName(long, long) - Method in class org.apache.storm.hdfs.bolt.format.SimpleFileNameFormat
- getName(long, long) - Method in class org.apache.storm.hdfs.trident.format.DefaultFileNameFormat
- getName(long, long) - Method in interface org.apache.storm.hdfs.trident.format.FileNameFormat
-
Returns the filename the HdfsBolt will create.
- getName(long, long) - Method in class org.apache.storm.hdfs.trident.format.SimpleFileNameFormat
- getNeedsSchedulingComponentToExecutors(TopologyDetails) - Method in class org.apache.storm.scheduler.Cluster
- getNeedsSchedulingComponentToExecutors(TopologyDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the component name to executor list for executors that need to be scheduled.
- getNeedsSchedulingExecutorToComponents(TopologyDetails) - Method in class org.apache.storm.scheduler.Cluster
- getNeedsSchedulingExecutorToComponents(TopologyDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the executor to component name map for executors that need to be scheduled.
- getNegativeResourceEventsMeter() - Method in class org.apache.storm.scheduler.resource.normalization.ResourceMetrics
- getNegotiatedProperty(String) - Method in class org.apache.storm.security.auth.plain.SaslPlainServer
-
Deprecated.
- getNetworkTopography() - Method in class org.apache.storm.scheduler.Cluster
- getNetworkTopography() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the network topography (rackId -> nodes in the rack).
- getNew() - Method in class org.apache.storm.windowing.TupleWindowImpl
- getNew() - Method in class org.apache.storm.windowing.TupleWindowIterImpl
- getNew() - Method in interface org.apache.storm.windowing.Window
-
Get the list of newly added events in the window since the last time the window was generated.
- getNextHighest() - Method in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
- getNextPrivateWorkerKeyVersion(WorkerTokenServiceType, String) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get the next key version number that should be used for this topology id.
- getNextPrivateWorkerKeyVersion(WorkerTokenServiceType, String) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- getNextToken() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Get the next Token.
- getNextToken() - Method in class org.apache.storm.sql.parser.impl.StormParserImplTokenManager
-
Get the next Token.
- getNextTopologyToSchedule(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getNextValues(OutputStreamEngine) - Method in class org.apache.storm.loadgen.LoadSpout
- getNextValues(OutputStreamEngine) - Method in class org.apache.storm.loadgen.ThroughputVsLatency.FastRandomSentenceSpout
- getNimbodesWithLatestSequenceNumberOfBlob(CuratorFramework, String) - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- getNimbus() - Method in class org.apache.storm.LocalCluster
-
Reference to nimbus.
- getNimbusAcls(Map<String, Object>) - Static method in class org.apache.storm.daemon.nimbus.Nimbus
- getNimbusAutoCredPlugins(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Get all the Nimbus Auto cred plugins.
- getNimbusBlobStore(Map<String, Object>, String, NimbusInfo, ILeaderElector) - Static method in class org.apache.storm.utils.ServerUtils
- getNimbusBlobStore(Map<String, Object>, NimbusInfo, ILeaderElector) - Static method in class org.apache.storm.utils.ServerUtils
- getNimbusConf() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getNimbusConf
- getNimbusConf() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getNimbusConf
- getNimbusConf() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getNimbusConf() - Method in class org.apache.storm.generated.Nimbus.Client
- getNimbusConf() - Method in interface org.apache.storm.generated.Nimbus.Iface
- getNimbusConf() - Method in class org.apache.storm.LocalCluster
- getNimbusConf(AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getNimbusConf(AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getNimbusConf_args() - Constructor for class org.apache.storm.generated.Nimbus.getNimbusConf_args
- getNimbusConf_args(Nimbus.getNimbusConf_args) - Constructor for class org.apache.storm.generated.Nimbus.getNimbusConf_args
-
Performs a deep copy on other.
- getNimbusConf_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getNimbusConf_call
- getNimbusConf_result() - Constructor for class org.apache.storm.generated.Nimbus.getNimbusConf_result
- getNimbusConf_result(String, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getNimbusConf_result
- getNimbusConf_result(Nimbus.getNimbusConf_result) - Constructor for class org.apache.storm.generated.Nimbus.getNimbusConf_result
-
Performs a deep copy on other.
- getNimbusHostPort() - Method in class org.apache.storm.blobstore.BlobKeySequenceInfo
- getNimbusLogLink(String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get log link to nimbus log.
- getNimbusSubject() - Static method in class org.apache.storm.blobstore.BlobStoreUtils
- getNimbusSummary(String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/nimbus/summary -> nimbus summary.
- getNimbusSummary(ClusterSummary, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getNimbusSummary.
- getNodeAndSlotCountIfSlotsWereTaken(int) - Method in class org.apache.storm.scheduler.multitenant.DefaultPool
- getNodeAndSlotCountIfSlotsWereTaken(int) - Method in class org.apache.storm.scheduler.multitenant.FreePool
- getNodeAndSlotCountIfSlotsWereTaken(int) - Method in class org.apache.storm.scheduler.multitenant.IsolatedPool
- getNodeAndSlotCountIfSlotsWereTaken(int) - Method in class org.apache.storm.scheduler.multitenant.NodePool
-
Get the number of nodes and slots this would provide to get the slots needed.
- getNodeById(String) - Method in class org.apache.storm.scheduler.resource.RasNodes
-
get node object from nodeId.
- getNodeCountIfSlotsWereTaken(int, NodePool[]) - Static method in class org.apache.storm.scheduler.multitenant.NodePool
- getNodeId() - Method in class org.apache.storm.scheduler.WorkerSlot
- getNodeIdToHostname() - Method in class org.apache.storm.scheduler.resource.RasNodes
-
Get a map from RasNodeId to HostName.
- getNodeIdToTotalSharedOffHeapNodeMemory() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Get the total shared off heap node memory mapping.
- getNodeIdToTotalSharedOffHeapNodeMemory() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getNodes() - Method in class org.apache.storm.redis.common.config.JedisClusterConfig
-
Returns nodes.
- getNodes() - Method in class org.apache.storm.scheduler.resource.RasNodes
- getNodeToHost() - Method in class org.apache.storm.task.WorkerTopologyContext
-
Get a map from nodeId to hostname.
- getNonBlacklistedAvailableSlots(List<String>) - Method in class org.apache.storm.scheduler.Cluster
- getNonBlacklistedAvailableSlots(List<String>) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all the available worker slots in the cluster, that are not blacklisted.
- getNonBlacklistedClusterAvailableResources(Collection<String>) - Method in class org.apache.storm.scheduler.Cluster
- getNonBlacklistedClusterAvailableResources(Collection<String>) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the resources in the cluster that are available for scheduling.
- getNormalizedResources() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- getNormalizedResources() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- getNormalizedResources() - Method in interface org.apache.storm.scheduler.resource.normalization.NormalizedResourcesWithMemory
- getNotifyOnRelease() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getNotifyOnRelease() - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
to get the notify_on_release config.
- getNthUncommittedOffsetAfterCommittedOffset(int) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
-
Gets the offset of the nth emitted message after the committed offset.
- getNumAcked(String) - Static method in class org.apache.storm.testing.FixedTupleSpout
- getNumAcked(String) - Static method in class org.apache.storm.testing.TestEventLogSpout
- getNumAcks() - Method in class org.apache.storm.testing.AckTracker
- getNumaIdForPort(Integer, Map<String, Object>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
-
getNumaIdForPort for a specific supervisor.
- getNumaMap(Map<String, Object>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
-
Return supervisor numa configuration.
- getNumaPorts(Map<String, Object>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
-
gets the set of all configured numa ports for a specific supervisor.
- getNumBacktrack() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getNumExecutors() - Method in class org.apache.storm.perf.utils.MetricsSample
- getNumExistingSchedule(String) - Method in interface org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorter.ExistingScheduleFunc
- getNumExistingSchedule(String) - Method in interface org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity.ExistingScheduleFunc
- getNumFailed(String) - Static method in class org.apache.storm.testing.FixedTupleSpout
- getNumFailed(String) - Static method in class org.apache.storm.testing.TestEventLogSpout
- getNumOfAckersToBind(ExecutorDetails, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Determine how many bound ackers to put in before assigning the executor to current workerSlot.
- getNumSupervisors() - Method in class org.apache.storm.perf.utils.MetricsSample
- getNumTasks() - Method in class org.apache.storm.flux.model.VertexDef
- getNumTasks() - Method in class org.apache.storm.perf.utils.MetricsSample
- getNumThreads(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getNumToposCached() - Method in class org.apache.storm.daemon.nimbus.HeartbeatCache
-
Get the number of topologies with cached heartbeats.
- getNumUncommittedOffsets() - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
- getNumWorkers() - Method in class org.apache.storm.perf.utils.MetricsSample
- getNumWorkers() - Method in class org.apache.storm.scheduler.TopologyDetails
- getObject() - Method in interface org.apache.storm.starter.tools.Rankable
- getObject() - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
- getObject() - Method in class org.apache.storm.utils.MutableObject
- getObjectResources() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesSummary
- getOciRuntimeConfig() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getOffHeapMemoryLoad() - Method in class org.apache.storm.flux.model.VertexDef
- getOffHeapMemoryMb() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- getOffHeapMemoryRequirement(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Gets the off heap memory requirement for a certain task within a topology.
- getOffsetLags(NewKafkaSpoutOffsetQuery) - Static method in class org.apache.storm.kafka.monitor.KafkaOffsetLagUtil
-
Get offset lags.
- getOffsetsCommitPeriodMs() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getOnHeapMemoryLoad() - Method in class org.apache.storm.flux.model.VertexDef
- getOnHeapMemoryMb() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- getOnHeapMemoryRequirement(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Gets the on heap memory requirement for a certain task within a topology.
- getOpenOrPrepareWasCalled() - Method in class org.apache.storm.executor.Executor
- getOperandList() - Method in class org.apache.storm.sql.parser.SqlCreateFunction
- getOperandList() - Method in class org.apache.storm.sql.parser.SqlCreateTable
- getOperator() - Method in class org.apache.storm.sql.parser.SqlCreateFunction
- getOperator() - Method in class org.apache.storm.sql.parser.SqlCreateTable
- getOrderedPartitions(List<Map<String, Object>>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentOpaqueSpoutEmitter
- getOrderedPartitions(List<Map<String, Object>>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutEmitter
-
Get the input partitions in sorted order.
- getOrderedPartitions(List<Map<String, Object>>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentTransactionalSpoutEmitter
- getOrderedPartitions(PartitionsT) - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Emitter
-
Sorts the partition info to produce an ordered list of partition.
- getOrderedPartitions(PartitionsT) - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Emitter
-
Sorts given partition info to produce an ordered list of partitions.
- getOrderedTopologies(ISchedulingState, Map<String, User>) - Method in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy
- getOrderedTopologies(ISchedulingState, Map<String, User>) - Method in class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy
- getOrderedTopologies(ISchedulingState, Map<String, User>) - Method in interface org.apache.storm.scheduler.resource.strategies.priority.ISchedulingPriorityStrategy
-
Prioritize the list of all topologies in the cluster.
- getOrError(Map<String, Object>, String) - Static method in class org.apache.storm.kafka.migration.MapUtil
-
Get value for key.
- getOtherField() - Method in class org.apache.storm.bolt.JoinBolt.JoinInfo
- getOtherStream() - Method in class org.apache.storm.bolt.JoinBolt.JoinInfo
- getOutboundTasks() - Method in class org.apache.storm.daemon.worker.WorkerState
- getOutgoingTasks(Integer, String, List<Object>) - Method in class org.apache.storm.daemon.Task
- getOutgoingTasks(String, List<Object>) - Method in class org.apache.storm.daemon.Task
- getOutput() - Method in class org.apache.storm.utils.ShellUtils.ShellCommandExecutor
-
Get the output of the shell command.
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.AggregateProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.AppendCollector
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.EachProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.FreshCollector
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.MapProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.MultiReducerProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.PartitionPersistProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.ProjectedProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.processor.StateQueryProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.planner.SubtopologyBolt.InitialReceiver
- getOutputFactory() - Method in interface org.apache.storm.trident.planner.TridentProcessor
- getOutputFactory() - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- getOutputFields() - Method in class org.apache.storm.bolt.JoinBolt.ResultRecord
- getOutputFields() - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
- getOutputFields() - Method in class org.apache.storm.jms.trident.TridentJmsSpout
- getOutputFields() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutOpaque
- getOutputFields() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTransactional
- getOutputFields() - Method in interface org.apache.storm.spout.MultiScheme
- getOutputFields() - Method in class org.apache.storm.spout.RawMultiScheme
- getOutputFields() - Method in class org.apache.storm.spout.RawScheme
- getOutputFields() - Method in interface org.apache.storm.spout.Scheme
- getOutputFields() - Method in class org.apache.storm.spout.SchemeAsMultiScheme
- getOutputFields() - Method in class org.apache.storm.sql.runtime.serde.avro.AvroScheme
- getOutputFields() - Method in class org.apache.storm.sql.runtime.serde.csv.CsvScheme
- getOutputFields() - Method in class org.apache.storm.sql.runtime.serde.json.JsonScheme
- getOutputFields() - Method in class org.apache.storm.sql.runtime.serde.tsv.TsvScheme
- getOutputFields() - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
- getOutputFields() - Method in class org.apache.storm.streams.WindowNode
- getOutputFields() - Method in class org.apache.storm.testing.TestEventOrderCheckBolt
- getOutputFields() - Method in class org.apache.storm.testing.TestGlobalCount
- getOutputFields() - Method in class org.apache.storm.testing.TestPlannerBolt
- getOutputFields() - Method in class org.apache.storm.testing.TestPlannerSpout
- getOutputFields() - Method in class org.apache.storm.trident.fluent.GroupedStream
- getOutputFields() - Method in interface org.apache.storm.trident.fluent.IAggregatableStream
- getOutputFields() - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor
- getOutputFields() - Method in interface org.apache.storm.trident.spout.IBatchSpout
- getOutputFields() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout
- getOutputFields() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout
- getOutputFields() - Method in interface org.apache.storm.trident.spout.ITridentSpout
- getOutputFields() - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor
- getOutputFields() - Method in class org.apache.storm.trident.spout.PartitionedTridentSpoutExecutor
- getOutputFields() - Method in class org.apache.storm.trident.spout.RichSpoutBatchExecutor
- getOutputFields() - Method in class org.apache.storm.trident.Stream
- getOutputFields() - Method in class org.apache.storm.trident.testing.FeederBatchSpout
- getOutputFields() - Method in class org.apache.storm.trident.testing.FeederCommitterBatchSpout
- getOutputFields() - Method in class org.apache.storm.trident.testing.FixedBatchSpout
- getOutputFields() - Method in interface org.apache.storm.trident.tuple.TridentTuple.Factory
- getOutputFields() - Method in class org.apache.storm.trident.tuple.TridentTupleView.FreshOutputFactory
- getOutputFields() - Method in class org.apache.storm.trident.tuple.TridentTupleView.OperationOutputFactory
- getOutputFields() - Method in class org.apache.storm.trident.tuple.TridentTupleView.ProjectionFactory
- getOutputFields() - Method in class org.apache.storm.trident.tuple.TridentTupleView.RootFactory
- getOutputFields(KafkaTridentSpoutConfig<K, V>) - Method in class org.apache.storm.kafka.spout.trident.internal.OutputFieldsExtractor
-
Extract the output fields from the config.
- getOutputName() - Method in class org.apache.storm.bolt.JoinBolt.FieldSelector
- getOutputStream() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getOutputStream() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getOutputStream() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- getOutputStream(File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Get an output stream to write to a given file.
- getOutputStream(File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Get an output stream to write to a given file.
- getOutputter() - Method in class org.apache.storm.topology.BasicOutputCollector
- getOutStreamId() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getOverflowCount() - Method in class org.apache.storm.utils.JCQueue
- getOverrideServiceId() - Static method in class org.apache.storm.utils.DRPCClient
-
Get override service ID.
- getOwner() - Method in interface org.apache.storm.localizer.PortAndAssignment
- getOwner() - Method in class org.apache.storm.localizer.TimePortAndAssignment
- getOwnerResource(String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/owner-resources/:id -> owner resources.
- getOwnerResources(String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/owner-resources -> owner resources.
- getOwnerResourceSummaries() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getOwnerResourceSummaries
- getOwnerResourceSummaries() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getOwnerResourceSummaries
- getOwnerResourceSummaries(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getOwnerResourceSummaries(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getOwnerResourceSummaries(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getOwnerResourceSummaries(String) - Method in class org.apache.storm.LocalCluster
- getOwnerResourceSummaries(String, AsyncMethodCallback<List<OwnerResourceSummary>>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getOwnerResourceSummaries(String, AsyncMethodCallback<List<OwnerResourceSummary>>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getOwnerResourceSummaries(List<OwnerResourceSummary>, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get prettified ownerResourceSummaries.
- getOwnerResourceSummaries_args() - Constructor for class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- getOwnerResourceSummaries_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- getOwnerResourceSummaries_args(Nimbus.getOwnerResourceSummaries_args) - Constructor for class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
-
Performs a deep copy on other.
- getOwnerResourceSummaries_call(String, AsyncMethodCallback<List<OwnerResourceSummary>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getOwnerResourceSummaries_call
- getOwnerResourceSummaries_result() - Constructor for class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- getOwnerResourceSummaries_result(List<OwnerResourceSummary>, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- getOwnerResourceSummaries_result(Nimbus.getOwnerResourceSummaries_result) - Constructor for class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
-
Performs a deep copy on other.
- getOwnerResourceSummary(List<OwnerResourceSummary>, Nimbus.Iface, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get a specific owner resource summary.
- getParallelism() - Method in class org.apache.storm.flux.model.VertexDef
- getParallelism() - Method in class org.apache.storm.loadgen.LoadCompConf.Builder
- getParallelism() - Method in class org.apache.storm.Thrift.BoltDetails
- getParallelism() - Method in class org.apache.storm.Thrift.SpoutDetails
- getParallelismHint(ComponentCommon) - Static method in class org.apache.storm.Thrift
- getParent() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getParent(DirectedGraph, T) - Static method in class org.apache.storm.trident.util.TridentUtils
- getParents() - Method in class org.apache.storm.scheduler.Component
- getParents(DirectedGraph<Node, Edge>, Node) - Static method in class org.apache.storm.streams.StreamUtil
- getParents(DirectedGraph, T) - Static method in class org.apache.storm.trident.util.TridentUtils
-
Assumes edge contains an index.
- getParentStreams() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getParentTupleFactories() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getPartition() - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- getPartitionedSpout() - Method in class org.apache.storm.trident.spout.PartitionedTridentSpoutExecutor
- getPartitionIndex() - Method in class org.apache.storm.trident.operation.TridentOperationContext
- getPartitionPath(Tuple) - Method in class org.apache.storm.hdfs.common.NullPartitioner
- getPartitionPath(Tuple) - Method in interface org.apache.storm.hdfs.common.Partitioner
-
Return a relative path that the tuple should be written to.
- getPartitionRefreshPeriodMs() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getPartitionsForBatch() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutCoordinator
- getPartitionsForBatch() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Coordinator
-
Gets the partitions for the following batches.
- getPartitionsForBatch() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Coordinator
-
Return the partitions currently in the source of data.
- getPartitionsForTask(int, int, List<KafkaTridentSpoutTopicPartition>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentOpaqueSpoutEmitter
- getPartitionsForTask(int, int, List<KafkaTridentSpoutTopicPartition>) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutEmitter
-
Get the partitions that should be handled by this task.
- getPartitionsForTask(int, int, List<PartitionT>) - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Emitter
-
Get the partitions assigned to this task.
- getPartitionsForTask(int, int, List<PartitionT>) - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Emitter
-
Get the partitions assigned to the given task.
- getPartitionsForThisTask(List<TopicPartition>, TopologyContext) - Method in interface org.apache.storm.kafka.spout.subscription.ManualPartitioner
-
Filter the list of all partitions handled by this set of spouts to get only the partitions assigned to this task.
- getPartitionsForThisTask(List<TopicPartition>, TopologyContext) - Method in class org.apache.storm.kafka.spout.subscription.RoundRobinManualPartitioner
- getPassword() - Method in class org.apache.storm.redis.common.config.JedisClusterConfig
-
Returns password.
- getPassword() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig
-
Returns password.
- getPasswordFailuresMeter() - Static method in class org.apache.storm.security.auth.workertoken.WorkerTokenAuthorizer
- getPasswordFor(String) - Method in class org.apache.storm.security.auth.digest.JassPasswordProvider
- getPasswordFor(String) - Method in interface org.apache.storm.security.auth.sasl.PasswordProvider
-
Get an optional password for a user.
- getPasswordFor(String) - Method in class org.apache.storm.security.auth.workertoken.WorkerTokenAuthorizer
- getPath() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciLayer
- getPath() - Method in class org.apache.storm.container.oci.OciResource
- getPath() - Method in class org.apache.storm.hdfs.bolt.format.DefaultFileNameFormat
- getPath() - Method in interface org.apache.storm.hdfs.bolt.format.FileNameFormat
- getPath() - Method in class org.apache.storm.hdfs.bolt.format.SimpleFileNameFormat
- getPath() - Method in class org.apache.storm.hdfs.trident.format.DefaultFileNameFormat
- getPath() - Method in interface org.apache.storm.hdfs.trident.format.FileNameFormat
- getPath() - Method in class org.apache.storm.hdfs.trident.format.SimpleFileNameFormat
- getPath() - Method in class org.apache.storm.testing.TmpPath
- getPathOwnerUid(String) - Static method in class org.apache.storm.utils.ServerUtils
-
Get the userId of the onwer of the path by running "ls -dn path" command.
- getPendingCount() - Method in class org.apache.storm.executor.spout.SpoutOutputCollectorImpl
- getPendingCount() - Method in interface org.apache.storm.spout.ISpoutOutputCollector
- getPendingCount() - Method in class org.apache.storm.spout.SpoutOutputCollector
- getPendingEmits() - Method in class org.apache.storm.executor.Executor
- getPendingTopologies(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getPendingTriggers() - Method in class org.apache.storm.trident.windowing.AbstractTridentWindowManager
- getPendingTriggers() - Method in interface org.apache.storm.trident.windowing.ITridentWindowManager
-
Returns pending triggers to be emitted.
- getPerCpuUsage() - Method in class org.apache.storm.container.cgroup.core.CpuacctCore
- getPhysicalFailCount() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getPhysicalUsage() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getPhysicalUsageLimit() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getPid() - Method in class org.apache.storm.utils.ShellProcess
-
Get PID.
- getPIDDir() - Method in class org.apache.storm.task.WorkerTopologyContext
-
If this task spawns any subprocesses, those subprocesses must immediately write their PID to this directory on the local filesystem to ensure that Storm properly destroys that process when the worker is shutdown.
- getPidFile() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getPids() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getPids() - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
get the PIDs of processes running in cgroup.
- getPlan(String) - Method in class org.apache.storm.sql.planner.streams.QueryPlanner
- getPollTimeoutMs() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getPort() - Method in class org.apache.storm.daemon.worker.WorkerState
- getPort() - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- getPort() - Method in class org.apache.storm.loadgen.HttpForwardingMetricsServer
- getPort() - Method in interface org.apache.storm.localizer.PortAndAssignment
- getPort() - Method in class org.apache.storm.localizer.TimePortAndAssignment
- getPort() - Method in interface org.apache.storm.messaging.IConnection
-
Get the port for this connection.
- getPort() - Method in class org.apache.storm.messaging.netty.Client
- getPort() - Method in class org.apache.storm.metricstore.FilterOptions
- getPort() - Method in class org.apache.storm.metricstore.Metric
- getPort() - Method in class org.apache.storm.nimbus.NimbusInfo
- getPort() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig
-
Returns port.
- getPort() - Method in class org.apache.storm.scheduler.WorkerSlot
- getPort() - Method in interface org.apache.storm.security.auth.ITransportPlugin
-
Get port.
- getPort() - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin
- getPort() - Method in class org.apache.storm.security.auth.SimpleTransportPlugin
- getPort() - Method in class org.apache.storm.security.auth.ThriftServer
-
Get port.
- getPort() - Method in class org.apache.storm.security.auth.tls.TlsTransportPlugin
- getPort() - Method in class org.apache.storm.testing.InProcessZookeeper
-
Get port.
- getPort() - Method in class org.apache.storm.utils.DRPCClient
- getPort(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getPortsPerSupervisor() - Method in class org.apache.storm.testing.MkClusterParam
- getPos() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- getPreparableReporters(Map<String, Object>) - Static method in class org.apache.storm.daemon.metrics.MetricsUtils
- getPrettifiedSupervisorMap(SupervisorSummary, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get supervisor info in a map.
- getPrev() - Method in class org.apache.storm.trident.state.OpaqueValue
- getPreviousState(long) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
- getPrincipalToLocalPlugin(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Construct a principal to local plugin.
- getPrioId() - Method in class org.apache.storm.container.cgroup.core.NetPrioCore
- getPrivateKey() - Method in class org.apache.storm.security.auth.ThriftClient
-
Get the private key using BouncyCastle library from a PKCS#1 format file.
- getPrivateKey(String) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- getPrivateWorkerKey(WorkerTokenServiceType, String, long) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get a private key used to validate a token is correct.
- getPrivateWorkerKey(WorkerTokenServiceType, String, long) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- getProcess() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getProcess() - Method in class org.apache.storm.utils.ShellUtils
-
get the current sub-process executing the given command.
- getProcessInfoString() - Method in class org.apache.storm.utils.ShellProcess
- getProcessingGuarantee() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getProcessLatencies() - Method in class org.apache.storm.stats.BoltExecutorStats
- getProcessor() - Method in class org.apache.storm.security.auth.ThriftServer
- getProcessor() - Method in class org.apache.storm.streams.ProcessorNode
- getProcessSampleStartTime() - Method in class org.apache.storm.tuple.TupleImpl
- getProcessTerminationInfoString() - Method in class org.apache.storm.utils.ShellProcess
- getProcessTime() - Method in class org.apache.storm.loadgen.InputStream.Builder
- getProducer() - Method in interface org.apache.storm.sql.runtime.ISqlStreamsDataSource
-
Provides instance of IRichSpout which can be used as producer in topology.
- getProfileActions(IStormClusterState, List<String>) - Method in class org.apache.storm.daemon.supervisor.ReadClusterState
- getProfilingDisabled() - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getProfilingDisabled.
- getProperties() - Method in class org.apache.storm.flux.model.ObjectDef
- getPunctuationFields() - Static method in class org.apache.storm.streams.StreamUtil
- getPunctuationStream(String) - Static method in class org.apache.storm.streams.StreamUtil
- getQueryProvider() - Method in class org.apache.storm.sql.runtime.calcite.StormDataContext
- getQueuedCount() - Method in class org.apache.storm.utils.JCQueue
- getQueueLoad() - Method in class org.apache.storm.utils.JCQueue
- getQueueName() - Method in class org.apache.storm.utils.JCQueue
- getQueueSize(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getRackIdToHosts() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
- getRankings() - Method in class org.apache.storm.starter.bolt.AbstractRankerBolt
- getRankings() - Method in class org.apache.storm.starter.tools.Rankings
-
The returned defensive copy is only "somewhat" defensive.
- getRate() - Method in class org.apache.storm.loadgen.OutputStream.Builder
- getRate() - Method in class org.apache.storm.stats.CommonStats
- getRateCounterUpdateIntervalSeconds() - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getRawTopology() - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the Thrift object representing the topology.
- getReadBps() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getReadClusterState() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getReadIOps() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getReapLayerKeepCount() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getReceiveQueue() - Method in class org.apache.storm.executor.Executor
- getReceiveQueue() - Method in class org.apache.storm.executor.ExecutorShutdown
- getReceiveQueue() - Method in interface org.apache.storm.executor.IRunningExecutor
- getReceiver() - Method in class org.apache.storm.daemon.worker.WorkerState
- getReceivers() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getRecords() - Method in class org.apache.storm.bolt.JoinBolt.JoinAccumulator
- getRef() - Method in class org.apache.storm.flux.model.PropertyDef
- getReferenceTime() - Method in class org.apache.storm.windowing.DefaultEvictionContext
- getReferenceTime() - Method in interface org.apache.storm.windowing.EvictionContext
-
Returns the reference time that the eviction policy could use to evict the events.
- getRegisteredMetricByName(String) - Method in class org.apache.storm.task.TopologyContext
-
Deprecated.
- getRegistry() - Method in interface org.apache.storm.metrics2.MetricRegistryProvider
- getRegistry() - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getReleaseAgent() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getReleaseAgent() - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
get the command for the relase agent to execute.
- getRemoteBlobstoreUpdateTime() - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Client facing API to get the last update time of existing blobs in a blobstore.
- getRemoteBlobstoreUpdateTime() - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- getRemoteBlobstoreUpdateTime() - Method in class org.apache.storm.blobstore.NimbusBlobStore
- getRemoteBlobstoreUpdateTime() - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- getRemoteVersion(ClientBlobStore) - Method in class org.apache.storm.localizer.LocalizedResource
- getRemoteVersion(ClientBlobStore) - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Get the version of the blob in the blob store.
- getRemoteVersion(ClientBlobStore) - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- getRepeat(List<String>) - Static method in class org.apache.storm.utils.Utils
- getReporter() - Method in class org.apache.storm.metrics.prometheus.PrometheusPreparableReporter
- getReportError() - Method in class org.apache.storm.executor.Executor
- getReportPeriod(Map<String, Object>) - Static method in class org.apache.storm.metrics2.reporters.ScheduledStormReporter
- getReportPeriodUnit(Map<String, Object>) - Static method in class org.apache.storm.metrics2.reporters.ScheduledStormReporter
- getRequest() - Method in class org.apache.storm.daemon.drpc.OutstandingRequest
- getRequestedCpu() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedGenericResources() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedMemOffHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedMemOnHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedNonSharedMemOffHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedNonSharedMemOnHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedNonSharedOffHeap() - Method in class org.apache.storm.scheduler.TopologyDetails
- getRequestedNonSharedOnHeap() - Method in class org.apache.storm.scheduler.TopologyDetails
- getRequestedSharedMemOffHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedSharedMemOnHeap() - Method in class org.apache.storm.daemon.nimbus.TopologyResources
- getRequestedSharedOffHeap() - Method in class org.apache.storm.scheduler.TopologyDetails
- getRequestedSharedOnHeap() - Method in class org.apache.storm.scheduler.TopologyDetails
- getReservedMemoryMb(String) - Method in class org.apache.storm.daemon.supervisor.ContainerMemoryTracker
-
Gets the memory reserved by the given topology across all ports on this supervisor.
- getResource(String) - Method in class org.apache.storm.task.WorkerTopologyContext
-
Fetches the worker-level data for the given name.
- getResourceFromClassloader(String) - Static method in class org.apache.storm.utils.ServerUtils
-
Returns the current thread classloader.
- getResourceFromClassloaderImpl(String) - Method in class org.apache.storm.utils.ServerUtils
- getResourceMetrics() - Method in class org.apache.storm.scheduler.Cluster
- getResourceNameMapping() - Method in class org.apache.storm.scheduler.resource.normalization.ResourceNameNormalizer
- getResourceNamesToArrayIndex() - Method in class org.apache.storm.scheduler.resource.normalization.ResourceMapArrayBridge
- getResourcePoolAverageUtilization(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getResources() - Method in class org.apache.storm.trident.operation.DefaultResourceDeclarer
- getResources() - Method in interface org.apache.storm.trident.operation.ITridentResource
-
Get resource.
- getResources(Map<String, Number>) - Method in class org.apache.storm.trident.graph.Group
-
In case no resources are specified, returns empty map.
- getResponse(Exception, Provider<HttpServletRequest>) - Static method in class org.apache.storm.daemon.ui.exceptionmappers.ExceptionMapperUtils
-
getResponse.
- getResponse(Exception, Response.Status, Provider<HttpServletRequest>) - Static method in class org.apache.storm.daemon.ui.exceptionmappers.ExceptionMapperUtils
-
getResponse.
- getResponse(AuthorizationException, Provider<HttpServletRequest>) - Static method in class org.apache.storm.daemon.ui.exceptionmappers.ExceptionMapperUtils
-
getResponse.
- getResult() - Method in class org.apache.storm.daemon.drpc.BlockingOutstandingRequest
- getResult() - Method in class org.apache.storm.generated.DistributedRPC.AsyncClient.execute_call
- getResult() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.failRequest_call
- getResult() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.failRequestV2_call
- getResult() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.fetchRequest_call
- getResult() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient.result_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.activate_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.beginBlobDownload_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.beginCreateBlob_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.beginFileUpload_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.beginUpdateBlob_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.cancelBlobUpload_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.createStateInZookeeper_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.deactivate_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.debug_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.deleteBlob_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.downloadBlobChunk_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.downloadChunk_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.finishBlobUpload_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.finishFileUpload_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getBlobMeta_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getBlobReplication_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getClusterInfo_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getComponentPageInfo_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getComponentPendingProfileActions_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getLeader_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getLogConfig_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getNimbusConf_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getOwnerResourceSummaries_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getSupervisorAssignments_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getSupervisorPageInfo_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopology_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyConf_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyHistory_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfo_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfoByName_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfoByNameWithOpts_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfoWithOpts_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyPageInfo_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologySummaries_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologySummary_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getTopologySummaryByName_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.getUserTopology_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.isRemoteBlobExists_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.isTopologyNameAllowed_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.killTopology_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.killTopologyWithOpts_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.listBlobs_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.processWorkerMetrics_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.rebalance_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.sendSupervisorWorkerHeartbeat_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.sendSupervisorWorkerHeartbeats_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.setBlobMeta_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.setLogConfig_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.setWorkerProfiler_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.submitTopology_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.submitTopologyWithOpts_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.updateBlobReplication_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.uploadBlobChunk_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.uploadChunk_call
- getResult() - Method in class org.apache.storm.generated.Nimbus.AsyncClient.uploadNewCredentials_call
- getResult() - Method in class org.apache.storm.generated.Supervisor.AsyncClient.getLocalAssignmentForStorm_call
- getResult() - Method in class org.apache.storm.generated.Supervisor.AsyncClient.sendSupervisorAssignments_call
- getResult() - Method in class org.apache.storm.generated.Supervisor.AsyncClient.sendSupervisorWorkerHeartbeat_call
- getResult(I, DistributedRPC.execute_args) - Method in class org.apache.storm.generated.DistributedRPC.Processor.execute
- getResult(I, DistributedRPCInvocations.failRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequest
- getResult(I, DistributedRPCInvocations.failRequestV2_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequestV2
- getResult(I, DistributedRPCInvocations.fetchRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.fetchRequest
- getResult(I, DistributedRPCInvocations.result_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.result
- getResult(I, Nimbus.activate_args) - Method in class org.apache.storm.generated.Nimbus.Processor.activate
- getResult(I, Nimbus.beginBlobDownload_args) - Method in class org.apache.storm.generated.Nimbus.Processor.beginBlobDownload
- getResult(I, Nimbus.beginCreateBlob_args) - Method in class org.apache.storm.generated.Nimbus.Processor.beginCreateBlob
- getResult(I, Nimbus.beginFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.Processor.beginFileUpload
- getResult(I, Nimbus.beginUpdateBlob_args) - Method in class org.apache.storm.generated.Nimbus.Processor.beginUpdateBlob
- getResult(I, Nimbus.cancelBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.Processor.cancelBlobUpload
- getResult(I, Nimbus.createStateInZookeeper_args) - Method in class org.apache.storm.generated.Nimbus.Processor.createStateInZookeeper
- getResult(I, Nimbus.deactivate_args) - Method in class org.apache.storm.generated.Nimbus.Processor.deactivate
- getResult(I, Nimbus.debug_args) - Method in class org.apache.storm.generated.Nimbus.Processor.debug
- getResult(I, Nimbus.deleteBlob_args) - Method in class org.apache.storm.generated.Nimbus.Processor.deleteBlob
- getResult(I, Nimbus.downloadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.Processor.downloadBlobChunk
- getResult(I, Nimbus.downloadChunk_args) - Method in class org.apache.storm.generated.Nimbus.Processor.downloadChunk
- getResult(I, Nimbus.finishBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.Processor.finishBlobUpload
- getResult(I, Nimbus.finishFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.Processor.finishFileUpload
- getResult(I, Nimbus.getBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getBlobMeta
- getResult(I, Nimbus.getBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getBlobReplication
- getResult(I, Nimbus.getClusterInfo_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getClusterInfo
- getResult(I, Nimbus.getComponentPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getComponentPageInfo
- getResult(I, Nimbus.getComponentPendingProfileActions_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getComponentPendingProfileActions
- getResult(I, Nimbus.getLeader_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getLeader
- getResult(I, Nimbus.getLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getLogConfig
- getResult(I, Nimbus.getNimbusConf_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getNimbusConf
- getResult(I, Nimbus.getOwnerResourceSummaries_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getOwnerResourceSummaries
- getResult(I, Nimbus.getSupervisorAssignments_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getSupervisorAssignments
- getResult(I, Nimbus.getSupervisorPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getSupervisorPageInfo
- getResult(I, Nimbus.getTopology_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopology
- getResult(I, Nimbus.getTopologyConf_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyConf
- getResult(I, Nimbus.getTopologyHistory_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyHistory
- getResult(I, Nimbus.getTopologyInfo_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfo
- getResult(I, Nimbus.getTopologyInfoByName_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByName
- getResult(I, Nimbus.getTopologyInfoByNameWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByNameWithOpts
- getResult(I, Nimbus.getTopologyInfoWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoWithOpts
- getResult(I, Nimbus.getTopologyPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyPageInfo
- getResult(I, Nimbus.getTopologySummaries_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummaries
- getResult(I, Nimbus.getTopologySummary_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummary
- getResult(I, Nimbus.getTopologySummaryByName_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummaryByName
- getResult(I, Nimbus.getUserTopology_args) - Method in class org.apache.storm.generated.Nimbus.Processor.getUserTopology
- getResult(I, Nimbus.isRemoteBlobExists_args) - Method in class org.apache.storm.generated.Nimbus.Processor.isRemoteBlobExists
- getResult(I, Nimbus.isTopologyNameAllowed_args) - Method in class org.apache.storm.generated.Nimbus.Processor.isTopologyNameAllowed
- getResult(I, Nimbus.killTopology_args) - Method in class org.apache.storm.generated.Nimbus.Processor.killTopology
- getResult(I, Nimbus.killTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.Processor.killTopologyWithOpts
- getResult(I, Nimbus.listBlobs_args) - Method in class org.apache.storm.generated.Nimbus.Processor.listBlobs
- getResult(I, Nimbus.processWorkerMetrics_args) - Method in class org.apache.storm.generated.Nimbus.Processor.processWorkerMetrics
- getResult(I, Nimbus.rebalance_args) - Method in class org.apache.storm.generated.Nimbus.Processor.rebalance
- getResult(I, Nimbus.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Nimbus.Processor.sendSupervisorWorkerHeartbeat
- getResult(I, Nimbus.sendSupervisorWorkerHeartbeats_args) - Method in class org.apache.storm.generated.Nimbus.Processor.sendSupervisorWorkerHeartbeats
- getResult(I, Nimbus.setBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.Processor.setBlobMeta
- getResult(I, Nimbus.setLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.Processor.setLogConfig
- getResult(I, Nimbus.setWorkerProfiler_args) - Method in class org.apache.storm.generated.Nimbus.Processor.setWorkerProfiler
- getResult(I, Nimbus.submitTopology_args) - Method in class org.apache.storm.generated.Nimbus.Processor.submitTopology
- getResult(I, Nimbus.submitTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.Processor.submitTopologyWithOpts
- getResult(I, Nimbus.updateBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.Processor.updateBlobReplication
- getResult(I, Nimbus.uploadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.Processor.uploadBlobChunk
- getResult(I, Nimbus.uploadChunk_args) - Method in class org.apache.storm.generated.Nimbus.Processor.uploadChunk
- getResult(I, Nimbus.uploadNewCredentials_args) - Method in class org.apache.storm.generated.Nimbus.Processor.uploadNewCredentials
- getResult(I, Supervisor.getLocalAssignmentForStorm_args) - Method in class org.apache.storm.generated.Supervisor.Processor.getLocalAssignmentForStorm
- getResult(I, Supervisor.sendSupervisorAssignments_args) - Method in class org.apache.storm.generated.Supervisor.Processor.sendSupervisorAssignments
- getResult(I, Supervisor.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Supervisor.Processor.sendSupervisorWorkerHeartbeat
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.DistributedRPC.AsyncProcessor.execute
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequest
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequestV2
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.fetchRequest
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.result
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.activate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginBlobDownload
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginCreateBlob
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginFileUpload
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginUpdateBlob
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.cancelBlobUpload
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.createStateInZookeeper
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.deactivate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.debug
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.deleteBlob
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadBlobChunk
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadChunk
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.finishBlobUpload
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.finishFileUpload
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobMeta
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobReplication
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getClusterInfo
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPageInfo
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPendingProfileActions
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getLeader
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getLogConfig
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getNimbusConf
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getOwnerResourceSummaries
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorAssignments
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorPageInfo
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopology
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyConf
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyHistory
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfo
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByName
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByNameWithOpts
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoWithOpts
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyPageInfo
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaries
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummary
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaryByName
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getUserTopology
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.isRemoteBlobExists
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.isTopologyNameAllowed
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.killTopology
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.killTopologyWithOpts
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.listBlobs
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.processWorkerMetrics
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.rebalance
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.sendSupervisorWorkerHeartbeat
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.sendSupervisorWorkerHeartbeats
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setBlobMeta
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setLogConfig
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setWorkerProfiler
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.submitTopology
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.submitTopologyWithOpts
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.updateBlobReplication
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadBlobChunk
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadChunk
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadNewCredentials
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.getLocalAssignmentForStorm
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.sendSupervisorAssignments
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.sendSupervisorWorkerHeartbeat
- getResults() - Method in class org.apache.storm.testing.TupleCaptureBolt
- getRetryService() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getRetryService() - Method in class org.apache.storm.kafka.spout.KafkaSpoutTopologyMainNamedTopics
- getRevision() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the SCM revision number of the build.
- getRevision() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the SCM revision number of the build.
- getRightStream() - Method in class org.apache.storm.streams.processors.JoinProcessor
- getRoot() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig.OciRuntimeConfig
- getRoot() - Method in class org.apache.storm.utils.VersionedStore
- getRootCgroups() - Method in class org.apache.storm.container.cgroup.Hierarchy
- getRootId() - Method in class org.apache.storm.executor.TupleInfo
- getRootSchema() - Method in class org.apache.storm.sql.runtime.calcite.StormDataContext
- getRuleSets() - Static method in class org.apache.storm.sql.planner.streams.StreamsStormRuleSets
- getRunningTopologies() - Method in class org.apache.storm.scheduler.multitenant.Node
-
Get running topologies.
- getRunningTopologies() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Get a collection of the topology ids currently running on this node.
- getRunningTopologies(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getRunningTopologyWithLowestPriority(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- getSampleTime() - Method in class org.apache.storm.perf.utils.MetricsSample
- getSaslClient() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- getSaslMechanism() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- getSaslServer() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- getSaslToken() - Method in class org.apache.storm.messaging.netty.SaslMessageToken
-
Read accessor for SASL token.
- getSchedRelaxDomainLevel() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- getScheduledCpuForNode(String) - Method in class org.apache.storm.scheduler.Cluster
- getScheduledCpuForNode(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the total cpu currently scheduled on a node.
- getScheduledExecCntByRackId() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
- getScheduledMemoryForNode(String) - Method in class org.apache.storm.scheduler.Cluster
- getScheduledMemoryForNode(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the total memory currently scheduled on a node.
- getScheduledResources() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Get the slot to resource mapping.
- getScheduledResources() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getSchedulerMeta() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getSchema() - Method in class org.apache.storm.sql.StormSqlContext
- getSchema(String) - Method in interface org.apache.storm.hdfs.avro.AvroSchemaRegistry
- getSchema(String) - Method in class org.apache.storm.hdfs.avro.FixedAvroSerializer
- getSchema(String) - Method in class org.apache.storm.hdfs.avro.GenericAvroSerializer
- getSchema(String) - Method in class org.apache.storm.sql.runtime.serde.avro.CachedSchemas
-
Get a schema based on schema string.
- getSchemaVersion() - Method in class org.apache.storm.container.oci.ImageManifest
- getScheme() - Method in interface org.apache.storm.spout.IMultiSchemableSpout
- getScheme() - Method in interface org.apache.storm.spout.ISchemableSpout
- getScheme(String, Properties, List<String>) - Static method in class org.apache.storm.sql.runtime.utils.SerdeUtils
-
Get a Scheme instance based on specific configurations.
- getScore(double, double) - Method in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
- getScore(double, double) - Method in class org.apache.storm.scheduler.resource.strategies.priority.FIFOSchedulingPriorityStrategy.FIFOSimulatedUser
- getScore(double, double, Map<String, Double>) - Method in class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser
- getScore(double, double, Map<String, Double>, TopologyDetails) - Method in class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser
-
Get a score for the simulated user.
- getScore(double, double, TopologyDetails) - Method in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
-
Get a score for the simulated user.
- getSearchString() - Method in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler.Matched
- getSecond() - Method in class org.apache.storm.streams.Pair
-
Returns the second value in a pair.
- getSecurityProtocol() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- getSelfOutputFields() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getSequenceNumber() - Method in class org.apache.storm.blobstore.BlobKeySequenceInfo
- getSerializer() - Method in class org.apache.storm.redis.trident.state.AbstractRedisMapState
-
Returns Serializer which is used for serializing tuple value and deserializing Redis value.
- getSerializer() - Method in class org.apache.storm.redis.trident.state.RedisClusterMapState
-
Returns Serializer which is used for serializing tuple value and deserializing Redis value.
- getSerializer() - Method in class org.apache.storm.redis.trident.state.RedisMapState
-
Returns Serializer which is used for serializing tuple value and deserializing Redis value.
- getSerializer(String, Properties, List<String>) - Static method in class org.apache.storm.sql.runtime.utils.SerdeUtils
-
Get a OutputSerializer instance based on specific configurations.
- getServer(TProcessor) - Method in interface org.apache.storm.security.auth.ITransportPlugin
-
Create a server associated with a given port, service handler, and purpose.
- getServer(TProcessor) - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin
- getServer(TProcessor) - Method in class org.apache.storm.security.auth.SimpleTransportPlugin
- getServer(TProcessor) - Method in class org.apache.storm.security.auth.tls.TlsTransportPlugin
- getServerAliases(String, Principal[]) - Method in class org.apache.storm.security.auth.tls.ReloadableX509KeyManager
- getServerKeyStorePassword(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getServerKeyStorePath(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getServerPort() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getServerSocket(int, int, InetAddress, ThriftConnectionType, Map<String, Object>) - Static method in class org.apache.storm.security.auth.tls.ReloadableTsslTransportFactory
- getServerTransportFactory(boolean) - Method in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
- getServerTransportFactory(boolean) - Method in class org.apache.storm.security.auth.kerberos.KerberosSaslTransportPlugin
- getServerTransportFactory(boolean) - Method in class org.apache.storm.security.auth.plain.PlainSaslTransportPlugin
-
Deprecated.
- getServerTransportFactory(boolean) - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin
-
Create the transport factory needed for serving.
- getServerTrustStorePassword(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getServerTrustStorePath(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getService(String) - Static method in class org.apache.storm.utils.ServiceRegistry
- getServiceId() - Method in interface org.apache.storm.ILocalDRPC
-
Get the ID of the service.
- getServiceId() - Method in class org.apache.storm.LocalDRPC
- getSession() - Method in class org.apache.storm.jms.spout.JmsSpout
-
Returns the currently active session.
- getSetComponentObject(ComponentObject) - Static method in class org.apache.storm.utils.Utils
- getSharedExecutor() - Method in class org.apache.storm.task.WorkerTopologyContext
- getSharedExecutorData() - Method in class org.apache.storm.executor.Executor
- getSharedMemory() - Method in class org.apache.storm.trident.graph.Group
-
Get shared memory.
- getSharedMemory() - Method in class org.apache.storm.trident.operation.DefaultResourceDeclarer
- getSharedMemory() - Method in interface org.apache.storm.trident.operation.ITridentResource
-
Get shared memory.
- getSharedMemoryRequests(Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Gets the total memory resource list for a set of tasks that is part of a topology.
- getShort(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getShort(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the Short at position i in the tuple.
- getShort(int) - Method in class org.apache.storm.tuple.TupleImpl
- getShortByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getShortByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the Short field with a specific name.
- getShortByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getSimulatedUserFor(User, ISchedulingState) - Method in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy
- getSimulatedUserFor(User, ISchedulingState) - Method in class org.apache.storm.scheduler.resource.strategies.priority.FIFOSchedulingPriorityStrategy
- getSimulatedUserFor(User, ISchedulingState) - Method in class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy
- getSingleOutputStreamFields(IComponent) - Static method in class org.apache.storm.trident.util.TridentUtils
- getSingletons() - Method in class org.apache.storm.daemon.drpc.webapp.DRPCApplication
- getSingletons() - Method in class org.apache.storm.daemon.logviewer.webapp.LogviewerApplication
- getSize() - Method in class org.apache.storm.container.oci.OciResource
- getSizeOnDisk() - Method in class org.apache.storm.localizer.LocalizedResource
- getSizeOnDisk() - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Get the amount of disk space that is used by this blob.
- getSizeOnDisk() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- getSizeOnDisk(Path) - Static method in class org.apache.storm.localizer.LocallyCachedBlob
-
Get the size of p in bytes.
- getSizeWithNoReferences() - Method in class org.apache.storm.localizer.LocalizedResourceRetentionSet
- getSkippedMaxSpout(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getSleepTimeMs(int, long) - Method in class org.apache.storm.utils.StormBoundedExponentialBackoffRetry
- getSlidingCount() - Method in class org.apache.storm.windowing.DefaultEvictionContext
- getSlidingCount() - Method in interface org.apache.storm.windowing.EvictionContext
-
Returns the sliding count for count based windows.
- getSlidingCountTimestamps(long, long, int) - Method in class org.apache.storm.windowing.WindowManager
-
Scans the event queue and returns the list of event ts falling between startTs (exclusive) and endTs (inclusive) at each sliding interval counts.
- getSlidingInterval() - Method in class org.apache.storm.streams.windowing.SlidingWindows
-
The sliding interval of the window.
- getSlidingInterval() - Method in class org.apache.storm.streams.windowing.TumblingWindows
- getSlidingInterval() - Method in interface org.apache.storm.streams.windowing.Window
-
The sliding interval of the window.
- getSlidingInterval() - Method in class org.apache.storm.windowing.DefaultEvictionContext
- getSlidingInterval() - Method in interface org.apache.storm.windowing.EvictionContext
-
Returns the sliding interval for time based windows.
- getSlidingLength() - Method in class org.apache.storm.trident.windowing.config.BaseWindowConfig
- getSlidingLength() - Method in interface org.apache.storm.trident.windowing.config.WindowConfig
-
Returns the sliding length of the moving window.
- getSlots() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Get the set of all slots that are a part of this.
- getSlots() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getSlotsAvailableToScheduleOn() - Method in class org.apache.storm.scheduler.resource.RasNode
- getSlotsPorts(Map<String, Object>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
- getSlotToExecutors() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Get the mapping of slot to executors on that slot.
- getSlotToExecutors() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getSocketTimeOut(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getSortedRacks() - Method in interface org.apache.storm.scheduler.resource.strategies.scheduling.sorter.INodeSorter
- getSortedRacks() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorter
-
Racks are sorted by two criteria.
- getSortedRacks() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
-
Racks are sorted by two criteria.
- getSourceComponent() - Method in interface org.apache.storm.tuple.Tuple
-
Gets the id of the component that created this tuple.
- getSourceComponent() - Method in class org.apache.storm.tuple.TupleImpl
- getSourceGlobalStreamId() - Method in interface org.apache.storm.tuple.Tuple
-
Returns the global stream id (component + stream) of this tuple.
- getSourceGlobalStreamId() - Method in class org.apache.storm.tuple.TupleImpl
- getSources() - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- getSources(String) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the declared inputs to the specified component.
- getSourceStream(String) - Static method in class org.apache.storm.streams.StreamUtil
- getSourceStreamId() - Method in interface org.apache.storm.tuple.Tuple
-
Gets the id of the stream that this tuple was emitted to.
- getSourceStreamId() - Method in class org.apache.storm.tuple.TupleImpl
- getSourceTask() - Method in interface org.apache.storm.tuple.Tuple
-
Gets the id of the task that created this tuple.
- getSourceTask() - Method in class org.apache.storm.tuple.TupleImpl
- getSourceTuples() - Method in class org.apache.storm.testing.FixedTupleSpout
- getSpout() - Method in class org.apache.storm.Thrift.SpoutDetails
- getSpoutDef(String) - Method in class org.apache.storm.flux.model.TopologyDef
- getSpoutEmitted() - Method in class org.apache.storm.perf.utils.MetricsSample
- getSpoutEmittedAggregate() - Method in class org.apache.storm.loadgen.TopologyLoadConf
-
Get the messages emitted per second in aggregate for all of the spouts in the topology.
- getSpoutExecutors() - Method in class org.apache.storm.perf.utils.MetricsSample
- getSpoutExecutors() - Method in interface org.apache.storm.st.topology.TestableTopology
- getSpoutExecutors() - Method in class org.apache.storm.st.topology.window.SlidingTimeCorrectness
- getSpoutExecutors() - Method in class org.apache.storm.st.topology.window.SlidingWindowCorrectness
- getSpoutExecutors() - Method in class org.apache.storm.st.topology.window.TumblingTimeCorrectness
- getSpoutExecutors() - Method in class org.apache.storm.st.topology.window.TumblingWindowCorrectness
- getSpoutExecutors(List<ExecutorSummary>, StormTopology) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getSpoutExecutors.
- getSpoutFields() - Static method in class org.apache.storm.Thrift
- getSpoutName() - Method in interface org.apache.storm.st.topology.TestableTopology
- getSpoutName() - Method in class org.apache.storm.st.topology.window.SlidingTimeCorrectness
- getSpoutName() - Method in class org.apache.storm.st.topology.window.SlidingWindowCorrectness
- getSpoutName() - Method in class org.apache.storm.st.topology.window.TumblingTimeCorrectness
- getSpoutName() - Method in class org.apache.storm.st.topology.window.TumblingWindowCorrectness
- getSpoutRecvqCheckSkipCount() - Method in class org.apache.storm.executor.spout.SpoutExecutor
- getSpoutResources(StormTopology, Map<String, Object>, String) - Static method in class org.apache.storm.scheduler.resource.ResourceUtils
- getSpouts() - Method in class org.apache.storm.flux.model.TopologyDef
-
Returns all spout definitions.
- getSpoutsResources(StormTopology, Map<String, Object>) - Static method in class org.apache.storm.scheduler.resource.ResourceUtils
- getSpoutTransferred() - Method in class org.apache.storm.perf.utils.MetricsSample
- getSqlType() - Method in class org.apache.storm.jdbc.common.Column
- getSrcChecksum() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the checksum of the source.
- getSrcChecksum() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the checksum of the source.
- getSrcSupervisorHost() - Method in class org.apache.storm.metric.api.IClusterMetricsConsumer.SupervisorInfo
- getSrcSupervisorId() - Method in class org.apache.storm.metric.api.IClusterMetricsConsumer.SupervisorInfo
- getSslConf(Map<String, Object>) - Static method in class org.apache.storm.utils.CuratorUtils
- getSSLWriteDirFromConf(Map<String, Object>) - Method in class org.apache.storm.security.auth.AutoSSL
- getStartTask() - Method in class org.apache.storm.scheduler.ExecutorDetails
- getStartTime() - Method in class org.apache.storm.metricstore.FilterOptions
- getStartTimeMillis() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getStartTimestamp() - Method in class org.apache.storm.windowing.TupleWindowImpl
- getStartTimestamp() - Method in class org.apache.storm.windowing.TupleWindowIterImpl
- getStartTimestamp() - Method in interface org.apache.storm.windowing.Window
-
Returns the window start timestamp.
- getStartTimeStamp() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getStat() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getStatDisplayMap(Map<String, Double>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getStatDisplayMap.
- getState() - Method in class org.apache.storm.container.cgroup.core.FreezerCore
- getState() - Method in interface org.apache.storm.metric.api.IStatefulObject
- getState() - Method in class org.apache.storm.spout.CheckPointState
- getState() - Method in class org.apache.storm.topology.WindowedBoltExecutor
- getState() - Method in class org.apache.storm.windowing.CountEvictionPolicy
- getState() - Method in class org.apache.storm.windowing.CountTriggerPolicy
- getState() - Method in interface org.apache.storm.windowing.EvictionPolicy
-
Return runtime state to be checkpointed by the framework for restoring the eviction policy in case of failures.
- getState() - Method in class org.apache.storm.windowing.TimeEvictionPolicy
- getState() - Method in class org.apache.storm.windowing.TimeTriggerPolicy
- getState() - Method in interface org.apache.storm.windowing.TriggerPolicy
-
Return runtime state to be checkpointed by the framework for restoring the trigger policy in case of failures.
- getState() - Method in class org.apache.storm.windowing.WatermarkCountEvictionPolicy
- getState() - Method in class org.apache.storm.windowing.WatermarkCountTriggerPolicy
- getState() - Method in class org.apache.storm.windowing.WatermarkTimeTriggerPolicy
- getState() - Method in class org.apache.storm.windowing.WindowManager
- getState(long) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
- getState(long, RotatingTransactionalState.StateInitializer) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
- getState(String) - Static method in class org.apache.storm.utils.RegisteredGlobalState
- getState(String, Map<String, Object>, TopologyContext) - Static method in class org.apache.storm.state.StateFactory
-
Returns a new state instance using the
Config.TOPOLOGY_STATE_PROVIDER
or aInMemoryKeyValueState
if no provider is configured. - getStateIndex() - Method in class org.apache.storm.trident.planner.processor.TridentContext
- getStateName(Watcher.Event.KeeperState) - Static method in class org.apache.storm.zookeeper.ZkKeeperStates
- getStateOrCreate(long, RotatingTransactionalState.StateInitializer) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
-
Returns null if it was created, the value otherwise.
- getStatesSearched() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getStateStorage() - Method in class org.apache.storm.daemon.worker.WorkerState
- getStateValue(String) - Static method in enum class org.apache.storm.container.cgroup.core.FreezerCore.State
- getStatMapFromExecutorSummary(ExecutorSummary) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getStatMapFromExecutorSummary.
- getStats() - Method in class org.apache.storm.cluster.ExecutorBeat
- getStats() - Method in class org.apache.storm.executor.bolt.BoltExecutor
- getStats() - Method in class org.apache.storm.executor.Executor
- getStats() - Method in class org.apache.storm.executor.spout.SpoutExecutor
- getStatus() - Method in class org.apache.storm.scheduler.resource.SchedulingResult
- getStatus(String) - Method in class org.apache.storm.scheduler.Cluster
- getStatusMap() - Method in class org.apache.storm.scheduler.Cluster
- getStatusMap() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all topology scheduler statuses.
- getStormClusterState() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getStormClusterState() - Method in class org.apache.storm.executor.Executor
- getStormComponentDebug() - Method in class org.apache.storm.executor.Executor
- getStormComponentToDebug() - Method in class org.apache.storm.daemon.worker.WorkerState
- getStormConf() - Method in class org.apache.storm.testing.CompleteTopologyParam
- getStormId() - Method in class org.apache.storm.executor.Executor
- getStormId() - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets the unique id assigned to this topology.
- getStormId(String) - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
-
Get storm runtime id from local.
- getStormId(String) - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
- getStormRelInput(RelNode) - Static method in class org.apache.storm.sql.planner.StormRelUtils
- getStormTopology() - Static method in class org.apache.storm.ExclamationTopology
- getStormVersion() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getStormVersionFor(Map<String, Object>, String, AdvancedFSOps, String) - Static method in class org.apache.storm.daemon.supervisor.BasicContainer
- getStr(Map, Object) - Static method in class org.apache.storm.perf.KafkaClientHdfsTopo
- getStr(Map, Object) - Static method in class org.apache.storm.perf.utils.Helper
- getStrategy(Map<String, Object>) - Static method in class org.apache.storm.nimbus.WorkerHeartbeatsRecoveryStrategyFactory
-
Get instance of
IWorkerHeartbeatsRecoveryStrategy
with conf. - getStream() - Method in class org.apache.storm.executor.TupleInfo
- getStream() - Method in class org.apache.storm.kafka.spout.KafkaTuple
- getStream() - Method in class org.apache.storm.multilang.BoltMsg
- getStream() - Method in class org.apache.storm.multilang.ShellMsg
- getStream() - Method in class org.apache.storm.testing.MkTupleParam
- getStreamBox(Object) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getStreamBox.
- getStreamBuilder() - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- getStreamForDirectory(Path) - Method in class org.apache.storm.daemon.logviewer.utils.DirectoryCleaner
-
Creates DirectoryStream for give directory.
- getStreamId() - Method in class org.apache.storm.flux.model.GroupingDef
- getStreamId() - Method in class org.apache.storm.metricstore.FilterOptions
- getStreamId() - Method in class org.apache.storm.metricstore.Metric
- getStreamId(String, String) - Method in class org.apache.storm.serialization.SerializationFactory.IdDictionary
- getStreamName() - Method in class org.apache.storm.bolt.JoinBolt.FieldSelector
- getStreamName(String, int) - Method in class org.apache.storm.serialization.SerializationFactory.IdDictionary
- getStreams() - Method in class org.apache.storm.flux.model.TopologyDef
- getStreams() - Method in class org.apache.storm.loadgen.LoadCompConf.Builder
- getStreamState() - Method in class org.apache.storm.streams.processors.StateQueryProcessor
- getStreamToComponentToGrouper() - Method in class org.apache.storm.executor.Executor
- getString(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getString(int) - Method in interface org.apache.storm.tuple.ITuple
-
Returns the String at position i in the tuple.
- getString(int) - Method in class org.apache.storm.tuple.TupleImpl
- getString(Object) - Static method in class org.apache.storm.utils.ObjectReader
- getString(Object, String) - Static method in class org.apache.storm.utils.ObjectReader
- getStringByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getStringByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the String field with a specific name.
- getStringByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getStrings(Object) - Static method in class org.apache.storm.utils.ObjectReader
-
Convert the input into a list of string; ignore null members.
- getStructDesc() - Method in class org.apache.storm.generated.ComponentObject
- getStructDesc() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- getStructDesc() - Method in class org.apache.storm.generated.Grouping
- getStructDesc() - Method in class org.apache.storm.generated.HBMessageData
- getStructDesc() - Method in class org.apache.storm.generated.JavaObjectArg
- getStructDesc() - Method in class org.apache.storm.generated.SpecificAggregateStats
- getStructDesc() - Method in class org.apache.storm.generated.TopologyActionOptions
- getSubject() - Method in class org.apache.storm.messaging.netty.Login
- getSubSystem(String) - Static method in enum class org.apache.storm.container.cgroup.SubSystemType
- getSubSystems() - Method in class org.apache.storm.container.cgroup.CgroupCenter
- getSubSystems() - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
get a list of available subsystems.
- getSubSystems() - Method in class org.apache.storm.container.cgroup.Hierarchy
-
get subsystems.
- getSubSystemsFromString(String) - Static method in class org.apache.storm.container.cgroup.CgroupUtils
-
Get a set of SubSystemType objects from a comma delimited list of subsystem names.
- GetSuffix(int) - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
-
Get the suffix.
- getSuicideCallback() - Method in class org.apache.storm.daemon.worker.WorkerState
- getSum() - Method in class org.apache.storm.metricstore.Metric
- getSuperUserAcl(Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
-
Get the ACL for nimbus/supervisor.
- getSupervisor(String) - Method in class org.apache.storm.LocalCluster
-
Get a specific Supervisor.
- getSupervisor(String, String, boolean, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/supervisor -> topo history.
- getSupervisorAssignments() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorAssignments
- getSupervisorAssignments() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getSupervisorAssignments
- getSupervisorAssignments(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getSupervisorAssignments(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getSupervisorAssignments(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
-
Get assigned assignments for a specific supervisor
- getSupervisorAssignments(String) - Method in class org.apache.storm.LocalCluster
- getSupervisorAssignments(String, AsyncMethodCallback<SupervisorAssignments>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getSupervisorAssignments(String, AsyncMethodCallback<SupervisorAssignments>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getSupervisorAssignments_args() - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- getSupervisorAssignments_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- getSupervisorAssignments_args(Nimbus.getSupervisorAssignments_args) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
-
Performs a deep copy on other.
- getSupervisorAssignments_call(String, AsyncMethodCallback<SupervisorAssignments>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getSupervisorAssignments_call
- getSupervisorAssignments_result() - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- getSupervisorAssignments_result(Nimbus.getSupervisorAssignments_result) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
-
Performs a deep copy on other.
- getSupervisorAssignments_result(SupervisorAssignments, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- getSupervisorById(String) - Method in class org.apache.storm.scheduler.Cluster
- getSupervisorById(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get a specific supervisor with the
nodeId
. - getSupervisorId() - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
- getSupervisorId() - Method in interface org.apache.storm.scheduler.ISupervisor
-
The id used for writing metadata into ZK.
- getSupervisorId() - Method in class org.apache.storm.utils.LocalState
- getSupervisorLogLink(String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get log link to supervisor log.
- getSupervisorPageInfo() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorPageInfo
- getSupervisorPageInfo() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getSupervisorPageInfo
- getSupervisorPageInfo(String, String, boolean) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getSupervisorPageInfo(String, String, boolean) - Method in class org.apache.storm.generated.Nimbus.Client
- getSupervisorPageInfo(String, String, boolean) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getSupervisorPageInfo(String, String, boolean) - Method in class org.apache.storm.LocalCluster
- getSupervisorPageInfo(String, String, boolean, AsyncMethodCallback<SupervisorPageInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getSupervisorPageInfo(String, String, boolean, AsyncMethodCallback<SupervisorPageInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getSupervisorPageInfo(SupervisorPageInfo, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getSupervisorPageInfo.
- getSupervisorPageInfo_args() - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- getSupervisorPageInfo_args(String, String, boolean) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- getSupervisorPageInfo_args(Nimbus.getSupervisorPageInfo_args) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
-
Performs a deep copy on other.
- getSupervisorPageInfo_call(String, String, boolean, AsyncMethodCallback<SupervisorPageInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getSupervisorPageInfo_call
- getSupervisorPageInfo_result() - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- getSupervisorPageInfo_result(Nimbus.getSupervisorPageInfo_result) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
-
Performs a deep copy on other.
- getSupervisorPageInfo_result(SupervisorPageInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- getSupervisors() - Method in class org.apache.storm.scheduler.Cluster
- getSupervisors() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all the supervisors.
- getSupervisors() - Method in class org.apache.storm.testing.MkClusterParam
- getSupervisorsByHost(String) - Method in class org.apache.storm.scheduler.Cluster
- getSupervisorsByHost(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all the supervisors on the specified
host
. - getSupervisorsResourcesMap() - Method in class org.apache.storm.scheduler.Cluster
- getSupervisorsResourcesMap() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the amount of used and free resources on a supervisor.
- getSupervisorSummary(SecurityContext, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/supervisor/summary -> supervisor summary.
- getSupervisorSummary(List<SupervisorSummary>, SecurityContext, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getSupervisorSummary.
- getSupervisorThriftInterface() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getSwappiness() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getSwitchMap() - Method in class org.apache.storm.networktopography.AbstractDNSToSwitchMapping
-
Get a copy of the map (for diagnostics).
- getSystemFreeMemoryMb() - Method in class org.apache.storm.container.cgroup.CgroupManager
- getSystemFreeMemoryMb() - Method in class org.apache.storm.container.DefaultResourceIsolationManager
- getSystemFreeMemoryMb() - Method in class org.apache.storm.container.oci.OciContainerManager
- getSystemFreeMemoryMb() - Method in interface org.apache.storm.container.ResourceIsolationInterface
-
Get the amount of free memory in MB.
- getSystemTopology() - Method in class org.apache.storm.daemon.worker.WorkerState
- getSysTime(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getTabSize() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
- getTargets(String) - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets information about who is consuming the outputs of the specified component, and how.
- getTask() - Method in class org.apache.storm.metric.IEventLogger.EventInfo
- getTask() - Method in class org.apache.storm.multilang.BoltMsg
- getTask() - Method in class org.apache.storm.multilang.ShellMsg
- getTaskCounters(int) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getTaskData(String) - Method in class org.apache.storm.task.TopologyContext
-
Fetches the task-level data for the given name.
- getTaskGauges(int) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getTaskHistograms(int) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getTaskId() - Method in class org.apache.storm.daemon.Task
- getTaskId() - Method in class org.apache.storm.executor.TupleInfo
- getTaskId() - Method in class org.apache.storm.kafka.spout.internal.CommitMetadata
- getTaskIds() - Method in class org.apache.storm.executor.Executor
- getTaskMeters(int) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getTaskMetrics() - Method in class org.apache.storm.daemon.Task
- getTaskMetrics() - Method in interface org.apache.storm.metrics2.MetricRegistryProvider
- getTaskMetrics() - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getTaskObject() - Method in class org.apache.storm.daemon.Task
- getTaskResourceReqList(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
get the resources requirements for a executor.
- getTasks() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- getTasks() - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
-
Get a list of task ids running in CGroup.
- getTaskTimers(int) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- getTaskToComponent() - Method in class org.apache.storm.daemon.worker.WorkerState
- getTaskToComponent() - Method in class org.apache.storm.task.GeneralTopologyContext
-
Gets a map from task id to component id.
- getTaskToNodePort() - Method in class org.apache.storm.task.WorkerTopologyContext
-
Get a map from task Id to NodePort.
- getTempExtractionDir(long) - Method in enum class org.apache.storm.localizer.LocallyCachedTopologyBlob.TopologyBlobType
- getTempFileName(long) - Method in enum class org.apache.storm.localizer.LocallyCachedTopologyBlob.TopologyBlobType
- getTGT(Map<String, String>) - Static method in class org.apache.storm.security.auth.kerberos.AutoTGT
- getThisComponentId() - Method in class org.apache.storm.task.TopologyContext
-
Get component id.
- getThisInputFields() - Method in class org.apache.storm.task.TopologyContext
-
Gets the declared input fields for this component.
- getThisOutputFields(String) - Method in class org.apache.storm.task.TopologyContext
-
Gets the declared output fields for the specified stream id for the component this task is a part of.
- getThisOutputFieldsForStreams() - Method in class org.apache.storm.task.TopologyContext
-
Gets the declared output fields for all streams for the component this task is a part of.
- getThisSources() - Method in class org.apache.storm.task.TopologyContext
-
Gets the declared inputs to this component.
- getThisStreams() - Method in class org.apache.storm.task.TopologyContext
-
Gets the set of streams declared for the component of this task.
- getThisTargets() - Method in class org.apache.storm.task.TopologyContext
-
Gets information about who is consuming the outputs of this component, and how.
- getThisTaskId() - Method in class org.apache.storm.task.TopologyContext
-
Gets the task id of this task.
- getThisTaskIndex() - Method in class org.apache.storm.task.TopologyContext
-
Gets the index of this task id in getComponentTasks(getThisComponentId()).
- getThisWorkerPort() - Method in class org.apache.storm.task.WorkerTopologyContext
- getThisWorkerTasks() - Method in class org.apache.storm.task.WorkerTopologyContext
-
Gets all the task ids that are running in this worker process (including the task for this task).
- getThreadId() - Method in class org.apache.storm.executor.spout.SpoutExecutor
- getThreadName() - Method in class org.apache.storm.kafka.spout.internal.CommitMetadata
- getThriftFieldId() - Method in enum class org.apache.storm.generated.AccessControl._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.AlreadyAliveException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Assignment._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.AuthorizationException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.BeginDownloadResult._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Bolt._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.BoltAggregateStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.BoltStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ClusterSummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ClusterWorkerHeartbeat._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.CommonAggregateStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ComponentAggregateStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ComponentCommon._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ComponentObject._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Credentials._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DebugOptions._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPC.execute_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPC.execute_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DistributedRPCInvocations.result_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DRPCExecutionException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.DRPCRequest._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ErrorInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ExecutorAggregateStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ExecutorInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ExecutorSpecificStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ExecutorStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ExecutorSummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.GetInfoOptions._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.GlobalStreamId._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Grouping._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBAuthorizationException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBExecutionException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBMessage._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBMessageData._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBNodes._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBPulse._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.HBRecords._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.IllegalStateException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.InvalidTopologyException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.JavaObject._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.JavaObjectArg._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.KeyAlreadyExistsException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.KeyNotFoundException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.KillOptions._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ListBlobsResult._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LocalAssignment._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LocalStateData._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LogConfig._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LogLevel._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LSApprovedWorkers._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LSSupervisorAssignments._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LSSupervisorId._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LSTopoHistory._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LSTopoHistoryList._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.LSWorkerHeartbeat._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.activate_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.activate_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginBlobDownload_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginCreateBlob_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginFileUpload_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.beginUpdateBlob_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.cancelBlobUpload_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.createStateInZookeeper_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.deactivate_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.deactivate_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.debug_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.debug_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.deleteBlob_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.downloadBlobChunk_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.downloadChunk_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.downloadChunk_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.finishBlobUpload_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.finishFileUpload_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getBlobMeta_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getBlobReplication_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getClusterInfo_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getLeader_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getLeader_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getLogConfig_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getLogConfig_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getNimbusConf_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopology_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopology_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyConf_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyHistory_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaries_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummary_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getUserTopology_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.getUserTopology_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.killTopology_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.killTopology_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.listBlobs_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.listBlobs_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.processWorkerMetrics_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.rebalance_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.rebalance_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.setBlobMeta_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.setLogConfig_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.setLogConfig_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.submitTopology_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.submitTopology_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.updateBlobReplication_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.uploadBlobChunk_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.uploadChunk_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.uploadChunk_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Nimbus.uploadNewCredentials_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.NimbusSummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.NodeInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.NotAliveException._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.NullStruct._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.PrivateWorkerKey._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ProfileRequest._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ReadableBlobMeta._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.RebalanceOptions._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SettableBlobMeta._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SharedMemory._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ShellComponent._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SpecificAggregateStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SpoutAggregateStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SpoutSpec._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SpoutStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.StateSpoutSpec._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.StormBase._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.StormTopology._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.StreamInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SubmitOptions._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SupervisorAssignments._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SupervisorInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SupervisorPageInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SupervisorSummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeat._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.SupervisorWorkerHeartbeats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.ThriftSerializedObject._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.TopologyActionOptions._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.TopologyHistoryInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.TopologyInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.TopologyStats._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.TopologySummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerMetricList._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerMetricPoint._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerMetrics._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerResources._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerSummary._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerToken._Fields
- getThriftFieldId() - Method in enum class org.apache.storm.generated.WorkerTokenInfo._Fields
- getThriftServerPort() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getThriftServerPort() - Method in class org.apache.storm.LocalCluster
- getThrottleIOServiceByte() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getThrottleIOServiced() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getTimeCounts() - Method in class org.apache.storm.metric.internal.CountStat
-
Get time counts.
- getTimeCounts() - Method in class org.apache.storm.metric.internal.MultiCountStat
- getTimeData() - Method in class org.apache.storm.st.topology.window.data.TimeDataWindow
- getTimeLatAvg() - Method in class org.apache.storm.metric.internal.LatencyStat
-
Get time latency average.
- getTimeLatAvg() - Method in class org.apache.storm.metric.internal.MultiLatencyStat
- getTimeout() - Method in class org.apache.storm.redis.common.config.JedisClusterConfig
-
Returns socket / connection timeout.
- getTimeout() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig
-
Returns timeout.
- getTimeoutMs() - Method in class org.apache.storm.testing.CompleteTopologyParam
- getTimeSecs() - Method in class org.apache.storm.cluster.ExecutorBeat
- getTimestamp() - Method in class org.apache.storm.container.oci.OciResource
- getTimestamp() - Method in class org.apache.storm.executor.TupleInfo
- getTimestamp() - Method in class org.apache.storm.metric.api.IClusterMetricsConsumer.ClusterInfo
- getTimestamp() - Method in class org.apache.storm.metric.api.IClusterMetricsConsumer.SupervisorInfo
- getTimestamp() - Method in class org.apache.storm.metricstore.Metric
- getTimestamp() - Method in interface org.apache.storm.windowing.Event
-
The event timestamp in millis.
- getTimestamp() - Method in class org.apache.storm.windowing.EventImpl
- getTimestampExtractor() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
- getTimestampExtractor() - Method in interface org.apache.storm.topology.IWindowedBolt
-
Return a
TimestampExtractor
for extracting timestamps from a tuple for event time based processing, or null for processing time. - getTimestampField() - Method in class org.apache.storm.streams.windowing.BaseWindow
- getTimestampField() - Method in interface org.apache.storm.streams.windowing.Window
-
The name of the field in the tuple that contains the timestamp when the event occurred as a long value.
- getTimestampFieldName() - Static method in class org.apache.storm.st.topology.window.data.TimeData
- getTimeUnit() - Method in class org.apache.storm.kafka.spout.internal.Timer
- getTimeUnitForConfig(Map<String, Object>, String) - Static method in class org.apache.storm.daemon.metrics.ClientMetricsUtils
- getTimeWindow() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getTlsPort() - Method in class org.apache.storm.nimbus.NimbusInfo
- getTo() - Method in class org.apache.storm.flux.model.StreamDef
- getToComponent() - Method in class org.apache.storm.loadgen.InputStream.Builder
- getToken(int) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Get the specific Token.
- getTokenSeparatorRegex() - Method in interface org.apache.storm.utils.ShellCommandRunner
-
Token separator regex used to parse Shell tool outputs.
- getTokenSeparatorRegex() - Method in class org.apache.storm.utils.ShellCommandRunnerImpl
- getTombstoneValue() - Method in class org.apache.storm.state.DefaultStateEncoder
- getTombstoneValue() - Method in interface org.apache.storm.state.StateEncoder
-
Get the tombstone value (deletion mark).
- getTopic() - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- getTopic(TridentTuple) - Method in class org.apache.storm.kafka.trident.selector.DefaultTopicSelector
- getTopic(TridentTuple) - Method in interface org.apache.storm.kafka.trident.selector.KafkaTopicSelector
- getTopic(Tuple) - Method in class org.apache.storm.kafka.bolt.selector.DefaultTopicSelector
- getTopic(Tuple) - Method in class org.apache.storm.kafka.bolt.selector.FieldIndexTopicSelector
- getTopic(Tuple) - Method in class org.apache.storm.kafka.bolt.selector.FieldNameTopicSelector
- getTopic(Tuple) - Method in interface org.apache.storm.kafka.bolt.selector.KafkaTopicSelector
- getTopicFilter() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getTopicMetricsMap() - Method in class org.apache.storm.kafka.spout.metrics2.KafkaOffsetMetricManager
- getTopicPartition() - Method in class org.apache.storm.kafka.spout.KafkaSpoutMessageId
- getTopicPartition() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTopicPartition
- getTopicPartitioner() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getTopicPartitionMetricsMap() - Method in class org.apache.storm.kafka.spout.metrics2.KafkaOffsetMetricManager
- getTopics() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- getTopicsPattern() - Method in class org.apache.storm.kafka.spout.subscription.PatternTopicFilter
- getTopicsString() - Method in class org.apache.storm.kafka.spout.subscription.NamedTopicFilter
- getTopicsString() - Method in class org.apache.storm.kafka.spout.subscription.PatternTopicFilter
- getTopicsString() - Method in interface org.apache.storm.kafka.spout.subscription.TopicFilter
-
Get the topics string.
- getToplogyId() - Method in interface org.apache.storm.localizer.PortAndAssignment
- getToplogyId() - Method in class org.apache.storm.localizer.TimePortAndAssignment
- getTopoConf() - Method in class org.apache.storm.executor.Executor
- getTopoHistoryList() - Method in class org.apache.storm.utils.LocalState
- getTopoId(String) - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get a topology ID from the name of a topology.
- getTopolgoyLogConfig(LogConfig) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopolgoyLogConfig.
- getTopologies() - Method in class org.apache.storm.scheduler.Cluster
- getTopologies() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all of the topologies.
- getTopologies() - Method in class org.apache.storm.scheduler.Topologies
- getTopologiesOwnedBy(String) - Method in class org.apache.storm.scheduler.Topologies
-
Get all topologies submitted/owned by a given user.
- getTopoLogsGroups(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerConfigUtils
- getTopoLogsUsers(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerConfigUtils
- getTopology() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopology
- getTopology() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopology
- getTopology() - Method in class org.apache.storm.daemon.worker.WorkerState
- getTopology() - Method in class org.apache.storm.jdbc.topology.AbstractUserTopology
- getTopology() - Method in class org.apache.storm.jdbc.topology.UserPersistenceTopology
- getTopology() - Method in class org.apache.storm.jdbc.topology.UserPersistenceTridentTopology
- getTopology() - Method in class org.apache.storm.scheduler.TopologyDetails
- getTopology() - Method in class org.apache.storm.testing.TrackedTopology
- getTopology(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopology(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopology(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
-
Returns the compiled topology that contains ackers and metrics consumsers.
- getTopology(String) - Method in interface org.apache.storm.ILocalCluster
-
Get the compiled storm topology.
- getTopology(String) - Method in class org.apache.storm.LocalCluster
- getTopology(String, String, boolean, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology -> topo.
- getTopology(String, AsyncMethodCallback<StormTopology>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopology(String, AsyncMethodCallback<StormTopology>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopology(Map<String, Object>) - Method in interface org.apache.storm.flux.api.TopologySource
- getTopology(Map<String, Object>) - Static method in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
-
Create and configure the topology.
- getTopology_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopology_args
- getTopology_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopology_args
- getTopology_args(Nimbus.getTopology_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopology_args
-
Performs a deep copy on other.
- getTopology_call(String, AsyncMethodCallback<StormTopology>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopology_call
- getTopology_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopology_result
- getTopology_result(Nimbus.getTopology_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopology_result
-
Performs a deep copy on other.
- getTopology_result(StormTopology, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopology_result
- getTopologyComponent(String, String, boolean, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/component/:component -> component.
- getTopologyConf() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyConf
- getTopologyConf() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyConf
- getTopologyConf() - Method in class org.apache.storm.daemon.worker.WorkerState
- getTopologyConf(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyConf(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyConf(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyConf(String) - Method in interface org.apache.storm.ILocalCluster
-
The config of a topology as a JSON string.
- getTopologyConf(String) - Method in class org.apache.storm.LocalCluster
- getTopologyConf(String, AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyConf(String, AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyConf_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyConf_args
- getTopologyConf_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyConf_args
- getTopologyConf_args(Nimbus.getTopologyConf_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyConf_args
-
Performs a deep copy on other.
- getTopologyConf_call(String, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyConf_call
- getTopologyConf_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyConf_result
- getTopologyConf_result(String, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyConf_result
- getTopologyConf_result(Nimbus.getTopologyConf_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyConf_result
-
Performs a deep copy on other.
- getTopologyDef() - Method in class org.apache.storm.flux.model.ExecutionContext
- getTopologyFields() - Static method in class org.apache.storm.Thrift
- getTopologyHistory() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyHistory
- getTopologyHistory() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyHistory
- getTopologyHistory(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyHistory(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyHistory(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyHistory(String) - Method in class org.apache.storm.LocalCluster
- getTopologyHistory(String, AsyncMethodCallback<TopologyHistoryInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyHistory(String, AsyncMethodCallback<TopologyHistoryInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyHistory_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- getTopologyHistory_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- getTopologyHistory_args(Nimbus.getTopologyHistory_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyHistory_args
-
Performs a deep copy on other.
- getTopologyHistory_call(String, AsyncMethodCallback<TopologyHistoryInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyHistory_call
- getTopologyHistory_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- getTopologyHistory_result(Nimbus.getTopologyHistory_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyHistory_result
-
Performs a deep copy on other.
- getTopologyHistory_result(TopologyHistoryInfo, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- getTopologyHistoryInfo(TopologyHistoryInfo) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get topology history.
- getTopologyId() - Method in class org.apache.storm.daemon.worker.WorkerState
- getTopologyId() - Method in class org.apache.storm.kafka.spout.internal.CommitMetadata
- getTopologyId() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutBatchMetadata
- getTopologyId() - Method in class org.apache.storm.metricstore.FilterOptions
- getTopologyId() - Method in class org.apache.storm.metricstore.Metric
- getTopologyId() - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Return the ID of the topology.
- getTopologyId() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- getTopologyId(String, Nimbus.Iface) - Static method in class org.apache.storm.utils.Utils
- getTopologyIds() - Method in class org.apache.storm.daemon.nimbus.HeartbeatCache
-
Get the topology ids with cached heartbeats.
- getTopologyIds() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getTopologyInfo() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfo
- getTopologyInfo() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyInfo
- getTopologyInfo(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyInfo(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyInfo(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyInfo(String) - Method in interface org.apache.storm.ILocalCluster
-
Get the state of a topology.
- getTopologyInfo(String) - Method in class org.apache.storm.LocalCluster
- getTopologyInfo(String, String, Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
- getTopologyInfo(String, AsyncMethodCallback<TopologyInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyInfo(String, AsyncMethodCallback<TopologyInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyInfo_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- getTopologyInfo_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- getTopologyInfo_args(Nimbus.getTopologyInfo_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfo_args
-
Performs a deep copy on other.
- getTopologyInfo_call(String, AsyncMethodCallback<TopologyInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfo_call
- getTopologyInfo_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- getTopologyInfo_result(Nimbus.getTopologyInfo_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfo_result
-
Performs a deep copy on other.
- getTopologyInfo_result(TopologyInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- getTopologyInfoByName() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByName
- getTopologyInfoByName() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByName
- getTopologyInfoByName(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyInfoByName(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyInfoByName(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyInfoByName(String) - Method in interface org.apache.storm.ILocalCluster
-
Get the state of a topology.
- getTopologyInfoByName(String) - Method in class org.apache.storm.LocalCluster
- getTopologyInfoByName(String, AsyncMethodCallback<TopologyInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyInfoByName(String, AsyncMethodCallback<TopologyInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyInfoByName_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- getTopologyInfoByName_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- getTopologyInfoByName_args(Nimbus.getTopologyInfoByName_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
-
Performs a deep copy on other.
- getTopologyInfoByName_call(String, AsyncMethodCallback<TopologyInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfoByName_call
- getTopologyInfoByName_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- getTopologyInfoByName_result(Nimbus.getTopologyInfoByName_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
-
Performs a deep copy on other.
- getTopologyInfoByName_result(TopologyInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- getTopologyInfoByNameWithOpts() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByNameWithOpts
- getTopologyInfoByNameWithOpts() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByNameWithOpts
- getTopologyInfoByNameWithOpts(String, GetInfoOptions) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyInfoByNameWithOpts(String, GetInfoOptions) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyInfoByNameWithOpts(String, GetInfoOptions) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyInfoByNameWithOpts(String, GetInfoOptions) - Method in interface org.apache.storm.ILocalCluster
-
Get the state of a topology.
- getTopologyInfoByNameWithOpts(String, GetInfoOptions) - Method in class org.apache.storm.LocalCluster
- getTopologyInfoByNameWithOpts(String, GetInfoOptions, AsyncMethodCallback<TopologyInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyInfoByNameWithOpts(String, GetInfoOptions, AsyncMethodCallback<TopologyInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyInfoByNameWithOpts_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- getTopologyInfoByNameWithOpts_args(String, GetInfoOptions) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- getTopologyInfoByNameWithOpts_args(Nimbus.getTopologyInfoByNameWithOpts_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
-
Performs a deep copy on other.
- getTopologyInfoByNameWithOpts_call(String, GetInfoOptions, AsyncMethodCallback<TopologyInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfoByNameWithOpts_call
- getTopologyInfoByNameWithOpts_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- getTopologyInfoByNameWithOpts_result(Nimbus.getTopologyInfoByNameWithOpts_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
-
Performs a deep copy on other.
- getTopologyInfoByNameWithOpts_result(TopologyInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- getTopologyInfoWithOpts() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoWithOpts
- getTopologyInfoWithOpts() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoWithOpts
- getTopologyInfoWithOpts(String, GetInfoOptions) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyInfoWithOpts(String, GetInfoOptions) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyInfoWithOpts(String, GetInfoOptions) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyInfoWithOpts(String, GetInfoOptions) - Method in interface org.apache.storm.ILocalCluster
-
Get the state of a topology.
- getTopologyInfoWithOpts(String, GetInfoOptions) - Method in class org.apache.storm.LocalCluster
- getTopologyInfoWithOpts(String, GetInfoOptions, AsyncMethodCallback<TopologyInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyInfoWithOpts(String, GetInfoOptions, AsyncMethodCallback<TopologyInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyInfoWithOpts_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- getTopologyInfoWithOpts_args(String, GetInfoOptions) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- getTopologyInfoWithOpts_args(Nimbus.getTopologyInfoWithOpts_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
-
Performs a deep copy on other.
- getTopologyInfoWithOpts_call(String, GetInfoOptions, AsyncMethodCallback<TopologyInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyInfoWithOpts_call
- getTopologyInfoWithOpts_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- getTopologyInfoWithOpts_result(Nimbus.getTopologyInfoWithOpts_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
-
Performs a deep copy on other.
- getTopologyInfoWithOpts_result(TopologyInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- getTopologyKafkaSpout(KafkaSpoutConfig<String, String>) - Method in class org.apache.storm.kafka.spout.KafkaSpoutTopologyMainNamedTopics
- getTopologyKafkaSpout(KafkaSpoutConfig<String, String>) - Method in class org.apache.storm.kafka.spout.KafkaSpoutTopologyMainWildcardTopics
- getTopologyLag(String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/lag -> lag.
- getTopologyLag(StormTopology, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyLag.
- getTopologyLogconfig(String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/logconfig -> logconfig.
- getTopologyMap(TopologySummary) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyMap.
- getTopologyMetrics(String, String, boolean, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/metrics -> metrics.
- getTopologyName() - Method in class org.apache.storm.testing.CompleteTopologyParam
- getTopologyOpResponse(String, String) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyOpResponse.
- getTopologyOwnerFromMetadataFile(Path) - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return topology owner from worker meta file.
- getTopologyPageInfo() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyPageInfo
- getTopologyPageInfo() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologyPageInfo
- getTopologyPageInfo(String, String, boolean) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologyPageInfo(String, String, boolean) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologyPageInfo(String, String, boolean) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologyPageInfo(String, String, boolean) - Method in class org.apache.storm.LocalCluster
- getTopologyPageInfo(String, String, boolean, AsyncMethodCallback<TopologyPageInfo>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologyPageInfo(String, String, boolean, AsyncMethodCallback<TopologyPageInfo>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologyPageInfo_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- getTopologyPageInfo_args(String, String, boolean) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- getTopologyPageInfo_args(Nimbus.getTopologyPageInfo_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
-
Performs a deep copy on other.
- getTopologyPageInfo_call(String, String, boolean, AsyncMethodCallback<TopologyPageInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologyPageInfo_call
- getTopologyPageInfo_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- getTopologyPageInfo_result(Nimbus.getTopologyPageInfo_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
-
Performs a deep copy on other.
- getTopologyPageInfo_result(TopologyPageInfo, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- getTopologyPortWorkerLog(Path) - Static method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return the path of the worker log with the format of topoId/port/worker.log.*
- getTopologyPriority() - Method in class org.apache.storm.scheduler.TopologyDetails
-
get the priority of this topology.
- getTopologyProfileRequests(String) - Method in interface org.apache.storm.cluster.IStormClusterState
- getTopologyProfileRequests(String) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- getTopologyProfilingDump(Nimbus.Iface, String, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyProfilingDump.
- getTopologyProfilingDumpheap(String, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/profiling/dumpheap/:host-port -> dump heap.
- getTopologyProfilingDumpHeap(Nimbus.Iface, String, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyProfilingDumpHeap.
- getTopologyProfilingDumpJstack(String, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/profiling/dumpjstack/:host-port -> dump jstack.
- getTopologyProfilingDumpJstack(Nimbus.Iface, String, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
- getTopologyProfilingDumpProfile(String, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/profiling/dumpprofile/:host-port -> dump profile.
- getTopologyProfilingRestartWorker(String, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/profiling/restartworker/:host-port -> restart worker.
- getTopologyProfilingRestartWorker(Nimbus.Iface, String, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyProfilingRestartWorker.
- getTopologyProfilingStart(String, String, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/profiling/start/:host-port/:timeout -> profiling start.
- getTopologyProfilingStart(Nimbus.Iface, String, String, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyProfilingStart.
- getTopologyProfilingStop(String, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/profiling/stop/:host-port -> profiling stop.
- getTopologyProfilingStop(Nimbus.Iface, String, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyProfilingStop.
- getTopologyResourcesMap() - Method in class org.apache.storm.scheduler.Cluster
- getTopologyResourcesMap() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the amount of resources used by topologies.
- getTopologySource() - Method in class org.apache.storm.flux.model.TopologyDef
- getTopologySubmitter() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get the user that submitted this topology.
- getTopologySummaries() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaries
- getTopologySummaries() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologySummaries
- getTopologySummaries() - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologySummaries() - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologySummaries() - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologySummaries() - Method in interface org.apache.storm.ILocalCluster
- getTopologySummaries() - Method in class org.apache.storm.LocalCluster
- getTopologySummaries(AsyncMethodCallback<List<TopologySummary>>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologySummaries(AsyncMethodCallback<List<TopologySummary>>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologySummaries_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- getTopologySummaries_args(Nimbus.getTopologySummaries_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaries_args
-
Performs a deep copy on other.
- getTopologySummaries_call(AsyncMethodCallback<List<TopologySummary>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologySummaries_call
- getTopologySummaries_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- getTopologySummaries_result(List<TopologySummary>, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- getTopologySummaries_result(Nimbus.getTopologySummaries_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaries_result
-
Performs a deep copy on other.
- getTopologySummary() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummary
- getTopologySummary() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologySummary
- getTopologySummary(SecurityContext, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/summary -> topo history.
- getTopologySummary(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologySummary(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologySummary(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologySummary(String) - Method in interface org.apache.storm.ILocalCluster
- getTopologySummary(String) - Method in class org.apache.storm.LocalCluster
- getTopologySummary(String, AsyncMethodCallback<TopologySummary>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologySummary(String, AsyncMethodCallback<TopologySummary>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologySummary(TopologyPageInfo, String, Map<String, Object>, String) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologySummary.
- getTopologySummary_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummary_args
- getTopologySummary_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummary_args
- getTopologySummary_args(Nimbus.getTopologySummary_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummary_args
-
Performs a deep copy on other.
- getTopologySummary_call(String, AsyncMethodCallback<TopologySummary>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologySummary_call
- getTopologySummary_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummary_result
- getTopologySummary_result(Nimbus.getTopologySummary_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummary_result
-
Performs a deep copy on other.
- getTopologySummary_result(TopologySummary, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummary_result
- getTopologySummaryByName() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaryByName
- getTopologySummaryByName() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getTopologySummaryByName
- getTopologySummaryByName(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getTopologySummaryByName(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getTopologySummaryByName(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
- getTopologySummaryByName(String) - Method in interface org.apache.storm.ILocalCluster
- getTopologySummaryByName(String) - Method in class org.apache.storm.LocalCluster
- getTopologySummaryByName(String, AsyncMethodCallback<TopologySummary>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getTopologySummaryByName(String, AsyncMethodCallback<TopologySummary>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getTopologySummaryByName_args() - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- getTopologySummaryByName_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- getTopologySummaryByName_args(Nimbus.getTopologySummaryByName_args) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
-
Performs a deep copy on other.
- getTopologySummaryByName_call(String, AsyncMethodCallback<TopologySummary>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getTopologySummaryByName_call
- getTopologySummaryByName_result() - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- getTopologySummaryByName_result(Nimbus.getTopologySummaryByName_result) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
-
Performs a deep copy on other.
- getTopologySummaryByName_result(TopologySummary, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- getTopologyTimeoutMillis(Map<String, Object>) - Method in class org.apache.storm.topology.WindowedBoltExecutor
- getTopologyVisializationInit(String, boolean, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/visualization-init -> visualization-init.
- getTopologyVisualization(String, boolean, String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology/:id/visualization -> visualization.
- getTopologyWorkerMaxHeapSize() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get the max heap size for a worker used by this topology.
- getTopologyWorkers(String, String) - Method in class org.apache.storm.daemon.ui.resources.StormApiResource
-
/api/v1/topology-workers/:id -> topo workers.
- getTopologyWorkers(TopologyInfo, Map) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getTopologyWorkers.
- getTotalAcked() - Method in class org.apache.storm.perf.utils.MetricsSample
- getTotalAvailableResources() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Gets all available resources for this node.
- getTotalCpu() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- getTotalCpu() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- getTotalCpu() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
-
Get the total amount of cpu.
- getTotalCpu() - Method in class org.apache.storm.scheduler.SupervisorDetails
-
Get the total CPU on this supervisor in % CPU.
- getTotalCpu() - Method in class org.apache.storm.scheduler.SupervisorResources
- getTotalCpuReqTask(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get the total CPU requirement for executor.
- getTotalCpuResources() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Gets the total cpu resources for this node.
- getTotalEmitted() - Method in class org.apache.storm.perf.utils.MetricsSample
- getTotalFailed() - Method in class org.apache.storm.perf.utils.MetricsSample
- getTotalGenericResources() - Method in class org.apache.storm.scheduler.SupervisorDetails
- getTotalGenericResources() - Method in class org.apache.storm.scheduler.SupervisorResources
- getTotalLatency() - Method in class org.apache.storm.perf.utils.MetricsSample
- getTotalMem() - Method in class org.apache.storm.scheduler.SupervisorResources
- getTotalMemory() - Method in class org.apache.storm.scheduler.SupervisorDetails
-
Get the total Memory on this supervisor in MB.
- getTotalMemoryMb() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
- getTotalMemoryMb() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
- getTotalMemoryMb() - Method in interface org.apache.storm.scheduler.resource.normalization.NormalizedResourcesWithMemory
- getTotalMemoryResources() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Gets the total memory resources for this node.
- getTotalMemReqTask(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Gets the total memory requirement for a task.
- getTotalRequestedCpu() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Note: The public API relevant to resource aware scheduling is unstable as of May 2015.
- getTotalRequestedGenericResources() - Method in class org.apache.storm.scheduler.TopologyDetails
- getTotalRequestedMemOffHeap() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Note: The public API relevant to resource aware scheduling is unstable as of May 2015.
- getTotalRequestedMemOnHeap() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Note: The public API relevant to resource aware scheduling is unstable as of May 2015.
- getTotalResources() - Method in class org.apache.storm.scheduler.resource.RasNode
-
Gets total resources for this node.
- getTotalResources() - Method in class org.apache.storm.scheduler.SupervisorDetails
-
Get all resources for this Supervisor.
- getTotalResources(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get the total resource requirement for an executor.
- getTotalResourcesOverall() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesSummary
- getTotalSlots() - Method in class org.apache.storm.perf.utils.MetricsSample
- getTotalTopologyMemoryReserved(LocalAssignment) - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the total memory reserved.
- getTotalTopologyMemoryUsed() - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the total memory used (on and off heap).
- getTotalTransferred() - Method in class org.apache.storm.perf.utils.MetricsSample
- getTotalWorkersForThisTopology() - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the number of workers for this topology.
- getTrackedId() - Method in interface org.apache.storm.ILocalCluster
-
If the cluster is tracked get the id for the tracked cluster.
- getTrackedId() - Method in class org.apache.storm.LocalCluster
- getTraitDef() - Method in enum class org.apache.storm.sql.planner.streams.rel.StreamsLogicalConvention
- getTransactionId() - Method in class org.apache.storm.transactional.TransactionAttempt
-
Deprecated.
- getTransactionId() - Method in class org.apache.storm.trident.topology.TransactionAttempt
- getTransferQueue() - Method in class org.apache.storm.daemon.worker.WorkerState
- getTransferQueue() - Method in class org.apache.storm.daemon.worker.WorkerTransfer
- getTransferred() - Method in class org.apache.storm.stats.CommonStats
- getTranslator() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
- getTransportPlugin(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- getTransportPlugin(ThriftConnectionType, Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Construct a transport plugin per storm configuration.
- getTridentEstimatedEmittedAggregate() - Method in class org.apache.storm.loadgen.TopologyLoadConf
-
Try and guess at the actual number of messages emitted per second by a trident topology, not the number of batches.
- getTridentTuples(List<TridentTuple>) - Method in class org.apache.storm.trident.windowing.InMemoryTridentWindowManager
- getTridentTuples(List<TridentBatchTuple>) - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
- getTridentTuples(List<T>) - Method in class org.apache.storm.trident.windowing.AbstractTridentWindowManager
-
Return
TridentTuple
s from giventupleEvents
. - getTriggerPolicy(TriggerHandler, EvictionPolicy<T, ?>) - Method in class org.apache.storm.trident.windowing.strategy.SlidingCountWindowStrategy
-
Returns a
TriggerPolicy
which triggers for every count of given sliding window. - getTriggerPolicy(TriggerHandler, EvictionPolicy<T, ?>) - Method in class org.apache.storm.trident.windowing.strategy.SlidingDurationWindowStrategy
-
Returns a
TriggerPolicy
which triggers for every configured sliding window duration. - getTriggerPolicy(TriggerHandler, EvictionPolicy<T, ?>) - Method in class org.apache.storm.trident.windowing.strategy.TumblingCountWindowStrategy
-
Returns a
TriggerPolicy
which triggers for every count of given sliding window. - getTriggerPolicy(TriggerHandler, EvictionPolicy<T, ?>) - Method in class org.apache.storm.trident.windowing.strategy.TumblingDurationWindowStrategy
-
Returns a
TriggerPolicy
which triggers for every given sliding duration. - getTriggerPolicy(TriggerHandler, EvictionPolicy<T, ?>) - Method in interface org.apache.storm.trident.windowing.strategy.WindowStrategy
-
Returns a
TriggerPolicy
by creating withtriggerHandler
andevictionPolicy
with the given configuration. - getTs() - Method in class org.apache.storm.metric.IEventLogger.EventInfo
- getTuple() - Method in class org.apache.storm.multilang.BoltMsg
- getTuple() - Method in class org.apache.storm.multilang.ShellMsg
- getTuple() - Method in class org.apache.storm.tuple.AddressedTuple
- getTuple(String, List) - Method in class org.apache.storm.daemon.Task
- getTupleListener() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- getTuples() - Method in interface org.apache.storm.trident.state.ITupleCollection
- getTuples() - Method in class org.apache.storm.trident.testing.LRUMemoryMapState
- getTuples() - Method in class org.apache.storm.trident.testing.MemoryMapState
- getTupleValue(Tuple, int) - Method in class org.apache.storm.testing.TestWordBytesCounter
- getTupleValue(Tuple, int) - Method in class org.apache.storm.testing.TestWordCounter
- GetTweeters() - Constructor for class org.apache.storm.starter.ReachTopology.GetTweeters
- getTxid() - Method in class org.apache.storm.spout.CheckPointState
- getTxid() - Method in class org.apache.storm.trident.state.TransactionalValue
- getType() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getType() - Method in interface org.apache.storm.container.cgroup.core.CgroupCore
- getType() - Method in class org.apache.storm.container.cgroup.core.CpuacctCore
- getType() - Method in class org.apache.storm.container.cgroup.core.CpuCore
- getType() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- getType() - Method in class org.apache.storm.container.cgroup.core.DevicesCore
- getType() - Method in class org.apache.storm.container.cgroup.core.FreezerCore
- getType() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getType() - Method in class org.apache.storm.container.cgroup.core.NetClsCore
- getType() - Method in class org.apache.storm.container.cgroup.core.NetPrioCore
- getType() - Method in class org.apache.storm.container.cgroup.Hierarchy
-
get all subsystems in hierarchy as a comma delimited list.
- getType() - Method in class org.apache.storm.container.cgroup.SubSystem
- getType() - Method in class org.apache.storm.container.oci.OciResource
- getType() - Method in class org.apache.storm.executor.Executor
- getType() - Method in class org.apache.storm.flux.model.GroupingDef
- getType() - Method in class org.apache.storm.scheduler.Component
- getType() - Method in class org.apache.storm.security.auth.ThriftServer
-
Get type.
- getType(String) - Static method in enum class org.apache.storm.container.cgroup.core.BlkioCore.RecordType
- getTypeFactory() - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
- getTypeFactory() - Method in class org.apache.storm.sql.runtime.calcite.StormDataContext
- getTypeFactory() - Method in class org.apache.storm.sql.StormSqlContext
- getTypeName(Watcher.Event.EventType) - Static method in class org.apache.storm.zookeeper.ZkEventTypes
- getUiCompleteLatency(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getUiHttpCredentialsPlugin(Map<String, Object>) - Static method in class org.apache.storm.security.auth.ServerAuthUtils
-
Construct an HttpServletRequest credential plugin specified by the UI storm configuration.
- getUnassignedAckers() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- getUnassignedExecutors(TopologyDetails) - Method in class org.apache.storm.scheduler.Cluster
- getUnassignedExecutors(TopologyDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
get the unassigned executors of the topology.
- getUnderlyingTransport() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- getUniqueStateId() - Method in class org.apache.storm.trident.fluent.UniqueIdGen
- getUniqueStateId() - Method in class org.apache.storm.trident.TridentTopology
- getUniqueStreamId() - Method in class org.apache.storm.trident.fluent.UniqueIdGen
- getUniqueStreamId() - Method in class org.apache.storm.trident.TridentTopology
- getUniqueWindowId() - Method in class org.apache.storm.trident.fluent.UniqueIdGen
- getUniqueWindowId() - Method in class org.apache.storm.trident.TridentTopology
- getUptime() - Method in class org.apache.storm.cluster.ExecutorBeat
- getUptime() - Method in class org.apache.storm.daemon.worker.WorkerState
- getUpTime() - Method in class org.apache.storm.daemon.supervisor.Supervisor
- getUpTime() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Get how long this topology has been executing.
- getUptimeSecs() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getUrl() - Method in class org.apache.storm.loadgen.HttpForwardingMetricsServer
- getUrl() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the full SCM URL for the build.
- getUrl() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the full SCM URL for the build.
- getUsedCpu() - Method in class org.apache.storm.scheduler.SupervisorResources
- getUsedGenericResources() - Method in class org.apache.storm.scheduler.SupervisorResources
- getUsedMem() - Method in class org.apache.storm.scheduler.SupervisorResources
- getUsedMemoryMb(int) - Method in class org.apache.storm.daemon.supervisor.ContainerMemoryTracker
-
Get the memory used by the worker on the given port.
- getUsedMemoryMb(String) - Method in class org.apache.storm.daemon.supervisor.ContainerMemoryTracker
-
Gets the memory used by the given topology across all ports on this supervisor.
- getUsedPorts(SupervisorDetails) - Method in class org.apache.storm.scheduler.Cluster
- getUsedPorts(SupervisorDetails) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all the used ports of this supervisor.
- getUsedSlots() - Method in class org.apache.storm.perf.utils.MetricsSample
- getUsedSlots() - Method in class org.apache.storm.scheduler.Cluster
- getUsedSlots() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get all currently occupied slots.
- getUsedSlots() - Method in class org.apache.storm.scheduler.resource.RasNode
- getUsedSlots(String) - Method in class org.apache.storm.scheduler.resource.RasNode
-
Get slots used by the given topology.
- getUsedSlotsByTopologyId(String) - Method in class org.apache.storm.scheduler.Cluster
- getUsedSlotsByTopologyId(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
get slots used by a topology.
- getUser() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the name of the user that did the build.
- getUser() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the name of the user that did the build.
- getUserContext() - Method in class org.apache.storm.daemon.Task
- getUserHZ() - Method in class org.apache.storm.metric.cgroup.CGroupCpu
-
Deprecated.
- getUserId(String) - Static method in class org.apache.storm.utils.ServerUtils
-
Get the userId for a user name.
- getUsername() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getUserName(HttpServletRequest) - Method in class org.apache.storm.security.auth.DefaultHttpCredentialsPlugin
- getUserName(HttpServletRequest) - Method in interface org.apache.storm.security.auth.IHttpCredentialsPlugin
-
Gets the user name from the request.
- getUserSharedResources() - Method in class org.apache.storm.daemon.worker.WorkerState
- getUserTime(TimeUnit) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getUserTimer() - Method in class org.apache.storm.daemon.worker.WorkerState
- getUserTopolgyComponents() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Returns a representation of the non-system components of the topology graph.
- getUserTopology() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.getUserTopology
- getUserTopology() - Constructor for class org.apache.storm.generated.Nimbus.Processor.getUserTopology
- getUserTopology(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- getUserTopology(String) - Method in class org.apache.storm.generated.Nimbus.Client
- getUserTopology(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
-
Returns the user specified topology as submitted originally.
- getUserTopology(String) - Method in class org.apache.storm.LocalCluster
- getUserTopology(String, AsyncMethodCallback<StormTopology>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- getUserTopology(String, AsyncMethodCallback<StormTopology>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- getUserTopology_args() - Constructor for class org.apache.storm.generated.Nimbus.getUserTopology_args
- getUserTopology_args(String) - Constructor for class org.apache.storm.generated.Nimbus.getUserTopology_args
- getUserTopology_args(Nimbus.getUserTopology_args) - Constructor for class org.apache.storm.generated.Nimbus.getUserTopology_args
-
Performs a deep copy on other.
- getUserTopology_call(String, AsyncMethodCallback<StormTopology>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.getUserTopology_call
- getUserTopology_result() - Constructor for class org.apache.storm.generated.Nimbus.getUserTopology_result
- getUserTopology_result(Nimbus.getUserTopology_result) - Constructor for class org.apache.storm.generated.Nimbus.getUserTopology_result
-
Performs a deep copy on other.
- getUserTopology_result(StormTopology, NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.getUserTopology_result
- getUserWhitelist() - Method in class org.apache.storm.daemon.logviewer.utils.ResourceAuthorizer.LogUserGroupWhitelist
- getVal() - Method in class org.apache.storm.jdbc.common.Column
- getVal() - Method in class org.apache.storm.trident.state.TransactionalValue
- getValue() - Method in class org.apache.storm.flux.model.PropertyDef
- getValue() - Method in enum class org.apache.storm.generated.AccessControlType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.ComponentType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.DRPCExceptionType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.HBServerMessageType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.LogLevelAction
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.NumErrorsChoice
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.ProfileAction
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.TopologyInitialStatus
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.TopologyStatus
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum class org.apache.storm.generated.WorkerTokenServiceType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.storm.hdfs.common.HdfsUtils.Pair
- getValue() - Method in class org.apache.storm.metric.api.DataPoint
- getValue() - Method in class org.apache.storm.metrics2.RateCounter
-
Reports the the average rate of events per second over 1 minute for the metric.
- getValue() - Method in class org.apache.storm.metrics2.RollingAverageGauge
- getValue() - Method in class org.apache.storm.metrics2.SimpleGauge
- getValue() - Method in enum class org.apache.storm.metricstore.AggLevel
- getValue() - Method in class org.apache.storm.metricstore.Metric
- getValue() - Method in class org.apache.storm.sql.parser.impl.Token
-
An optional attribute value of the Token.
- getValue() - Method in class org.apache.storm.utils.CRC32OutputStream
- getValue(int) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getValue(int) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the field at position i in the tuple.
- getValue(int) - Method in class org.apache.storm.tuple.TupleImpl
- getValueAndReset() - Method in class org.apache.storm.messaging.DeserializingConnectionCallback
-
Returns serialized byte count traffic metrics.
- getValueAndReset() - Method in class org.apache.storm.metric.api.AssignableMetric
- getValueAndReset() - Method in class org.apache.storm.metric.api.CombinedMetric
- getValueAndReset() - Method in class org.apache.storm.metric.api.CountMetric
- getValueAndReset() - Method in interface org.apache.storm.metric.api.IMetric
-
Get value and reset.
- getValueAndReset() - Method in class org.apache.storm.metric.api.MultiCountMetric
- getValueAndReset() - Method in class org.apache.storm.metric.api.MultiReducedMetric
- getValueAndReset() - Method in class org.apache.storm.metric.api.ReducedMetric
- getValueAndReset() - Method in class org.apache.storm.metric.api.StateMetric
- getValueAndReset() - Method in class org.apache.storm.metric.cgroup.CGroupMetricsBase
-
Deprecated.
- getValueAndReset() - Method in class org.apache.storm.metrics.hdrhistogram.HistogramMetric
- getValueAndReset() - Method in class org.apache.storm.metrics.sigar.CPUMetric
- getValueAsList(String, Map<String, Object>) - Static method in class org.apache.storm.utils.ConfigUtils
-
Get the given config value as a List <String>, if possible.
- getValueByField(String) - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getValueByField(String) - Method in interface org.apache.storm.tuple.ITuple
-
Gets the field with a specific name.
- getValueByField(String) - Method in class org.apache.storm.tuple.TupleImpl
- getValueForReporter(Object) - Method in class org.apache.storm.metrics2.PerReporterGauge
- getValueFromTuple(ITuple) - Method in interface org.apache.storm.redis.common.mapper.TupleMapper
-
Extracts value from tuple.
- getValueFromTuple(ITuple) - Method in class org.apache.storm.redis.trident.WordCountLookupMapper
- getValueFromTuple(ITuple) - Method in class org.apache.storm.redis.trident.WordCountStoreMapper
- getValues() - Method in class org.apache.storm.executor.TupleInfo
- getValues() - Method in class org.apache.storm.metric.IEventLogger.EventInfo
- getValues() - Method in class org.apache.storm.st.topology.window.data.TimeData
- getValues() - Method in class org.apache.storm.trident.tuple.TridentTupleView
- getValues() - Method in interface org.apache.storm.tuple.ITuple
-
Gets all the values in this tuple.
- getValues() - Method in class org.apache.storm.tuple.TupleImpl
- getValueSerializer() - Method in class org.apache.storm.state.DefaultStateEncoder
- getVersion() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
- getVersion() - Method in class org.apache.storm.blobstore.BlobStoreFile
- getVersion() - Method in class org.apache.storm.blobstore.InputStreamWithMeta
- getVersion() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
- getVersion() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusDownloadInputStream
- getVersion() - Method in class org.apache.storm.cluster.VersionedData
- getVersion() - Method in class org.apache.storm.container.oci.OciContainerExecutorConfig
- getVersion() - Method in interface org.apache.storm.utils.IVersionInfo
-
Get the version number of the build.
- getVersion() - Static method in class org.apache.storm.utils.VersionInfo
-
Get the version number of the build.
- getVersion(CuratorFramework, String, boolean) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
- getVersionFileName() - Method in enum class org.apache.storm.localizer.LocallyCachedTopologyBlob.TopologyBlobType
- getVersionForKey(String, NimbusInfo, CuratorFramework) - Static method in class org.apache.storm.daemon.nimbus.Nimbus
- getVIntSize(long) - Static method in class org.apache.storm.utils.WritableUtils
-
Get the encoded length if an integer is stored in a variable-length format.
- getVisualizationData(Nimbus.Iface, String, String, boolean) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getVisualizationData.
- getWildcardDir(File) - Method in class org.apache.storm.daemon.supervisor.BasicContainer
-
Returns a path with a wildcard as the final element, so that the JVM will expand that to all JARs in the directory.
- getWindowedParentStreams() - Method in class org.apache.storm.streams.ProcessorNode
- getWindowedParentStreams() - Method in class org.apache.storm.streams.processors.ChainedProcessorContext
- getWindowedParentStreams() - Method in class org.apache.storm.streams.processors.EmittingProcessorContext
- getWindowedParentStreams() - Method in class org.apache.storm.streams.processors.ForwardingProcessorContext
- getWindowedParentStreams() - Method in interface org.apache.storm.streams.processors.ProcessorContext
-
Returns the windowed parent streams.
- getWindowHint(String) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getWindowHint.
- getWindowLength() - Method in class org.apache.storm.streams.windowing.SlidingWindows
-
The length of the window.
- getWindowLength() - Method in class org.apache.storm.streams.windowing.TumblingWindows
- getWindowLength() - Method in interface org.apache.storm.streams.windowing.Window
-
The length of the window.
- getWindowLength() - Method in class org.apache.storm.trident.windowing.config.BaseWindowConfig
- getWindowLength() - Method in interface org.apache.storm.trident.windowing.config.WindowConfig
-
Returns the length of the window.
- getWindowStrategy() - Method in class org.apache.storm.trident.windowing.config.SlidingCountWindow
- getWindowStrategy() - Method in class org.apache.storm.trident.windowing.config.SlidingDurationWindow
- getWindowStrategy() - Method in class org.apache.storm.trident.windowing.config.TumblingCountWindow
- getWindowStrategy() - Method in class org.apache.storm.trident.windowing.config.TumblingDurationWindow
- getWindowStrategy() - Method in interface org.apache.storm.trident.windowing.config.WindowConfig
-
Gives the type of windowing.
- getWindowTriggerInprocessIdPrefix(String) - Static method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- getWindowTriggerTaskPrefix(String) - Static method in class org.apache.storm.trident.windowing.WindowTridentProcessor
- getWithSwapFailCount() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getWithSwapUsage() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getWithSwapUsageLimit() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- getWorkerACL(Map<String, Object>) - Static method in class org.apache.storm.utils.Utils
-
Get the ZK ACLs that a worker should use when writing to ZK.
- getWorkerClassPath(String, List<String>, SimpleVersion) - Method in class org.apache.storm.daemon.supervisor.BasicContainer
-
Compute the classpath for the worker process.
- getWorkerData() - Method in class org.apache.storm.executor.Executor
- getWorkerDirFromRoot(String, String, Integer) - Static method in class org.apache.storm.utils.ConfigUtils
- getWorkerDumpLink(String, long, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getWorkerDumpLink.
- getWorkerHeartbeat(String, String, Long) - Method in interface org.apache.storm.cluster.IStormClusterState
- getWorkerHeartbeat(String, String, Long) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- getWorkerHeartBeat() - Method in class org.apache.storm.utils.LocalState
- getWorkerHook(String) - Method in class org.apache.storm.flux.model.TopologyDef
- getWorkerHooks() - Method in class org.apache.storm.flux.model.TopologyDef
-
Returns worker hook definitions.
- getWorkerId() - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the id of the container or null if there is no worker id right now.
- getWorkerId() - Method in class org.apache.storm.daemon.supervisor.Slot
-
get the workerID (nullable) from CURRENT container, if existed, or return null.
- getWorkerId() - Method in class org.apache.storm.daemon.worker.WorkerState
- getWorkerIdFromMetadataFile(Path) - Method in class org.apache.storm.daemon.logviewer.utils.WorkerLogs
-
Return worker id from worker meta file.
- getWorkerLogLink(String, int, Map<String, Object>, String) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Get log link to supervisor log.
- getWorkerLogWriter(SimpleVersion) - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- getWorkerMain(SimpleVersion) - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- getWorkerProfileRequests(String, NodeInfo) - Method in interface org.apache.storm.cluster.IStormClusterState
- getWorkerProfileRequests(String, NodeInfo) - Method in class org.apache.storm.cluster.StormClusterStateImpl
- getWorkerResources(WorkerSlot) - Method in class org.apache.storm.scheduler.Cluster
- getWorkerResources(WorkerSlot) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Get the resources for a given slot.
- getWorkerResourcesMap() - Method in class org.apache.storm.scheduler.Cluster
- getWorkerResourcesMap() - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Gets the reference to the full topology->worker resource map.
- getWorkers() - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
- getWorkerSummaries(SupervisorPageInfo, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
getWorkerSummaries.
- getWorkerTokenInfo(WorkerToken) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
-
Get and deserialize the WorkerTokenInfo in the worker token.
- getWorkerTopologyContext() - Method in class org.apache.storm.daemon.worker.WorkerState
- getWorkerTopologyContext() - Method in class org.apache.storm.executor.Executor
- getWorkerUser() - Method in class org.apache.storm.daemon.supervisor.Container
-
Get the user of the worker.
- getWorkerUserContext() - Method in class org.apache.storm.daemon.worker.WorkerState
- getWriteBps() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getWriteIOps() - Method in class org.apache.storm.container.cgroup.core.BlkioCore
- getWriter(File) - Method in class org.apache.storm.daemon.supervisor.AdvancedFSOps
-
Get a writer for the given location.
- getWriter(File) - Method in interface org.apache.storm.daemon.supervisor.IAdvancedFSOps
-
Get a writer for the given location.
- getWriterKey(Tuple) - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- getWriterKey(Tuple) - Method in class org.apache.storm.hdfs.bolt.AvroGenericRecordBolt
-
AvroGenericRecordBolt must override this method because messages with different schemas cannot be written to the same file.
- getWriterKey(Tuple) - Method in class org.apache.storm.hdfs.bolt.HdfsBolt
- getWriterKey(Tuple) - Method in class org.apache.storm.hdfs.bolt.SequenceFileBolt
- getWtType() - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
-
Get the corresponding worker token type for this thrift connection.
- getZkSecretAcls(WorkerTokenServiceType) - Method in class org.apache.storm.cluster.ClusterStateContext
- getZkSecretAcls(WorkerTokenServiceType, Map<String, Object>) - Method in enum class org.apache.storm.cluster.DaemonType
-
Get the ACLs to store a secret for a given service.
- getZookeeperKeySet() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreSynchronizer
- global() - Method in class org.apache.storm.trident.Stream
-
## Repartitioning Operation.
- GLOBAL - Enum constant in enum class org.apache.storm.flux.model.GroupingDef.Type
- GLOBAL - Enum constant in enum class org.apache.storm.loadgen.GroupingType
- GLOBAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GlobalAggregationScheme<S extends IAggregatableStream> - Interface in org.apache.storm.trident.fluent
- globalAmt(String) - Method in class org.apache.storm.testing.TrackedTopology
-
Read a metric from the tracked cluster (NOT JUST THIS TOPOLOGY).
- globalAmt(String, String) - Static method in class org.apache.storm.Testing
-
Deprecated.
- GlobalBatchToPartition - Class in org.apache.storm.trident.operation.impl
- GlobalBatchToPartition() - Constructor for class org.apache.storm.trident.operation.impl.GlobalBatchToPartition
- GlobalGrouper() - Constructor for class org.apache.storm.daemon.GrouperFactory.GlobalGrouper
- globalGrouping() - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- globalGrouping(String) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
- globalGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
-
The entire stream goes to a single one of the bolt's tasks.
- globalGrouping(String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- globalGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
-
The entire stream goes to a single one of the bolt's tasks.
- globalGrouping(String, String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- GlobalGrouping - Class in org.apache.storm.trident.partition
- GlobalGrouping() - Constructor for class org.apache.storm.trident.partition.GlobalGrouping
- globalKey - Variable in class org.apache.storm.redis.trident.state.Options
- globalLock() - Static method in class org.apache.storm.utils.RegisteredGlobalState
- GlobalStreamId - Class in org.apache.storm.generated
- GlobalStreamId() - Constructor for class org.apache.storm.generated.GlobalStreamId
- GlobalStreamId(String, String) - Constructor for class org.apache.storm.generated.GlobalStreamId
- GlobalStreamId(GlobalStreamId) - Constructor for class org.apache.storm.generated.GlobalStreamId
-
Performs a deep copy on other.
- GlobalStreamId._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- GO - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GoodToGo - Class in org.apache.storm.localizer
-
Used as a way to give feedback that the listener is ready for the caller to change the blob.
- GoodToGo(CountDownLatch, Future<Void>) - Constructor for class org.apache.storm.localizer.GoodToGo
- GoodToGo.GoodToGoLatch - Class in org.apache.storm.localizer
- GoodToGoLatch(CountDownLatch, Future<Void>) - Constructor for class org.apache.storm.localizer.GoodToGo.GoodToGoLatch
- gotMessage(HBMessage) - Method in class org.apache.storm.pacemaker.PacemakerClient
- GOTO - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GRANT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GRANTED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- GraphGrouper - Class in org.apache.storm.trident.graph
- GraphGrouper(DirectedGraph<Node, IndexedEdge>, Collection<Group>) - Constructor for class org.apache.storm.trident.graph.GraphGrouper
- GRAPHITE_HOST - Static variable in class org.apache.storm.metrics2.reporters.GraphiteStormReporter
- GRAPHITE_PORT - Static variable in class org.apache.storm.metrics2.reporters.GraphiteStormReporter
- GRAPHITE_PREFIXED_WITH - Static variable in class org.apache.storm.metrics2.reporters.GraphiteStormReporter
- GRAPHITE_TRANSPORT - Static variable in class org.apache.storm.metrics2.reporters.GraphiteStormReporter
- GraphiteStormReporter - Class in org.apache.storm.metrics2.reporters
- GraphiteStormReporter() - Constructor for class org.apache.storm.metrics2.reporters.GraphiteStormReporter
- GrasSimulatedUser(User, ISchedulingState) - Constructor for class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser
- GREP_BUF_SIZE - Static variable in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler
- GREP_CONTEXT_SIZE - Static variable in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler
- GREP_MAX_SEARCH_SIZE - Static variable in class org.apache.storm.daemon.logviewer.handler.LogviewerLogSearchHandler
- greyListedSupervisorIds - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorter
- greyListedSupervisorIds - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
- Group - Class in org.apache.storm.trident.graph
- Group(DirectedGraph, List<Node>) - Constructor for class org.apache.storm.trident.graph.Group
- Group(DirectedGraph, Node) - Constructor for class org.apache.storm.trident.graph.Group
- Group(Group, Group) - Constructor for class org.apache.storm.trident.graph.Group
- GROUP - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- groupAdd(String[]) - Method in class org.apache.storm.container.docker.DockerRunCommand
-
Set --group-add option.
- groupBy(Fields) - Method in class org.apache.storm.trident.Stream
-
## Grouping Operation.
- groupByKey() - Method in class org.apache.storm.streams.PairStream
-
Returns a new stream where the values are grouped by the keys.
- groupByKeyAndWindow(Window<?, ?>) - Method in class org.apache.storm.streams.PairStream
-
Returns a new stream where the values are grouped by keys and the given window.
- GroupByKeyAndWindowExample - Class in org.apache.storm.starter.streams
-
An example that shows the usage of
PairStream.groupByKeyAndWindow(Window)
andPairStream.reduceByKeyAndWindow(Reducer, Window)
. - GroupByKeyAndWindowExample() - Constructor for class org.apache.storm.starter.streams.GroupByKeyAndWindowExample
- GroupByOpt() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses the optional GROUP BY clause for SELECT.
- GroupCollector - Class in org.apache.storm.trident.operation.impl
- GroupCollector(TridentCollector, ComboList.Factory) - Constructor for class org.apache.storm.trident.operation.impl.GroupCollector
- GroupedAggregator - Class in org.apache.storm.trident.operation.impl
- GroupedAggregator(Aggregator, Fields, Fields, int) - Constructor for class org.apache.storm.trident.operation.impl.GroupedAggregator
- GroupedMultiReducer<T> - Interface in org.apache.storm.trident.operation
- GroupedMultiReducerExecutor - Class in org.apache.storm.trident.operation.impl
- GroupedMultiReducerExecutor(GroupedMultiReducer, List<Fields>, List<Fields>) - Constructor for class org.apache.storm.trident.operation.impl.GroupedMultiReducerExecutor
- GroupedStream - Class in org.apache.storm.trident.fluent
- GroupedStream(Stream, Fields) - Constructor for class org.apache.storm.trident.fluent.GroupedStream
- GrouperFactory - Class in org.apache.storm.daemon
- GrouperFactory() - Constructor for class org.apache.storm.daemon.GrouperFactory
- GrouperFactory.AllGrouper - Class in org.apache.storm.daemon
- GrouperFactory.BasicLoadAwareCustomStreamGrouping - Class in org.apache.storm.daemon
-
A bridge between CustomStreamGrouping and LoadAwareCustomStreamGrouping.
- GrouperFactory.FieldsGrouper - Class in org.apache.storm.daemon
- GrouperFactory.GlobalGrouper - Class in org.apache.storm.daemon
- GrouperFactory.NoneGrouper - Class in org.apache.storm.daemon
- groupers - Variable in class org.apache.storm.executor.Executor
- grouping(GlobalStreamId, Grouping) - Method in interface org.apache.storm.topology.InputDeclarer
- grouping(GlobalStreamId, Grouping) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
- Grouping - Class in org.apache.storm.generated
- Grouping() - Constructor for class org.apache.storm.generated.Grouping
- Grouping(Grouping) - Constructor for class org.apache.storm.generated.Grouping
- Grouping(Grouping._Fields, Object) - Constructor for class org.apache.storm.generated.Grouping
- GROUPING - Static variable in class org.apache.storm.perf.ConstSpoutNullBoltTopo
- GROUPING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- Grouping._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- GroupingDef - Class in org.apache.storm.flux.model
-
Bean representation of a Storm stream grouping.
- GroupingDef() - Constructor for class org.apache.storm.flux.model.GroupingDef
- GroupingDef.Type - Enum Class in org.apache.storm.flux.model
-
Types of stream groupings Storm allows.
- GroupingElement() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- GroupingElementList() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- groupingInfo - Variable in class org.apache.storm.streams.WindowNode
- groupingType - Variable in class org.apache.storm.loadgen.InputStream
- groupingType(Grouping) - Static method in class org.apache.storm.Thrift
- GroupingType - Enum Class in org.apache.storm.loadgen
-
The different types of groupings that are supported.
- groupMappingProvider - Variable in class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer
- groupMappingServiceProvider - Variable in class org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
- groupMappingServiceProvider - Variable in class org.apache.storm.security.auth.authorizer.SupervisorSimpleACLAuthorizer
- GROUPS - Enum constant in enum class org.apache.storm.generated.LSTopoHistory._Fields
- GROUPS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- gsid() - Method in class org.apache.storm.loadgen.InputStream
-
Get the global stream id for this input stream.
- GSID_TO_INPUT_STATS - Enum constant in enum class org.apache.storm.generated.ComponentPageInfo._Fields
- GT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- guaranteedCpu - Variable in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
- guaranteedGenericResources - Variable in class org.apache.storm.scheduler.resource.strategies.priority.GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser
- guaranteedMemory - Variable in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
- gunzip(byte[]) - Static method in class org.apache.storm.utils.Utils
- gzip(byte[]) - Static method in class org.apache.storm.utils.Utils
- GzipBridgeThriftSerializationDelegate - Class in org.apache.storm.serialization
-
Always writes gzip out, but tests incoming to see if it's gzipped.
- GzipBridgeThriftSerializationDelegate() - Constructor for class org.apache.storm.serialization.GzipBridgeThriftSerializationDelegate
- GzipSerializationDelegate - Class in org.apache.storm.serialization
-
Note, this assumes it's deserializing a gzip byte stream, and will err if it encounters any other serialization.
- GzipSerializationDelegate() - Constructor for class org.apache.storm.serialization.GzipSerializationDelegate
- GzipThriftSerializationDelegate - Class in org.apache.storm.serialization
-
Note, this assumes it's deserializing a gzip byte stream, and will err if it encounters any other serialization.
- GzipThriftSerializationDelegate() - Constructor for class org.apache.storm.serialization.GzipThriftSerializationDelegate
H
- HadoopLoginUtil - Class in org.apache.storm.utils
-
UserGroupInformation#loginUserFromKeytab(String, String) changes the static fields of UserGroupInformation, especially the current logged-in user, and UserGroupInformation itself is not thread-safe.
- HadoopLoginUtil() - Constructor for class org.apache.storm.utils.HadoopLoginUtil
- haltTransferThd() - Method in class org.apache.storm.daemon.worker.WorkerTransfer
- haltWorkerTransfer() - Method in class org.apache.storm.daemon.worker.WorkerState
- handle(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.storm.daemon.drpc.webapp.ReqContextFilter
-
A method used by doFilter which populates the request if it is null and then passes it on to the next entity in the chain.
- handle(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.storm.logging.filters.AccessLoggingFilter
- handle(Callback[]) - Method in class org.apache.storm.security.auth.kerberos.ClientCallbackHandler
-
This method is invoked by SASL for authentication challenges.
- handle(Callback[]) - Method in class org.apache.storm.security.auth.kerberos.ServerCallbackHandler
- handle(Callback[]) - Method in class org.apache.storm.security.auth.sasl.SimpleSaslClientCallbackHandler
- handle(Callback[]) - Method in class org.apache.storm.security.auth.sasl.SimpleSaslServerCallbackHandler
- handle(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>, String) - Method in class org.apache.storm.loadgen.HttpForwardingMetricsServer
- handle(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>, String) - Method in class org.apache.storm.loadgen.LoadMetricsServer
- handleCheckpoint(Tuple, CheckPointState.Action, long) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor
-
Sub-classes can implement the logic for handling checkpoint tuple.
- handleCheckpoint(Tuple, CheckPointState.Action, long) - Method in class org.apache.storm.topology.CheckpointTupleForwarder
-
Forwards the checkpoint tuple downstream.
- handleCheckpoint(Tuple, CheckPointState.Action, long) - Method in class org.apache.storm.topology.StatefulBoltExecutor
- handleDataPoints(IClusterMetricsConsumer.ClusterInfo, Collection<DataPoint>) - Method in interface org.apache.storm.metric.api.IClusterMetricsConsumer
- handleDataPoints(IClusterMetricsConsumer.ClusterInfo, Collection<DataPoint>) - Method in class org.apache.storm.metric.ClusterMetricsConsumerExecutor
- handleDataPoints(IClusterMetricsConsumer.ClusterInfo, Collection<DataPoint>) - Method in class org.apache.storm.metric.LoggingClusterMetricsConsumer
- handleDataPoints(IClusterMetricsConsumer.SupervisorInfo, Collection<DataPoint>) - Method in interface org.apache.storm.metric.api.IClusterMetricsConsumer
- handleDataPoints(IClusterMetricsConsumer.SupervisorInfo, Collection<DataPoint>) - Method in class org.apache.storm.metric.ClusterMetricsConsumerExecutor
- handleDataPoints(IClusterMetricsConsumer.SupervisorInfo, Collection<DataPoint>) - Method in class org.apache.storm.metric.LoggingClusterMetricsConsumer
- handleDataPoints(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>) - Method in class org.apache.storm.loadgen.HttpForwardingMetricsConsumer
- handleDataPoints(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>) - Method in interface org.apache.storm.metric.api.IMetricsConsumer
- handleDataPoints(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>) - Method in class org.apache.storm.metric.LoggingMetricsConsumer
- handleDataPoints(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>) - Method in class org.apache.storm.testing.ForwardingMetricsConsumer
- handleMessage(HBMessage, boolean) - Method in interface org.apache.storm.pacemaker.IServerMessageHandler
- handleMessage(HBMessage, boolean) - Method in class org.apache.storm.pacemaker.Pacemaker
- handleTuple(Tuple) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor
-
Sub-classes can implement the logic for handling the tuple.
- handleTuple(Tuple) - Method in class org.apache.storm.topology.CheckpointTupleForwarder
-
Hands off tuple to the wrapped bolt to execute.
- handleTuple(Tuple) - Method in class org.apache.storm.topology.StatefulBoltExecutor
- handleUncaughtException(Throwable) - Static method in class org.apache.storm.utils.Utils
- handleUncaughtException(Throwable, Set<Class<?>>, boolean) - Static method in class org.apache.storm.utils.Utils
-
Handles uncaught exceptions.
- handleWorkerUncaughtException(Throwable) - Static method in class org.apache.storm.utils.Utils
- hardMemoryLimitMultiplier - Variable in class org.apache.storm.daemon.supervisor.BasicContainer
- hardMemoryLimitOver - Variable in class org.apache.storm.daemon.supervisor.BasicContainer
- hasAckers(Map<String, Object>) - Static method in class org.apache.storm.daemon.StormCommon
- hasAnyPermissions(List<AccessControl>, int, Subject, String) - Method in class org.apache.storm.blobstore.BlobStoreAclHandler
-
Validates if the user has any of the permissions mentioned in the mask.
- hasCache(long) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
- hasCommitted() - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
-
Checks if this OffsetManager has committed to Kafka.
- hasConstructorArgs() - Method in class org.apache.storm.flux.model.ObjectDef
- hasEventLoggers - Variable in class org.apache.storm.executor.Executor
- hasEventLoggers(Map<String, Object>) - Static method in class org.apache.storm.daemon.StormCommon
- hasExecInTopo(ExecutorDetails) - Method in class org.apache.storm.scheduler.TopologyDetails
-
Checks if a executor is part of this topology.
- hasFactory() - Method in class org.apache.storm.flux.model.ObjectDef
- hasFactoryArgs() - Method in class org.apache.storm.flux.model.ObjectDef
- HASH - Enum constant in enum class org.apache.storm.redis.common.mapper.RedisDataTypeDescription.RedisDataType
- hashCode() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- hashCode() - Method in class org.apache.storm.container.cgroup.core.CpuCore.Stat
- hashCode() - Method in class org.apache.storm.container.cgroup.core.DevicesCore.Record
- hashCode() - Method in class org.apache.storm.container.cgroup.Device
- hashCode() - Method in class org.apache.storm.container.cgroup.Hierarchy
- hashCode() - Method in class org.apache.storm.container.cgroup.SubSystem
- hashCode() - Method in class org.apache.storm.generated.AccessControl
- hashCode() - Method in exception org.apache.storm.generated.AlreadyAliveException
- hashCode() - Method in class org.apache.storm.generated.Assignment
- hashCode() - Method in exception org.apache.storm.generated.AuthorizationException
- hashCode() - Method in class org.apache.storm.generated.BeginDownloadResult
- hashCode() - Method in class org.apache.storm.generated.Bolt
- hashCode() - Method in class org.apache.storm.generated.BoltAggregateStats
- hashCode() - Method in class org.apache.storm.generated.BoltStats
- hashCode() - Method in class org.apache.storm.generated.ClusterSummary
- hashCode() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
- hashCode() - Method in class org.apache.storm.generated.CommonAggregateStats
- hashCode() - Method in class org.apache.storm.generated.ComponentAggregateStats
- hashCode() - Method in class org.apache.storm.generated.ComponentCommon
- hashCode() - Method in class org.apache.storm.generated.ComponentObject
- hashCode() - Method in class org.apache.storm.generated.ComponentPageInfo
- hashCode() - Method in class org.apache.storm.generated.Credentials
- hashCode() - Method in class org.apache.storm.generated.DebugOptions
- hashCode() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
- hashCode() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
- hashCode() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
- hashCode() - Method in exception org.apache.storm.generated.DRPCExecutionException
- hashCode() - Method in class org.apache.storm.generated.DRPCRequest
- hashCode() - Method in class org.apache.storm.generated.ErrorInfo
- hashCode() - Method in class org.apache.storm.generated.ExecutorAggregateStats
- hashCode() - Method in class org.apache.storm.generated.ExecutorInfo
- hashCode() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- hashCode() - Method in class org.apache.storm.generated.ExecutorStats
- hashCode() - Method in class org.apache.storm.generated.ExecutorSummary
- hashCode() - Method in class org.apache.storm.generated.GetInfoOptions
- hashCode() - Method in class org.apache.storm.generated.GlobalStreamId
- hashCode() - Method in class org.apache.storm.generated.Grouping
- hashCode() - Method in exception org.apache.storm.generated.HBAuthorizationException
- hashCode() - Method in exception org.apache.storm.generated.HBExecutionException
- hashCode() - Method in class org.apache.storm.generated.HBMessage
- hashCode() - Method in class org.apache.storm.generated.HBMessageData
- hashCode() - Method in class org.apache.storm.generated.HBNodes
- hashCode() - Method in class org.apache.storm.generated.HBPulse
- hashCode() - Method in class org.apache.storm.generated.HBRecords
- hashCode() - Method in exception org.apache.storm.generated.IllegalStateException
- hashCode() - Method in exception org.apache.storm.generated.InvalidTopologyException
- hashCode() - Method in class org.apache.storm.generated.JavaObject
- hashCode() - Method in class org.apache.storm.generated.JavaObjectArg
- hashCode() - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
- hashCode() - Method in exception org.apache.storm.generated.KeyNotFoundException
- hashCode() - Method in class org.apache.storm.generated.KillOptions
- hashCode() - Method in class org.apache.storm.generated.ListBlobsResult
- hashCode() - Method in class org.apache.storm.generated.LocalAssignment
- hashCode() - Method in class org.apache.storm.generated.LocalStateData
- hashCode() - Method in class org.apache.storm.generated.LogConfig
- hashCode() - Method in class org.apache.storm.generated.LogLevel
- hashCode() - Method in class org.apache.storm.generated.LSApprovedWorkers
- hashCode() - Method in class org.apache.storm.generated.LSSupervisorAssignments
- hashCode() - Method in class org.apache.storm.generated.LSSupervisorId
- hashCode() - Method in class org.apache.storm.generated.LSTopoHistory
- hashCode() - Method in class org.apache.storm.generated.LSTopoHistoryList
- hashCode() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
- hashCode() - Method in class org.apache.storm.generated.Nimbus.activate_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.activate_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.deactivate_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.debug_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.debug_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getLeader_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopology_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.killTopology_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
- hashCode() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
- hashCode() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
- hashCode() - Method in class org.apache.storm.generated.NimbusSummary
- hashCode() - Method in class org.apache.storm.generated.NodeInfo
- hashCode() - Method in exception org.apache.storm.generated.NotAliveException
- hashCode() - Method in class org.apache.storm.generated.NullStruct
- hashCode() - Method in class org.apache.storm.generated.OwnerResourceSummary
- hashCode() - Method in class org.apache.storm.generated.PrivateWorkerKey
- hashCode() - Method in class org.apache.storm.generated.ProfileRequest
- hashCode() - Method in class org.apache.storm.generated.ReadableBlobMeta
- hashCode() - Method in class org.apache.storm.generated.RebalanceOptions
- hashCode() - Method in class org.apache.storm.generated.SettableBlobMeta
- hashCode() - Method in class org.apache.storm.generated.SharedMemory
- hashCode() - Method in class org.apache.storm.generated.ShellComponent
- hashCode() - Method in class org.apache.storm.generated.SpecificAggregateStats
- hashCode() - Method in class org.apache.storm.generated.SpoutAggregateStats
- hashCode() - Method in class org.apache.storm.generated.SpoutSpec
- hashCode() - Method in class org.apache.storm.generated.SpoutStats
- hashCode() - Method in class org.apache.storm.generated.StateSpoutSpec
- hashCode() - Method in class org.apache.storm.generated.StormBase
- hashCode() - Method in class org.apache.storm.generated.StormTopology
- hashCode() - Method in class org.apache.storm.generated.StreamInfo
- hashCode() - Method in class org.apache.storm.generated.SubmitOptions
- hashCode() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
- hashCode() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
- hashCode() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
- hashCode() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
- hashCode() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
- hashCode() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
- hashCode() - Method in class org.apache.storm.generated.SupervisorAssignments
- hashCode() - Method in class org.apache.storm.generated.SupervisorInfo
- hashCode() - Method in class org.apache.storm.generated.SupervisorPageInfo
- hashCode() - Method in class org.apache.storm.generated.SupervisorSummary
- hashCode() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
- hashCode() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
- hashCode() - Method in class org.apache.storm.generated.ThriftSerializedObject
- hashCode() - Method in class org.apache.storm.generated.TopologyActionOptions
- hashCode() - Method in class org.apache.storm.generated.TopologyHistoryInfo
- hashCode() - Method in class org.apache.storm.generated.TopologyInfo
- hashCode() - Method in class org.apache.storm.generated.TopologyPageInfo
- hashCode() - Method in class org.apache.storm.generated.TopologyStats
- hashCode() - Method in class org.apache.storm.generated.TopologySummary
- hashCode() - Method in class org.apache.storm.generated.WorkerMetricList
- hashCode() - Method in class org.apache.storm.generated.WorkerMetricPoint
- hashCode() - Method in class org.apache.storm.generated.WorkerMetrics
- hashCode() - Method in class org.apache.storm.generated.WorkerResources
- hashCode() - Method in class org.apache.storm.generated.WorkerSummary
- hashCode() - Method in class org.apache.storm.generated.WorkerToken
- hashCode() - Method in class org.apache.storm.generated.WorkerTokenInfo
- hashCode() - Method in class org.apache.storm.hdfs.spout.TextFileReader
- hashCode() - Method in class org.apache.storm.hdfs.spout.FileLock.LogEntry
- hashCode() - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
- hashCode() - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
- hashCode() - Method in class org.apache.storm.jdbc.common.Column
- hashCode() - Method in class org.apache.storm.jms.spout.JmsMessageID
- hashCode() - Method in class org.apache.storm.kafka.monitor.KafkaOffsetLagResult
- hashCode() - Method in class org.apache.storm.kafka.monitor.KafkaPartitionOffsetLag
- hashCode() - Method in class org.apache.storm.kafka.monitor.NewKafkaSpoutOffsetQuery
- hashCode() - Method in class org.apache.storm.kafka.spout.KafkaSpoutMessageId
- hashCode() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutTopicPartition
- hashCode() - Method in class org.apache.storm.localizer.LocalizedResource
- hashCode() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- hashCode() - Method in class org.apache.storm.localizer.TimePortAndAssignment
-
All implementations of PortAndAssignment should implement the same hashCode() method.
- hashCode() - Method in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
- hashCode() - Method in class org.apache.storm.metrics2.TaskMetricDimensions
- hashCode() - Method in class org.apache.storm.nimbus.NimbusInfo
- hashCode() - Method in class org.apache.storm.scheduler.ExecutorDetails
- hashCode() - Method in class org.apache.storm.scheduler.multitenant.Node
- hashCode() - Method in class org.apache.storm.scheduler.resource.RasNode
- hashCode() - Method in class org.apache.storm.scheduler.resource.User
- hashCode() - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- hashCode() - Method in class org.apache.storm.scheduler.TopologyDetails
- hashCode() - Method in class org.apache.storm.scheduler.WorkerSlot
- hashCode() - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin.User
- hashCode() - Method in class org.apache.storm.security.auth.SingleUserPrincipal
- hashCode() - Method in class org.apache.storm.spout.CheckPointState
- hashCode() - Method in class org.apache.storm.st.topology.window.data.TimeData
- hashCode() - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
- hashCode() - Method in class org.apache.storm.streams.Pair
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple10
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple3
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple4
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple5
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple6
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple7
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple8
- hashCode() - Method in class org.apache.storm.streams.tuple.Tuple9
- hashCode() - Method in class org.apache.storm.streams.windowing.BaseWindow
- hashCode() - Method in class org.apache.storm.streams.windowing.SlidingWindows
- hashCode() - Method in class org.apache.storm.streams.windowing.TumblingWindows
- hashCode() - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Count
- hashCode() - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
- hashCode() - Method in class org.apache.storm.transactional.TransactionAttempt
-
Deprecated.
- hashCode() - Method in class org.apache.storm.trident.graph.Group
- hashCode() - Method in class org.apache.storm.trident.planner.Node
- hashCode() - Method in class org.apache.storm.trident.spout.RichSpoutBatchId
- hashCode() - Method in class org.apache.storm.trident.topology.TransactionAttempt
- hashCode() - Method in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordType
- hashCode() - Method in class org.apache.storm.trident.util.IndexedEdge
- hashCode() - Method in class org.apache.storm.tuple.Fields
- hashCode() - Method in class org.apache.storm.tuple.MessageId
- hashCode() - Method in class org.apache.storm.tuple.TupleImpl
- hashCode() - Method in class org.apache.storm.utils.SimpleVersion
- hashCode() - Method in class org.apache.storm.windowing.TupleWindowImpl
- hashJoin(List<Tuple>) - Method in class org.apache.storm.bolt.JoinBolt
- HashMapSerializer - Class in org.apache.storm.serialization.types
- HashMapSerializer() - Constructor for class org.apache.storm.serialization.types.HashMapSerializer
- HashSetSerializer - Class in org.apache.storm.serialization.types
- HashSetSerializer() - Constructor for class org.apache.storm.serialization.types.HashSetSerializer
- hasMetrics() - Method in class org.apache.storm.grouping.Load
-
Check whether has metrics.
- hasNext() - Method in class org.apache.storm.blobstore.BlobStore.KeyTranslationIterator
- hasNext() - Method in class org.apache.storm.blobstore.FileBlobStoreImpl.KeyInHashDirIterator
- hasNext() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusKeyIterator
- hasNext() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl.KeyInHashDirIterator
- hasNext() - Method in class org.apache.storm.state.BaseStateIterator
- hasPermissions(List<AccessControl>, int, Subject, String) - Method in class org.apache.storm.blobstore.BlobStoreAclHandler
-
Validates if the user has at least the set of permissions mentioned in the mask.
- hasReferences() - Method in class org.apache.storm.flux.model.ConfigMethodDef
- hasReferences() - Method in class org.apache.storm.flux.model.ObjectDef
- hasRemoteOutboundTasks() - Method in class org.apache.storm.daemon.worker.WorkerState
-
Check if this worker has remote outbound tasks.
- hasSpouts() - Method in class org.apache.storm.scheduler.TopologyDetails
-
Determine if there are non-system spouts.
- hasTopologyNeedSchedule(ISchedulingState) - Method in class org.apache.storm.scheduler.resource.User
- hasTransformedResource() - Method in class org.apache.storm.maven.shade.clojure.ClojureTransformer
- HAVING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- HavingOpt() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses the optional HAVING clause for SELECT.
- HBASE_CREDENTIALS - Static variable in class org.apache.storm.hbase.security.HBaseSecurityUtil
- HBASE_CREDENTIALS_CONFIG_KEYS - Static variable in class org.apache.storm.hbase.security.HBaseSecurityUtil
- HBASE_KEYTAB_FILE_KEY - Static variable in class org.apache.storm.hbase.security.HBaseSecurityUtil
- HBASE_PRINCIPAL_KEY - Static variable in class org.apache.storm.hbase.security.HBaseSecurityUtil
- HBaseSecurityUtil - Class in org.apache.storm.hbase.security
-
This class provides util methods for storm-hbase connector communicating with secured HBase.
- HBAuthorizationException - Exception in org.apache.storm.generated
- HBAuthorizationException() - Constructor for exception org.apache.storm.generated.HBAuthorizationException
- HBAuthorizationException(String) - Constructor for exception org.apache.storm.generated.HBAuthorizationException
- HBAuthorizationException(HBAuthorizationException) - Constructor for exception org.apache.storm.generated.HBAuthorizationException
-
Performs a deep copy on other.
- HBAuthorizationException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBExecutionException - Exception in org.apache.storm.generated
- HBExecutionException() - Constructor for exception org.apache.storm.generated.HBExecutionException
- HBExecutionException(String) - Constructor for exception org.apache.storm.generated.HBExecutionException
- HBExecutionException(HBExecutionException) - Constructor for exception org.apache.storm.generated.HBExecutionException
-
Performs a deep copy on other.
- HBExecutionException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBMessage - Class in org.apache.storm.generated
- HBMessage() - Constructor for class org.apache.storm.generated.HBMessage
- HBMessage(HBMessage) - Constructor for class org.apache.storm.generated.HBMessage
-
Performs a deep copy on other.
- HBMessage(HBServerMessageType, HBMessageData) - Constructor for class org.apache.storm.generated.HBMessage
- HBMessage._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBMessageData - Class in org.apache.storm.generated
- HBMessageData() - Constructor for class org.apache.storm.generated.HBMessageData
- HBMessageData(HBMessageData) - Constructor for class org.apache.storm.generated.HBMessageData
- HBMessageData(HBMessageData._Fields, Object) - Constructor for class org.apache.storm.generated.HBMessageData
- HBMessageData._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBNodes - Class in org.apache.storm.generated
- HBNodes() - Constructor for class org.apache.storm.generated.HBNodes
- HBNodes(List<String>) - Constructor for class org.apache.storm.generated.HBNodes
- HBNodes(HBNodes) - Constructor for class org.apache.storm.generated.HBNodes
-
Performs a deep copy on other.
- HBNodes._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBPulse - Class in org.apache.storm.generated
- HBPulse() - Constructor for class org.apache.storm.generated.HBPulse
- HBPulse(String, ByteBuffer) - Constructor for class org.apache.storm.generated.HBPulse
- HBPulse(HBPulse) - Constructor for class org.apache.storm.generated.HBPulse
-
Performs a deep copy on other.
- HBPulse._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBRecords - Class in org.apache.storm.generated
- HBRecords() - Constructor for class org.apache.storm.generated.HBRecords
- HBRecords(List<HBPulse>) - Constructor for class org.apache.storm.generated.HBRecords
- HBRecords(HBRecords) - Constructor for class org.apache.storm.generated.HBRecords
-
Performs a deep copy on other.
- HBRecords._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBServerMessageType - Enum Class in org.apache.storm.generated
- hdel(byte[], byte[]...) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hdel(byte[], byte[]...) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hdel(byte[], byte[]...) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- HDFS_BATCH - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- HDFS_BATCH - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- HDFS_CREDENTIALS - Static variable in class org.apache.storm.hdfs.security.HdfsSecurityUtil
- HDFS_CREDENTIALS_CONFIG_KEYS - Static variable in class org.apache.storm.hdfs.security.HdfsSecurityUtil
- HDFS_PATH - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- HDFS_PATH - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- HDFS_URI - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.please use
HdfsSpout.setHdfsUri(String)
- HDFS_URI - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
- HDFS_URI - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
- HdfsBlobStore - Class in org.apache.storm.hdfs.blobstore
-
Provides a HDFS file system backed blob store implementation.
- HdfsBlobStore() - Constructor for class org.apache.storm.hdfs.blobstore.HdfsBlobStore
- HdfsBlobStoreFile - Class in org.apache.storm.hdfs.blobstore
- HdfsBlobStoreFile(Path, boolean, boolean, Configuration) - Constructor for class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- HdfsBlobStoreFile(Path, String, Configuration) - Constructor for class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
- HdfsBlobStoreImpl - Class in org.apache.storm.hdfs.blobstore
-
HDFS blob store impl.
- HdfsBlobStoreImpl(Path, Map<String, Object>) - Constructor for class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- HdfsBlobStoreImpl(Path, Map<String, Object>, Configuration) - Constructor for class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
- HdfsBlobStoreImpl.KeyInHashDirIterator - Class in org.apache.storm.hdfs.blobstore
- HdfsBolt - Class in org.apache.storm.hdfs.bolt
- HdfsBolt() - Constructor for class org.apache.storm.hdfs.bolt.HdfsBolt
- HdfsClientBlobStore - Class in org.apache.storm.hdfs.blobstore
-
Client to access the HDFS blobStore.
- HdfsClientBlobStore() - Constructor for class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- hdfsConfig - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
- hdfsConfig - Variable in class org.apache.storm.hdfs.trident.HdfsState.Options
- HdfsDataSourcesProvider - Class in org.apache.storm.sql.hdfs
-
Create a HDFS sink based on the URI and properties.
- HdfsDataSourcesProvider() - Constructor for class org.apache.storm.sql.hdfs.HdfsDataSourcesProvider
- HdfsFileOptions() - Constructor for class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
- HdfsFileTopology - Class in org.apache.storm.hdfs.bolt
- HdfsFileTopology() - Constructor for class org.apache.storm.hdfs.bolt.HdfsFileTopology
- HdfsFileTopology.MyBolt - Class in org.apache.storm.hdfs.bolt
- HdfsFileTopology.SentenceSpout - Class in org.apache.storm.hdfs.bolt
- HdfsManifestToResourcesPlugin - Class in org.apache.storm.container.oci
- HdfsManifestToResourcesPlugin() - Constructor for class org.apache.storm.container.oci.HdfsManifestToResourcesPlugin
- HdfsOciResourcesLocalizer - Class in org.apache.storm.container.oci
- HdfsOciResourcesLocalizer() - Constructor for class org.apache.storm.container.oci.HdfsOciResourcesLocalizer
- HdfsSecurityUtil - Class in org.apache.storm.hdfs.security
-
This class provides util methods for storm-hdfs connector communicating with secured HDFS.
- HdfsSpout - Class in org.apache.storm.hdfs.spout
- HdfsSpout() - Constructor for class org.apache.storm.hdfs.spout.HdfsSpout
- HdfsSpoutNullBoltTopo - Class in org.apache.storm.perf
-
This topo helps measure speed of reading from Hdfs.
- HdfsSpoutNullBoltTopo() - Constructor for class org.apache.storm.perf.HdfsSpoutNullBoltTopo
- HdfsSpoutTopology - Class in org.apache.storm.hdfs.spout
- HdfsSpoutTopology() - Constructor for class org.apache.storm.hdfs.spout.HdfsSpoutTopology
- HdfsSpoutTopology.ConstBolt - Class in org.apache.storm.hdfs.spout
- HdfsState - Class in org.apache.storm.hdfs.trident
- HdfsState.HdfsFileOptions - Class in org.apache.storm.hdfs.trident
- HdfsState.Options - Class in org.apache.storm.hdfs.trident
- HdfsState.SequenceFileOptions - Class in org.apache.storm.hdfs.trident
- HdfsStateFactory - Class in org.apache.storm.hdfs.trident
- HdfsStateFactory() - Constructor for class org.apache.storm.hdfs.trident.HdfsStateFactory
- HdfsUpdater - Class in org.apache.storm.hdfs.trident
- HdfsUpdater() - Constructor for class org.apache.storm.hdfs.trident.HdfsUpdater
- HdfsUtils - Class in org.apache.storm.hdfs.common
- HdfsUtils() - Constructor for class org.apache.storm.hdfs.common.HdfsUtils
- HdfsUtils.Pair<K,
V> - Class in org.apache.storm.hdfs.common - HDFSWriter - Class in org.apache.storm.hdfs.common
- HDFSWriter(FileRotationPolicy, Path, FSDataOutputStream, RecordFormat) - Constructor for class org.apache.storm.hdfs.common.HDFSWriter
- HeaderResponseFilter - Class in org.apache.storm.daemon.ui.filters
- HeaderResponseFilter(StormMetricsRegistry) - Constructor for class org.apache.storm.daemon.ui.filters.HeaderResponseFilter
- HeaderResponseServletFilter - Class in org.apache.storm.daemon.ui.filters
- HeaderResponseServletFilter(StormMetricsRegistry) - Constructor for class org.apache.storm.daemon.ui.filters.HeaderResponseServletFilter
- healthCheck(Map<String, Object>, StormMetricsRegistry) - Static method in class org.apache.storm.healthcheck.HealthChecker
- HealthCheck - Class in org.apache.storm.command
- HealthCheck() - Constructor for class org.apache.storm.command.HealthCheck
- HealthChecker - Class in org.apache.storm.healthcheck
- HealthChecker() - Constructor for class org.apache.storm.healthcheck.HealthChecker
- heartbeat(String) - Method in class org.apache.storm.hdfs.spout.FileLock
- HEARTBEAT - Enum constant in enum class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args._Fields
- HEARTBEAT_STREAM_ID - Static variable in class org.apache.storm.task.ShellBolt
- HeartbeatCache - Class in org.apache.storm.daemon.nimbus
-
Holds a cache of heartbeats from the workers.
- HeartbeatCache() - Constructor for class org.apache.storm.daemon.nimbus.HeartbeatCache
-
Create an empty cache.
- Heartbeats - Class in org.apache.storm.command
- Heartbeats() - Constructor for class org.apache.storm.command.Heartbeats
- HEARTBEATS - Enum constant in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args._Fields
- heartbeatStorms() - Method in interface org.apache.storm.cluster.IStormClusterState
- heartbeatStorms() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- HEATBEAT - Enum constant in enum class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args._Fields
- Helper - Class in org.apache.storm.perf.utils
- Helper() - Constructor for class org.apache.storm.perf.utils.Helper
- HEXDIGIT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- hexists(String, String) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- hexists(String, String) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- hexists(String, String) - Method in class org.apache.storm.redis.common.container.JedisContainer
- hget(byte[], byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hget(byte[], byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hget(byte[], byte[]) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- hget(String, String) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- hget(String, String) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- hget(String, String) - Method in class org.apache.storm.redis.common.container.JedisContainer
- hgetAll(byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hgetAll(byte[]) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hgetAll(byte[]) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- hgetAll(String) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hgetAll(String) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hgetAll(String) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- hierarchicalMemoryLimitSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- hierarchicalMemSwapLimitSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- Hierarchy - Class in org.apache.storm.container.cgroup
-
A class that describes a cgroup hierarchy.
- Hierarchy(String, Set<SubSystemType>, String) - Constructor for class org.apache.storm.container.cgroup.Hierarchy
- HIERARCHY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- HikariCPConnectionProvider - Class in org.apache.storm.jdbc.common
- HikariCPConnectionProvider(Map<String, Object>) - Constructor for class org.apache.storm.jdbc.common.HikariCPConnectionProvider
- histogram(String, TopologyContext) - Method in class org.apache.storm.metrics2.StormMetricRegistry
- HistogramMetric - Class in org.apache.storm.metrics.hdrhistogram
-
A metric wrapping an HdrHistogram.
- HistogramMetric(int) - Constructor for class org.apache.storm.metrics.hdrhistogram.HistogramMetric
- HistogramMetric(Long, int) - Constructor for class org.apache.storm.metrics.hdrhistogram.HistogramMetric
- HistogramMetric(Long, Long, int) - Constructor for class org.apache.storm.metrics.hdrhistogram.HistogramMetric
-
(From the Constructor of Histogram) Construct a Histogram given the Lowest and Highest values to be tracked and a number of significant decimal digits.
- hmset(byte[], Map<byte[], byte[]>) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hmset(byte[], Map<byte[], byte[]>) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hmset(byte[], Map<byte[], byte[]>) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- hmset(String, Map<String, String>) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hmset(String, Map<String, String>) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hmset(String, Map<String, String>) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- HOLD - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- HOOK - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- HOST - Enum constant in enum class org.apache.storm.generated.ErrorInfo._Fields
- HOST - Enum constant in enum class org.apache.storm.generated.ExecutorSummary._Fields
- HOST - Enum constant in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
- HOST - Enum constant in enum class org.apache.storm.generated.NimbusSummary._Fields
- HOST - Enum constant in enum class org.apache.storm.generated.SupervisorSummary._Fields
- HOST - Enum constant in enum class org.apache.storm.generated.WorkerSummary._Fields
- HOST_STRING - Enum constant in enum class org.apache.storm.metricstore.rocksdb.KeyType
- hostname - Variable in class org.apache.storm.executor.Executor
- hostname() - Static method in class org.apache.storm.utils.Utils
-
Gets the storm.local.hostname value, or tries to figure out the local hostname if it is not set in the config.
- HOSTNAME - Enum constant in enum class org.apache.storm.generated.SupervisorInfo._Fields
- HOSTNAME - Enum constant in enum class org.apache.storm.generated.WorkerMetrics._Fields
- hostnameImpl() - Method in class org.apache.storm.utils.Utils
- hostnameToNodes(String) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
-
hostname to Ids.
- hostnameToNodes(String) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorter
-
hostname to Ids.
- hostnameToNodes(String) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.sorter.NodeSorterHostProximity
-
hostname to Ids.
- HOUR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- hours(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
-
Returns a
BaseWindowedBolt.Duration
corresponding to the the given value in hours. - HOURS - Enum constant in enum class org.apache.storm.hdfs.bolt.rotation.TimedRotationPolicy.TimeUnit
- HOURS - Enum constant in enum class org.apache.storm.hdfs.trident.rotation.TimedRotationPolicy.TimeUnit
- hscan(byte[], byte[], ScanParams) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
- hscan(byte[], byte[], ScanParams) - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
- hscan(byte[], byte[], ScanParams) - Method in interface org.apache.storm.redis.common.commands.RedisCommands
- hset(String, String, String) - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
- hset(String, String, String) - Method in interface org.apache.storm.redis.common.container.JedisCommandsContainer
- hset(String, String, String) - Method in class org.apache.storm.redis.common.container.JedisContainer
- HttpForwardingMetricsConsumer - Class in org.apache.storm.loadgen
-
Listens for all metrics and POSTs them serialized to a configured URL.
- HttpForwardingMetricsConsumer() - Constructor for class org.apache.storm.loadgen.HttpForwardingMetricsConsumer
- HttpForwardingMetricsServer - Class in org.apache.storm.loadgen
-
A server that can listen for metrics from the HttpForwardingMetricsConsumer.
- HttpForwardingMetricsServer(Map<String, Object>) - Constructor for class org.apache.storm.loadgen.HttpForwardingMetricsServer
-
Constructor.
- HYPER_LOG_LOG - Enum constant in enum class org.apache.storm.redis.common.mapper.RedisDataTypeDescription.RedisDataType
I
- IAdvancedFSOps - Interface in org.apache.storm.daemon.supervisor
- IAggregatableStream - Interface in org.apache.storm.trident.fluent
- IAuthorizer - Interface in org.apache.storm.security.auth
-
Nimbus could be configured with an authorization plugin.
- IAutoCredentials - Interface in org.apache.storm.security.auth
-
Provides a way to automatically push credentials to a topology and to retrieve them in the worker.
- IBackingMap<T> - Interface in org.apache.storm.trident.state.map
- IBasicBolt - Interface in org.apache.storm.topology
- IBasicOutputCollector - Interface in org.apache.storm.topology
- IBatchBolt<T> - Interface in org.apache.storm.coordination
- IBatchID - Interface in org.apache.storm.trident.spout
- IBatchSpout - Interface in org.apache.storm.trident.spout
- IBlacklistStrategy - Interface in org.apache.storm.scheduler.blacklist.strategies
- IBolt - Interface in org.apache.storm.task
-
An IBolt represents a component that takes tuples as input and produces tuples as output.
- IChainedAggregatorDeclarer - Interface in org.apache.storm.trident.fluent
- IClusterMetricsConsumer - Interface in org.apache.storm.metric.api
- IClusterMetricsConsumer.ClusterInfo - Class in org.apache.storm.metric.api
- IClusterMetricsConsumer.SupervisorInfo - Class in org.apache.storm.metric.api
- ICombiner<T> - Interface in org.apache.storm.metric.api
- ICommitterTridentSpout<X> - Interface in org.apache.storm.trident.spout
- ICommitterTridentSpout.Emitter - Interface in org.apache.storm.trident.spout
- IComponent - Interface in org.apache.storm.topology
-
Common methods for all possible components in a topology.
- IConfigLoader - Interface in org.apache.storm.scheduler.utils
- IConfigLoaderFactory - Interface in org.apache.storm.scheduler.utils
- IConfigurator - Interface in org.apache.storm.daemon.ui
- IConnection - Interface in org.apache.storm.messaging
- IConnectionCallback - Interface in org.apache.storm.messaging
-
A class that is called when a TaskMessage arrives.
- IContext - Interface in org.apache.storm.messaging
-
This interface needs to be implemented for messaging plugin.
- ICredentialsListener - Interface in org.apache.storm
-
Allows a bolt or a spout to be informed when the credentials of the topology have changed.
- ICredentialsRenewer - Interface in org.apache.storm.security.auth
-
Provides a way to renew credentials on behalf of a user.
- id - Variable in class org.apache.storm.flux.model.BeanReference
- id - Variable in class org.apache.storm.loadgen.InputStream
- id - Variable in class org.apache.storm.loadgen.LoadCompConf
- id - Variable in class org.apache.storm.loadgen.OutputStream
- id - Variable in class org.apache.storm.messaging.netty.BackPressureStatus
- id - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.ObjectResourcesItem
- id - Variable in class org.apache.storm.StormTimer.QueueEntry
- id - Variable in class org.apache.storm.trident.planner.NodeStateInfo
- ID - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.DistributedRPCInvocations.result_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.HBPulse._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.downloadChunk_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopology_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyConf_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfo_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologySummary_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.getUserTopology_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Nimbus.setWorkerProfiler_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args._Fields
- ID - Enum constant in enum class org.apache.storm.generated.TopologyInfo._Fields
- ID - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ID - Enum constant in enum class org.apache.storm.generated.TopologySummary._Fields
- ID_FIELD - Static variable in class org.apache.storm.trident.spout.TridentSpoutExecutor
- ID_STREAM - Static variable in class org.apache.storm.drpc.PrepareRequest
- ID_TO_BOLT_AGG_STATS - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- ID_TO_SPOUT_AGG_STATS - Enum constant in enum class org.apache.storm.generated.TopologyPageInfo._Fields
- IdBolt - Class in org.apache.storm.perf.bolt
- IdBolt() - Constructor for class org.apache.storm.perf.bolt.IdBolt
- IdDictionary(StormTopology) - Constructor for class org.apache.storm.serialization.SerializationFactory.IdDictionary
- Identifier() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses a simple identifier as a string.
- IDENTIFIER - Static variable in class org.apache.storm.messaging.netty.BackPressureStatus
- IDENTIFIER - Static variable in class org.apache.storm.messaging.netty.SaslMessageToken
- IDENTIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- identity() - Method in interface org.apache.storm.metric.api.ICombiner
- IDENTITY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IDENTITY - Static variable in class org.apache.storm.stats.ClientStatsUtil
- IdentityBolt - Class in org.apache.storm.perf.utils
- IdentityBolt - Class in org.apache.storm.testing
- IdentityBolt() - Constructor for class org.apache.storm.perf.utils.IdentityBolt
- IdentityBolt(Fields) - Constructor for class org.apache.storm.testing.IdentityBolt
- IdentityFunction<T> - Class in org.apache.storm.streams.operations
-
A
Function
that returns the input argument itself as the result. - IdentityFunction() - Constructor for class org.apache.storm.streams.operations.IdentityFunction
- IdentityGrouping - Class in org.apache.storm.trident.partition
- IdentityGrouping() - Constructor for class org.apache.storm.trident.partition.IdentityGrouping
- IdentityMultiReducer<T> - Class in org.apache.storm.trident.operation.impl
- IdentityMultiReducer() - Constructor for class org.apache.storm.trident.operation.impl.IdentityMultiReducer
- identityPartition() - Method in class org.apache.storm.trident.Stream
-
## Repartitioning Operation.
- idle(int) - Method in interface org.apache.storm.policy.IWaitStrategy
-
Implementations of this method should be thread-safe (preferably no side-effects and lock-free).
- idle(int) - Method in class org.apache.storm.policy.WaitStrategyPark
- idle(int) - Method in class org.apache.storm.policy.WaitStrategyProgressive
- ids - Variable in class org.apache.storm.flux.model.BeanListReference
- idsOfTopologiesWithPrivateWorkerKeys() - Method in interface org.apache.storm.cluster.IStormClusterState
-
Get a list of all topologyIds that currently have private worker keys stored, of any kind.
- idsOfTopologiesWithPrivateWorkerKeys() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- IdStreamSpec(String, String) - Constructor for class org.apache.storm.coordination.CoordinatedBolt.IdStreamSpec
- idToNode(String) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
-
Find RASNode for specified node id.
- idToTask - Variable in class org.apache.storm.executor.Executor
- idToTaskBase - Variable in class org.apache.storm.executor.Executor
- IErrorReporter - Interface in org.apache.storm.task
- IEventLogger - Interface in org.apache.storm.metric
-
EventLogger interface for logging the event info to a sink like log file or db for inspecting the events via UI for debugging.
- IEventLogger.EventInfo - Class in org.apache.storm.metric
-
A wrapper for the fields that we would log.
- IExecSorter - Interface in org.apache.storm.scheduler.resource.strategies.scheduling.sorter
- IFeeder - Interface in org.apache.storm.trident.testing
- IGNORE_SUFFIX - Static variable in class org.apache.storm.hdfs.spout.Configs
-
Deprecated.please use
HdfsSpout.setIgnoreSuffix(String)
- IGroupMappingServiceProvider - Interface in org.apache.storm.security.auth
- IHttpCredentialsPlugin - Interface in org.apache.storm.security.auth
-
Interface for handling credentials in an HttpServletRequest.
- IKryoDecorator - Interface in org.apache.storm.serialization
- IKryoFactory - Interface in org.apache.storm.serialization
-
An interface that controls the Kryo instance used by Storm for serialization.
- ILeaderElector - Interface in org.apache.storm.nimbus
-
The interface for leader election.
- IllegalStateException - Exception in org.apache.storm.generated
- IllegalStateException() - Constructor for exception org.apache.storm.generated.IllegalStateException
- IllegalStateException(String) - Constructor for exception org.apache.storm.generated.IllegalStateException
- IllegalStateException(IllegalStateException) - Constructor for exception org.apache.storm.generated.IllegalStateException
-
Performs a deep copy on other.
- IllegalStateException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ILocalAssignmentsBackend - Interface in org.apache.storm.assignments
-
Interface for storing local assignments.
- ILocalCluster - Interface in org.apache.storm
-
This is here mostly for backwards compatibility.
- ILocalCluster.ILocalTopology - Interface in org.apache.storm
-
Close this class to kill the topology.
- ILocalClusterTrackedTopologyAware - Interface in org.apache.storm
-
This is here mostly for backwards compatibility.
- ILocalDRPC - Interface in org.apache.storm
- image - Variable in class org.apache.storm.sql.parser.impl.Token
-
The string image of the token.
- ImageManifest - Class in org.apache.storm.container.oci
-
The image manifest.
- ImageManifest() - Constructor for class org.apache.storm.container.oci.ImageManifest
- ImageManifest(int, String, ImageManifest.Blob, ArrayList<ImageManifest.Blob>, Map<String, String>) - Constructor for class org.apache.storm.container.oci.ImageManifest
- IMetric - Interface in org.apache.storm.metric.api
-
Produces metrics.
- IMetricsConsumer - Interface in org.apache.storm.metric.api
- IMetricsConsumer.DataPoint - Class in org.apache.storm.metric.api
- IMetricsConsumer.TaskInfo - Class in org.apache.storm.metric.api
- IMetricsContext - Interface in org.apache.storm.task
- IMetricsRegistrant - Interface in org.apache.storm.metric.api
-
Interface to allow registration of metrics.
- IMMEDIATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IMMEDIATELY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- impersonatingUser - Variable in class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer.ImpersonationACL
- ImpersonationAclUserEntryValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.ImpersonationAclUserEntryValidator
- ImpersonationAuthorizer - Class in org.apache.storm.security.auth.authorizer
- ImpersonationAuthorizer() - Constructor for class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer
- ImpersonationAuthorizer.ImpersonationACL - Class in org.apache.storm.security.auth.authorizer
- impl() - Method in class org.apache.storm.sql.parser.StormParser
- IMPLEMENTATION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- implementsClass() - Element in annotation interface org.apache.storm.validation.ConfigValidationAnnotations.IsImplementationOfClass
- ImplementsClassValidator(Map<String, Object>) - Constructor for class org.apache.storm.validation.ConfigValidation.ImplementsClassValidator
- IMPORT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IMultiSchemableSpout - Interface in org.apache.storm.spout
- IN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IN_FORMAL_COMMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
Lexical state.
- IN_MULTI_LINE_COMMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
Lexical state.
- INACTIVATE - Enum constant in enum class org.apache.storm.daemon.nimbus.TopologyActions
- INACTIVE - Enum constant in enum class org.apache.storm.generated.TopologyInitialStatus
- INACTIVE - Enum constant in enum class org.apache.storm.generated.TopologyStatus
- inactiveAnonSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- inactiveFileSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
- inBuf - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
- inc(long) - Method in class org.apache.storm.metrics2.RateCounter
- incBy(long) - Method in class org.apache.storm.metric.internal.CountStat
-
Increase the count by the given value.
- incBy(T, long) - Method in class org.apache.storm.metric.internal.MultiCountStat
-
Increase the count by the given value.
- IncludeDef - Class in org.apache.storm.flux.model
-
Represents an include.
- IncludeDef() - Constructor for class org.apache.storm.flux.model.IncludeDef
- includeZero() - Element in annotation interface org.apache.storm.validation.ConfigValidationAnnotations.IsPositiveNumber
- INCLUDING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- incomingGroups(Group) - Method in class org.apache.storm.trident.graph.GraphGrouper
- incomingNodes() - Method in class org.apache.storm.trident.graph.Group
- incr() - Method in class org.apache.storm.metric.api.CountMetric
- incrBy(long) - Method in class org.apache.storm.metric.api.CountMetric
- increment() - Method in class org.apache.storm.streams.RefCountedTuple
- increment() - Method in class org.apache.storm.utils.MutableInt
- increment() - Method in class org.apache.storm.utils.MutableLong
- increment(int) - Method in class org.apache.storm.utils.MutableInt
- increment(long) - Method in class org.apache.storm.utils.MutableLong
- INCREMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- incrementCount(T) - Method in class org.apache.storm.starter.tools.SlidingWindowCounter
- incrementCount(T, int) - Method in class org.apache.storm.starter.tools.SlotBasedCounter
- IncrementingSpout - Class in org.apache.storm.st.topology.window
- IncrementingSpout() - Constructor for class org.apache.storm.st.topology.window.IncrementingSpout
- incrementNumFails() - Method in class org.apache.storm.kafka.spout.KafkaSpoutMessageId
- incrementReportedErrorCount() - Method in class org.apache.storm.executor.Executor
- incStatesSearched() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
- index - Variable in class org.apache.storm.trident.tuple.ValuePointer
- index - Variable in class org.apache.storm.trident.util.IndexedEdge
- IndexedEdge<T> - Class in org.apache.storm.trident.util
- IndexedEdge(T, T, int) - Constructor for class org.apache.storm.trident.util.IndexedEdge
- IndexHashBatchToPartition - Class in org.apache.storm.trident.operation.impl
- IndexHashBatchToPartition() - Constructor for class org.apache.storm.trident.operation.impl.IndexHashBatchToPartition
- IndexHashGrouping - Class in org.apache.storm.trident.partition
- IndexHashGrouping(int) - Constructor for class org.apache.storm.trident.partition.IndexHashGrouping
- indexOf(Object) - Method in class org.apache.storm.utils.ListDelegate
- INDICATOR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IndifferentAccessMap - Class in org.apache.storm.clojure
- IndifferentAccessMap(IPersistentMap) - Constructor for class org.apache.storm.clojure.IndifferentAccessMap
- INettySerializable - Interface in org.apache.storm.messaging.netty
- inferKeyStoreTypeFromPath(String) - Static method in class org.apache.storm.utils.SecurityUtils
-
Check if the suffix ends in pkcs12/p12/jks (case insensitive) and return PKCS12 ot JKS.
- INFO - Enum constant in enum class org.apache.storm.generated.WorkerToken._Fields
- INFO - Enum constant in enum class org.apache.storm.multilang.ShellMsg.ShellLogLevel
- informReferencesAndCommitNewVersion(long) - Method in class org.apache.storm.localizer.LocallyCachedBlob
-
Inform all of the callbacks that a change is going to happen and then wait for them to all get back that it is OK to make that change.
- INimbus - Interface in org.apache.storm.scheduler
- INimbusCredentialPlugin - Interface in org.apache.storm.security
-
Nimbus auto credential plugin that will be called on nimbus host during submit topology option.
- init() - Method in class org.apache.storm.dependency.DependencyUploader
- init() - Method in interface org.apache.storm.metric.api.IReducer
- init() - Method in class org.apache.storm.metric.api.MeanReducer
- init() - Method in class org.apache.storm.streams.operations.aggregators.Count
- init() - Method in class org.apache.storm.streams.operations.aggregators.LongSum
- init() - Method in interface org.apache.storm.streams.operations.CombinerAggregator
-
The initial value of the accumulator to start with.
- init() - Method in interface org.apache.storm.streams.operations.StateUpdater
-
The initial value of the state to start with.
- init() - Method in interface org.apache.storm.trident.operation.ReducerAggregator
- init(long, Object) - Method in interface org.apache.storm.trident.topology.state.RotatingTransactionalState.StateInitializer
- init(FilterConfig) - Method in class org.apache.storm.daemon.drpc.webapp.ReqContextFilter
- init(FilterConfig) - Method in class org.apache.storm.daemon.ui.filters.HeaderResponseServletFilter
- init(FilterConfig) - Method in class org.apache.storm.daemon.ui.TestingFilter
- init(FilterConfig) - Method in class org.apache.storm.logging.filters.AccessLoggingFilter
- init(Object, TridentCollector) - Method in interface org.apache.storm.trident.operation.Aggregator
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.ComparisonAggregator
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNSortedAgg
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedAggregator
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ReducerAggregatorImpl
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.SingleEmitAggregator
- init(Object, TridentCollector) - Method in class org.apache.storm.trident.testing.CountAsAggregator
- init(ArrayList<Task>, int) - Method in class org.apache.storm.executor.bolt.BoltExecutor
- init(ArrayList<Task>, int) - Method in class org.apache.storm.executor.spout.SpoutExecutor
- init(Map<String, Object>) - Method in class org.apache.storm.container.oci.HdfsManifestToResourcesPlugin
- init(Map<String, Object>) - Method in class org.apache.storm.container.oci.HdfsOciResourcesLocalizer
-
Initialization.
- init(Map<String, Object>) - Method in class org.apache.storm.container.oci.LocalOrHdfsImageTagToManifestPlugin
- init(Map<String, Object>) - Method in interface org.apache.storm.container.oci.OciImageTagToManifestPluginInterface
- init(Map<String, Object>) - Method in interface org.apache.storm.container.oci.OciManifestToResourcesPluginInterface
-
Initialization.
- init(Map<String, Object>) - Method in interface org.apache.storm.container.oci.OciResourcesLocalizerInterface
- init(Cluster, Map<String, Node>) - Method in class org.apache.storm.scheduler.multitenant.FreePool
- init(Cluster, Map<String, Node>) - Method in class org.apache.storm.scheduler.multitenant.NodePool
-
Initialize the pool.
- init(ProcessorContext) - Method in class org.apache.storm.streams.processors.MapValuesProcessor
-
Initializes the processor.
- init(ProcessorContext) - Method in interface org.apache.storm.streams.processors.Processor
-
Initializes the processor.
- init(TopologyContext, OutputCollector) - Method in class org.apache.storm.topology.BaseStatefulBoltExecutor
- init(TridentCollector) - Method in class org.apache.storm.trident.drpc.ReturnResultsReducer
- init(TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedMultiReducerExecutor
- init(TridentCollector) - Method in class org.apache.storm.trident.operation.impl.IdentityMultiReducer
- init(TridentCollector) - Method in interface org.apache.storm.trident.operation.MultiReducer
- init(TridentCollector, TridentTuple) - Method in interface org.apache.storm.trident.operation.GroupedMultiReducer
- init(TridentCollector, TridentTuple) - Method in class org.apache.storm.trident.operation.impl.JoinerMultiReducer
- init(TridentCollector, TridentTuple) - Method in class org.apache.storm.trident.operation.impl.PreservingFieldsOrderJoinerMultiReducer
- init(TridentTuple) - Method in class org.apache.storm.starter.trident.TridentReach.One
- init(TridentTuple) - Method in class org.apache.storm.trident.operation.builtin.Count
- init(TridentTuple) - Method in class org.apache.storm.trident.operation.builtin.Sum
- init(TridentTuple) - Method in interface org.apache.storm.trident.operation.CombinerAggregator
- INIT_TXID - Static variable in class org.apache.storm.trident.topology.MasterBatchCoordinator
- initBatchState(String, Object) - Method in class org.apache.storm.trident.planner.SubtopologyBolt
- initBatchState(String, Object) - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
- initBatchState(String, Object) - Method in interface org.apache.storm.trident.topology.ITridentBatchBolt
- initChannel(Channel) - Method in class org.apache.storm.pacemaker.codec.ThriftNettyClientCodec
- initChannel(Channel) - Method in class org.apache.storm.pacemaker.codec.ThriftNettyServerCodec
- INITIAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INITIAL_STATUS - Enum constant in enum class org.apache.storm.generated.SubmitOptions._Fields
- initialize() - Method in class org.apache.storm.trident.windowing.AbstractTridentWindowManager
-
Load and initialize any resources into window manager before windowing for component/task is activated.
- initialize() - Method in class org.apache.storm.trident.windowing.InMemoryTridentWindowManager
- initialize() - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
- initialize(OutputStream, InputStream) - Method in interface org.apache.storm.multilang.ISerializer
-
This method sets the input and output streams of the serializer.
- initialize(OutputStream, InputStream) - Method in class org.apache.storm.multilang.JsonSerializer
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
- initializeTransaction(long, Object, Object) - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.EmptyCoordinator
- initializeTransaction(long, Object, Object) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Coordinator
- initializeTransaction(long, Map<Integer, List<List<Object>>>, Map<Integer, List<List<Object>>>) - Method in class org.apache.storm.trident.testing.FeederBatchSpout.FeederCoordinator
- initializeTransaction(long, X, X) - Method in interface org.apache.storm.trident.spout.ITridentSpout.BatchCoordinator
-
Create metadata for this particular transaction id which has never been emitted before.
- INITIALLY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- InitialReceiver(String, Fields) - Constructor for class org.apache.storm.trident.planner.SubtopologyBolt.InitialReceiver
- initLocalRecvQueues() - Method in class org.apache.storm.executor.ExecutorTransfer
- initState(KeyValueState<String, Long>) - Method in class org.apache.storm.flux.examples.StatefulWordCounter
- initState(KeyValueState<K, R>) - Method in class org.apache.storm.streams.processors.UpdateStateByKeyProcessor
- initState(KeyValueState<K, V>) - Method in interface org.apache.storm.streams.processors.StatefulProcessor
-
Initialize the state of the processor with the given
KeyValueState
. - initState(KeyValueState<K, V>) - Method in class org.apache.storm.streams.processors.StateQueryProcessor
- initState(T) - Method in interface org.apache.storm.topology.IStatefulComponent
-
This method is invoked by the framework with the previously saved state of the component.
- initState(T) - Method in class org.apache.storm.topology.PersistentWindowedBoltExecutor
- initState(T) - Method in class org.apache.storm.topology.StatefulWindowedBoltExecutor
- INITSTATE - Enum constant in enum class org.apache.storm.spout.CheckPointState.Action
-
initialize the state.
- InMemoryAssignmentBackend - Class in org.apache.storm.assignments
-
An assignment backend which will keep all assignments and id-info in memory.
- InMemoryAssignmentBackend() - Constructor for class org.apache.storm.assignments.InMemoryAssignmentBackend
- InMemoryKeyValueState<K,
V> - Class in org.apache.storm.state -
An in-memory implementation of the
State
. - InMemoryKeyValueState() - Constructor for class org.apache.storm.state.InMemoryKeyValueState
- InMemoryKeyValueStateProvider - Class in org.apache.storm.state
-
Provides
InMemoryKeyValueState
. - InMemoryKeyValueStateProvider() - Constructor for class org.apache.storm.state.InMemoryKeyValueStateProvider
- InMemoryTridentWindowManager - Class in org.apache.storm.trident.windowing
-
This
ITridentWindowManager
instance stores all the tuples and trigger related information inmemory. - InMemoryTridentWindowManager(WindowConfig, String, WindowsStore, Aggregator, BatchOutputCollector) - Constructor for class org.apache.storm.trident.windowing.InMemoryTridentWindowManager
- InMemoryWindowsStore - Class in org.apache.storm.trident.windowing
-
Inmemory store implementation of
WindowsStore
which can be backed by persistent store. - InMemoryWindowsStore() - Constructor for class org.apache.storm.trident.windowing.InMemoryWindowsStore
- InMemoryWindowsStore(int, WindowsStore) - Constructor for class org.apache.storm.trident.windowing.InMemoryWindowsStore
-
Creates a new in-memory window store.
- InMemoryWindowsStoreFactory - Class in org.apache.storm.trident.windowing
-
InMemoryWindowsStoreFactory contains a single instance of
InMemoryWindowsStore
which will be used for storing tuples and triggers of the window. - InMemoryWindowsStoreFactory() - Constructor for class org.apache.storm.trident.windowing.InMemoryWindowsStoreFactory
- INNER - Enum constant in enum class org.apache.storm.bolt.JoinBolt.JoinType
- INNER - Enum constant in enum class org.apache.storm.streams.processors.JoinProcessor.JoinType
- INNER - Enum constant in enum class org.apache.storm.trident.JoinType
- INNER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INodeAssignmentSentCallBack - Interface in org.apache.storm.scheduler
- INodeSorter - Interface in org.apache.storm.scheduler.resource.strategies.scheduling.sorter
- InOrderDeliveryTest - Class in org.apache.storm.starter
- InOrderDeliveryTest() - Constructor for class org.apache.storm.starter.InOrderDeliveryTest
- InOrderDeliveryTest.Check - Class in org.apache.storm.starter
- InOrderDeliveryTest.InOrderSpout - Class in org.apache.storm.starter
- InOrderSpout() - Constructor for class org.apache.storm.starter.InOrderDeliveryTest.InOrderSpout
- INOUT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- InProcessZookeeper - Class in org.apache.storm.testing
-
A local Zookeeper instance available for testing.
- InProcessZookeeper() - Constructor for class org.apache.storm.testing.InProcessZookeeper
- InprocMessaging - Class in org.apache.storm.utils
- InprocMessaging() - Constructor for class org.apache.storm.utils.InprocMessaging
- INPUT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INPUT_FILE - Static variable in class org.apache.storm.perf.FileReadWordCountTopo
- INPUT_FILE - Static variable in class org.apache.storm.perf.SimplifiedWordCountTopo
- input_stream - Variable in class org.apache.storm.sql.parser.impl.StormParserImplTokenManager
- InputDeclarer<T extends InputDeclarer> - Interface in org.apache.storm.topology
- INPUTFORMAT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- inputFormatClass() - Method in class org.apache.storm.sql.parser.SqlCreateTable
- INPUTS - Enum constant in enum class org.apache.storm.generated.ComponentCommon._Fields
- inputStream - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
- InputStream - Class in org.apache.storm.loadgen
-
A set of measurements about a stream so we can statistically reproduce it.
- InputStream(String, String, String, NormalDistStats, NormalDistStats, GroupingType) - Constructor for class org.apache.storm.loadgen.InputStream
-
Create a new input stream to a bolt.
- InputStream.Builder - Class in org.apache.storm.loadgen
- InputStreamWithMeta - Class in org.apache.storm.blobstore
- InputStreamWithMeta() - Constructor for class org.apache.storm.blobstore.InputStreamWithMeta
- INSENSITIVE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- insert(String, List<List<Column>>) - Method in class org.apache.storm.jdbc.common.JdbcClient
- insert(JoinBolt.ResultRecord) - Method in class org.apache.storm.bolt.JoinBolt.JoinAccumulator
- insert(Metric) - Method in interface org.apache.storm.metricstore.MetricStore
-
Stores a metric in the store.
- insert(Metric) - Method in class org.apache.storm.metricstore.NoOpMetricStore
- insert(Metric) - Method in class org.apache.storm.metricstore.rocksdb.RocksDbStore
-
Stores metrics in the store.
- INSERT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INSTANCE - Enum constant in enum class org.apache.storm.sql.planner.streams.rel.StreamsLogicalConvention
- INSTANCE - Static variable in class org.apache.storm.kafka.spout.TopicPartitionComparator
- INSTANCE - Static variable in class org.apache.storm.messaging.netty.NettySerializableMessageEncoder
- INSTANCE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsAggregateRule
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsCalcRule
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsFilterRule
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsJoinRule
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsModifyRule
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsProjectRule
- INSTANCE - Static variable in class org.apache.storm.sql.planner.streams.rules.StreamsScanRule
- INSTANTIABLE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- instantiateJavaObject(JavaObject) - Static method in class org.apache.storm.Thrift
- INT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- int_arg(int) - Static method in class org.apache.storm.generated.JavaObjectArg
- INT_ARG - Enum constant in enum class org.apache.storm.generated.JavaObjectArg._Fields
- INTEGER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- integerDivided(int, int) - Static method in class org.apache.storm.utils.Utils
- IntegerValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.IntegerValidator
- InterfaceStability - Class in org.apache.storm.annotation
-
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.storm.annotation.InterfaceStability
- InterfaceStability.Evolving - Annotation Interface in org.apache.storm.annotation
-
Evolving, but can break compatibility at minor release (i.e.
- InterfaceStability.Stable - Annotation Interface in org.apache.storm.annotation
-
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
- InterfaceStability.Unstable - Annotation Interface in org.apache.storm.annotation
-
No guarantee is provided as to reliability or stability across any level of release granularity.
- interleaveAll(List<List<T>>) - Static method in class org.apache.storm.utils.ServerUtils
- INTERMEDIATE_BOLT - Static variable in class org.apache.storm.jms.example.ExampleJmsTopology
- IntermediateRankingsBolt - Class in org.apache.storm.starter.bolt
-
This bolt ranks incoming objects by their count.
- IntermediateRankingsBolt() - Constructor for class org.apache.storm.starter.bolt.IntermediateRankingsBolt
- IntermediateRankingsBolt(int) - Constructor for class org.apache.storm.starter.bolt.IntermediateRankingsBolt
- IntermediateRankingsBolt(int, int) - Constructor for class org.apache.storm.starter.bolt.IntermediateRankingsBolt
- INTERNAL_ERROR - Enum constant in enum class org.apache.storm.generated.DRPCExceptionType
- INTERNAL_VALUE_SERIALIZER - Static variable in class org.apache.storm.state.DefaultStateEncoder
- interpretCreateFunction(SqlCreateFunction) - Method in class org.apache.storm.sql.StormSqlContext
- interpretCreateTable(SqlCreateTable) - Method in class org.apache.storm.sql.StormSqlContext
- INTERSECT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INTERSECTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INTERVAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IntervalLiteral() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
-
Parses an interval literal.
- IntervalQualifier() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- intervalToTaskToMetricToRegistry - Variable in class org.apache.storm.executor.Executor
- IntLiteral() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
- INTO - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- INTO_LIST - Static variable in class org.apache.storm.command.CLI
-
All values are returned as a List.
- INTO_MAP - Static variable in class org.apache.storm.command.CLI
-
All values are returned as a map.
- INVALID_LEXICAL_STATE - Static variable in error org.apache.storm.sql.parser.impl.TokenMgrError
-
Tried to change to an invalid lexical state.
- invalidate(K) - Method in class org.apache.storm.windowing.persistence.SimpleWindowPartitionCache
- invalidate(K) - Method in interface org.apache.storm.windowing.persistence.WindowPartitionCache
-
Invalidate an entry from the cache.
- InvalidRequestException - Exception in org.apache.storm.daemon.ui
- InvalidRequestException() - Constructor for exception org.apache.storm.daemon.ui.InvalidRequestException
- InvalidRequestException(String) - Constructor for exception org.apache.storm.daemon.ui.InvalidRequestException
- InvalidRequestException(String, Throwable) - Constructor for exception org.apache.storm.daemon.ui.InvalidRequestException
- InvalidRequestException(Throwable) - Constructor for exception org.apache.storm.daemon.ui.InvalidRequestException
- InvalidTopologyException - Exception in org.apache.storm.generated
- InvalidTopologyException() - Constructor for exception org.apache.storm.generated.InvalidTopologyException
- InvalidTopologyException(String) - Constructor for exception org.apache.storm.generated.InvalidTopologyException
- InvalidTopologyException(InvalidTopologyException) - Constructor for exception org.apache.storm.generated.InvalidTopologyException
-
Performs a deep copy on other.
- InvalidTopologyException._Fields - Enum Class in org.apache.storm.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- INVOCATION_USER_KEY - Static variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
- invocationUser - Variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer.AclFunctionEntry
- invoke() - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
- invoke(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object...) - Method in class org.apache.storm.clojure.ClojureTuple
- invokeConfigMethods(ObjectDef, Object, ExecutionContext) - Static method in class org.apache.storm.flux.FluxBuilder
-
Invokes configuration methods on an class instance.
- INVOKER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- IOFunction<T,
R> - Interface in org.apache.storm.localizer - IOpaquePartitionedTridentSpout<PartitionsT,
PartitionT extends ISpoutPartition, M> - Interface in org.apache.storm.trident.spout -
This defines a transactional spout which does *not* necessarily replay the same batch every time it emits a batch for a transaction id.
- IOpaquePartitionedTridentSpout.Coordinator<PartitionsT> - Interface in org.apache.storm.trident.spout
-
Coordinator for batches.
- IOpaquePartitionedTridentSpout.Emitter<PartitionsT,
PartitionT extends ISpoutPartition, M> - Interface in org.apache.storm.trident.spout - IOutputCollector - Interface in org.apache.storm.task
- IOutputSerializer - Interface in org.apache.storm.sql.runtime
- IPartitionedTridentSpout<PartitionsT,
PartitionT extends ISpoutPartition, T> - Interface in org.apache.storm.trident.spout -
This interface defines a transactional spout that reads its tuples from a partitioned set of brokers.
- IPartitionedTridentSpout.Coordinator<PartitionsT> - Interface in org.apache.storm.trident.spout
- IPartitionedTridentSpout.Emitter<PartitionsT,
PartitionT extends ISpoutPartition, X> - Interface in org.apache.storm.trident.spout - IPredicate<T> - Interface in org.apache.storm.utils
-
This interface is implemented by classes, instances of which can be passed into certain Util functions which test some collection for elements matching the IPredicate.
- IPrincipalToLocal - Interface in org.apache.storm.security.auth
-
Storm can be configured to launch worker processed as a given user.
- IReducer<T> - Interface in org.apache.storm.metric.api
- IReporter - Interface in org.apache.storm.scheduler.blacklist.reporters
-
report blacklist to alert system.
- IReportError - Interface in org.apache.storm.executor.error
- IRichBolt - Interface in org.apache.storm.topology
-
When writing topologies using Java,
IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology. - IRichSpout - Interface in org.apache.storm.topology
-
When writing topologies using Java,
IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology. - IRichStateSpout - Interface in org.apache.storm.topology
- IRunningExecutor - Interface in org.apache.storm.executor
- IS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- is_blacklisted() - Method in class org.apache.storm.generated.SupervisorSummary
- is_direct() - Method in class org.apache.storm.generated.StreamInfo
- is_enable() - Method in class org.apache.storm.generated.DebugOptions
- is_enable() - Method in class org.apache.storm.generated.Nimbus.debug_args
- IS_INCLUDE_SYS - Enum constant in enum class org.apache.storm.generated.Nimbus.getComponentPageInfo_args._Fields
- IS_INCLUDE_SYS - Enum constant in enum class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args._Fields
- IS_INCLUDE_SYS - Enum constant in enum class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args._Fields
- is_is_include_sys() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
- is_is_include_sys() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
- is_is_include_sys() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
- is_isLeader() - Method in class org.apache.storm.generated.NimbusSummary
- IS_LEADER - Enum constant in enum class org.apache.storm.generated.NimbusSummary._Fields
- IS_ON_WINDOWS - Static variable in class org.apache.storm.utils.ServerUtils
- is_set_access() - Method in class org.apache.storm.generated.AccessControl
-
Returns true if field access is set (has been assigned a value) and false otherwise
- is_set_acked() - Method in class org.apache.storm.generated.BoltStats
-
Returns true if field acked is set (has been assigned a value) and false otherwise
- is_set_acked() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field acked is set (has been assigned a value) and false otherwise
- is_set_acked() - Method in class org.apache.storm.generated.SpoutStats
-
Returns true if field acked is set (has been assigned a value) and false otherwise
- is_set_acl() - Method in class org.apache.storm.generated.SettableBlobMeta
-
Returns true if field acl is set (has been assigned a value) and false otherwise
- is_set_action() - Method in class org.apache.storm.generated.LogLevel
-
Returns true if field action is set (has been assigned a value) and false otherwise
- is_set_action() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
-
Returns true if field action is set (has been assigned a value) and false otherwise
- is_set_action() - Method in class org.apache.storm.generated.ProfileRequest
-
Returns true if field action is set (has been assigned a value) and false otherwise
- is_set_all() - Method in class org.apache.storm.generated.Grouping
- is_set_approved_workers() - Method in class org.apache.storm.generated.LSApprovedWorkers
-
Returns true if field approved_workers is set (has been assigned a value) and false otherwise
- is_set_args_list() - Method in class org.apache.storm.generated.JavaObject
-
Returns true if field args_list is set (has been assigned a value) and false otherwise
- is_set_assigned_cpu() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field assigned_cpu is set (has been assigned a value) and false otherwise
- is_set_assigned_cpu() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_cpu is set (has been assigned a value) and false otherwise
- is_set_assigned_cpu() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field assigned_cpu is set (has been assigned a value) and false otherwise
- is_set_assigned_cpu() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field assigned_cpu is set (has been assigned a value) and false otherwise
- is_set_assigned_generic_resources() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_generic_resources is set (has been assigned a value) and false otherwise
- is_set_assigned_generic_resources() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field assigned_generic_resources is set (has been assigned a value) and false otherwise
- is_set_assigned_memoffheap() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field assigned_memoffheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memoffheap() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_memoffheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memoffheap() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field assigned_memoffheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memoffheap() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field assigned_memoffheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memonheap() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field assigned_memonheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memonheap() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_memonheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memonheap() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field assigned_memonheap is set (has been assigned a value) and false otherwise
- is_set_assigned_memonheap() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field assigned_memonheap is set (has been assigned a value) and false otherwise
- is_set_assigned_off_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field assigned_off_heap_memory is set (has been assigned a value) and false otherwise
- is_set_assigned_on_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field assigned_on_heap_memory is set (has been assigned a value) and false otherwise
- is_set_assigned_regular_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_regular_off_heap_memory is set (has been assigned a value) and false otherwise
- is_set_assigned_regular_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_regular_on_heap_memory is set (has been assigned a value) and false otherwise
- is_set_assigned_shared_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_shared_off_heap_memory is set (has been assigned a value) and false otherwise
- is_set_assigned_shared_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field assigned_shared_on_heap_memory is set (has been assigned a value) and false otherwise
- is_set_assignment_id() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field assignment_id is set (has been assigned a value) and false otherwise
- is_set_assignments() - Method in class org.apache.storm.generated.LSSupervisorAssignments
-
Returns true if field assignments is set (has been assigned a value) and false otherwise
- is_set_assignments() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
-
Returns true if field assignments is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.activate_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.debug_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_aze() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
-
Returns true if field aze is set (has been assigned a value) and false otherwise
- is_set_binary_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- is_set_bits() - Method in class org.apache.storm.generated.ThriftSerializedObject
-
Returns true if field bits is set (has been assigned a value) and false otherwise
- is_set_blacklisted() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field blacklisted is set (has been assigned a value) and false otherwise
- is_set_blobKey() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
-
Returns true if field blobKey is set (has been assigned a value) and false otherwise
- is_set_bolt() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- is_set_bolt() - Method in class org.apache.storm.generated.SpecificAggregateStats
- is_set_bolt_object() - Method in class org.apache.storm.generated.Bolt
-
Returns true if field bolt_object is set (has been assigned a value) and false otherwise
- is_set_bolts() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field bolts is set (has been assigned a value) and false otherwise
- is_set_bool_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- is_set_boolval() - Method in class org.apache.storm.generated.HBMessageData
- is_set_capacity() - Method in class org.apache.storm.generated.BoltAggregateStats
-
Returns true if field capacity is set (has been assigned a value) and false otherwise
- is_set_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
-
Returns true if field chunk is set (has been assigned a value) and false otherwise
- is_set_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
-
Returns true if field chunk is set (has been assigned a value) and false otherwise
- is_set_common() - Method in class org.apache.storm.generated.Bolt
-
Returns true if field common is set (has been assigned a value) and false otherwise
- is_set_common() - Method in class org.apache.storm.generated.SpoutSpec
-
Returns true if field common is set (has been assigned a value) and false otherwise
- is_set_common() - Method in class org.apache.storm.generated.StateSpoutSpec
-
Returns true if field common is set (has been assigned a value) and false otherwise
- is_set_common_stats() - Method in class org.apache.storm.generated.ComponentAggregateStats
-
Returns true if field common_stats is set (has been assigned a value) and false otherwise
- is_set_complete_latency_ms() - Method in class org.apache.storm.generated.SpoutAggregateStats
-
Returns true if field complete_latency_ms is set (has been assigned a value) and false otherwise
- is_set_complete_ms_avg() - Method in class org.apache.storm.generated.SpoutStats
-
Returns true if field complete_ms_avg is set (has been assigned a value) and false otherwise
- is_set_component() - Method in class org.apache.storm.generated.Nimbus.debug_args
-
Returns true if field component is set (has been assigned a value) and false otherwise
- is_set_component_debug() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field component_debug is set (has been assigned a value) and false otherwise
- is_set_component_debug() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field component_debug is set (has been assigned a value) and false otherwise
- is_set_component_executors() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field component_executors is set (has been assigned a value) and false otherwise
- is_set_component_id() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field component_id is set (has been assigned a value) and false otherwise
- is_set_component_id() - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field component_id is set (has been assigned a value) and false otherwise
- is_set_component_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
-
Returns true if field component_id is set (has been assigned a value) and false otherwise
- is_set_component_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
-
Returns true if field component_id is set (has been assigned a value) and false otherwise
- is_set_component_to_num_tasks() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field component_to_num_tasks is set (has been assigned a value) and false otherwise
- is_set_component_to_shared_memory() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field component_to_shared_memory is set (has been assigned a value) and false otherwise
- is_set_component_type() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field component_type is set (has been assigned a value) and false otherwise
- is_set_componentId() - Method in class org.apache.storm.generated.GlobalStreamId
-
Returns true if field componentId is set (has been assigned a value) and false otherwise
- is_set_componentId() - Method in class org.apache.storm.generated.WorkerMetricPoint
-
Returns true if field componentId is set (has been assigned a value) and false otherwise
- is_set_config() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
-
Returns true if field config is set (has been assigned a value) and false otherwise
- is_set_cpu() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field cpu is set (has been assigned a value) and false otherwise
- is_set_cpu_guarantee() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field cpu_guarantee is set (has been assigned a value) and false otherwise
- is_set_cpu_guarantee_remaining() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field cpu_guarantee_remaining is set (has been assigned a value) and false otherwise
- is_set_cpu_usage() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field cpu_usage is set (has been assigned a value) and false otherwise
- is_set_creds() - Method in class org.apache.storm.generated.Credentials
-
Returns true if field creds is set (has been assigned a value) and false otherwise
- is_set_creds() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
-
Returns true if field creds is set (has been assigned a value) and false otherwise
- is_set_creds() - Method in class org.apache.storm.generated.SubmitOptions
-
Returns true if field creds is set (has been assigned a value) and false otherwise
- is_set_custom_object() - Method in class org.apache.storm.generated.Grouping
- is_set_custom_serialized() - Method in class org.apache.storm.generated.Grouping
- is_set_data() - Method in class org.apache.storm.generated.HBMessage
-
Returns true if field data is set (has been assigned a value) and false otherwise
- is_set_data_size() - Method in class org.apache.storm.generated.BeginDownloadResult
-
Returns true if field data_size is set (has been assigned a value) and false otherwise
- is_set_debug_options() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field debug_options is set (has been assigned a value) and false otherwise
- is_set_debug_options() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field debug_options is set (has been assigned a value) and false otherwise
- is_set_dependency_artifacts() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field dependency_artifacts is set (has been assigned a value) and false otherwise
- is_set_dependency_jars() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field dependency_jars is set (has been assigned a value) and false otherwise
- is_set_details() - Method in class org.apache.storm.generated.HBPulse
-
Returns true if field details is set (has been assigned a value) and false otherwise
- is_set_direct() - Method in class org.apache.storm.generated.Grouping
- is_set_direct() - Method in class org.apache.storm.generated.StreamInfo
-
Returns true if field direct is set (has been assigned a value) and false otherwise
- is_set_double_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- is_set_e() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.activate_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.debug_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_e() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- is_set_emitted() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field emitted is set (has been assigned a value) and false otherwise
- is_set_emitted() - Method in class org.apache.storm.generated.ExecutorStats
-
Returns true if field emitted is set (has been assigned a value) and false otherwise
- is_set_enable() - Method in class org.apache.storm.generated.DebugOptions
-
Returns true if field enable is set (has been assigned a value) and false otherwise
- is_set_enable() - Method in class org.apache.storm.generated.Nimbus.debug_args
-
Returns true if field enable is set (has been assigned a value) and false otherwise
- is_set_error() - Method in class org.apache.storm.generated.ErrorInfo
-
Returns true if field error is set (has been assigned a value) and false otherwise
- is_set_error_time_secs() - Method in class org.apache.storm.generated.ErrorInfo
-
Returns true if field error_time_secs is set (has been assigned a value) and false otherwise
- is_set_errors() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field errors is set (has been assigned a value) and false otherwise
- is_set_errors() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field errors is set (has been assigned a value) and false otherwise
- is_set_eventlog_host() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field eventlog_host is set (has been assigned a value) and false otherwise
- is_set_eventlog_port() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field eventlog_port is set (has been assigned a value) and false otherwise
- is_set_exec_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field exec_stats is set (has been assigned a value) and false otherwise
- is_set_exec_summary() - Method in class org.apache.storm.generated.ExecutorAggregateStats
-
Returns true if field exec_summary is set (has been assigned a value) and false otherwise
- is_set_execute_latency_ms() - Method in class org.apache.storm.generated.BoltAggregateStats
-
Returns true if field execute_latency_ms is set (has been assigned a value) and false otherwise
- is_set_execute_ms_avg() - Method in class org.apache.storm.generated.BoltStats
-
Returns true if field execute_ms_avg is set (has been assigned a value) and false otherwise
- is_set_executed() - Method in class org.apache.storm.generated.BoltAggregateStats
-
Returns true if field executed is set (has been assigned a value) and false otherwise
- is_set_executed() - Method in class org.apache.storm.generated.BoltStats
-
Returns true if field executed is set (has been assigned a value) and false otherwise
- is_set_execution_command() - Method in class org.apache.storm.generated.ShellComponent
-
Returns true if field execution_command is set (has been assigned a value) and false otherwise
- is_set_executor_info() - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field executor_info is set (has been assigned a value) and false otherwise
- is_set_executor_node_port() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field executor_node_port is set (has been assigned a value) and false otherwise
- is_set_executor_start_time_secs() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field executor_start_time_secs is set (has been assigned a value) and false otherwise
- is_set_executor_stats() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
-
Returns true if field executor_stats is set (has been assigned a value) and false otherwise
- is_set_executorId() - Method in class org.apache.storm.generated.WorkerMetricPoint
-
Returns true if field executorId is set (has been assigned a value) and false otherwise
- is_set_executors() - Method in class org.apache.storm.generated.LocalAssignment
-
Returns true if field executors is set (has been assigned a value) and false otherwise
- is_set_executors() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
-
Returns true if field executors is set (has been assigned a value) and false otherwise
- is_set_executors() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
-
Returns true if field executors is set (has been assigned a value) and false otherwise
- is_set_executors() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field executors is set (has been assigned a value) and false otherwise
- is_set_expirationTimeMillis() - Method in class org.apache.storm.generated.PrivateWorkerKey
-
Returns true if field expirationTimeMillis is set (has been assigned a value) and false otherwise
- is_set_expirationTimeMillis() - Method in class org.apache.storm.generated.WorkerTokenInfo
-
Returns true if field expirationTimeMillis is set (has been assigned a value) and false otherwise
- is_set_failed() - Method in class org.apache.storm.generated.BoltStats
-
Returns true if field failed is set (has been assigned a value) and false otherwise
- is_set_failed() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field failed is set (has been assigned a value) and false otherwise
- is_set_failed() - Method in class org.apache.storm.generated.SpoutStats
-
Returns true if field failed is set (has been assigned a value) and false otherwise
- is_set_fields() - Method in class org.apache.storm.generated.Grouping
- is_set_fragmented_cpu() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field fragmented_cpu is set (has been assigned a value) and false otherwise
- is_set_fragmented_mem() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field fragmented_mem is set (has been assigned a value) and false otherwise
- is_set_full_class_name() - Method in class org.apache.storm.generated.JavaObject
-
Returns true if field full_class_name is set (has been assigned a value) and false otherwise
- is_set_func_args() - Method in class org.apache.storm.generated.DRPCRequest
-
Returns true if field func_args is set (has been assigned a value) and false otherwise
- is_set_funcArgs() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
-
Returns true if field funcArgs is set (has been assigned a value) and false otherwise
- is_set_functionName() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
-
Returns true if field functionName is set (has been assigned a value) and false otherwise
- is_set_functionName() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
-
Returns true if field functionName is set (has been assigned a value) and false otherwise
- is_set_groups() - Method in class org.apache.storm.generated.LSTopoHistory
-
Returns true if field groups is set (has been assigned a value) and false otherwise
- is_set_gsid_to_input_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field gsid_to_input_stats is set (has been assigned a value) and false otherwise
- is_set_heartbeat() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
-
Returns true if field heartbeat is set (has been assigned a value) and false otherwise
- is_set_heartbeats() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
-
Returns true if field heartbeats is set (has been assigned a value) and false otherwise
- is_set_heatbeat() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
-
Returns true if field heatbeat is set (has been assigned a value) and false otherwise
- is_set_host() - Method in class org.apache.storm.generated.ErrorInfo
-
Returns true if field host is set (has been assigned a value) and false otherwise
- is_set_host() - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field host is set (has been assigned a value) and false otherwise
- is_set_host() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
-
Returns true if field host is set (has been assigned a value) and false otherwise
- is_set_host() - Method in class org.apache.storm.generated.NimbusSummary
-
Returns true if field host is set (has been assigned a value) and false otherwise
- is_set_host() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field host is set (has been assigned a value) and false otherwise
- is_set_host() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field host is set (has been assigned a value) and false otherwise
- is_set_hostname() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field hostname is set (has been assigned a value) and false otherwise
- is_set_hostname() - Method in class org.apache.storm.generated.WorkerMetrics
-
Returns true if field hostname is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.HBPulse
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getTopology_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field id is set (has been assigned a value) and false otherwise
- is_set_id_to_bolt_agg_stats() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field id_to_bolt_agg_stats is set (has been assigned a value) and false otherwise
- is_set_id_to_spout_agg_stats() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field id_to_spout_agg_stats is set (has been assigned a value) and false otherwise
- is_set_info() - Method in class org.apache.storm.generated.WorkerToken
-
Returns true if field info is set (has been assigned a value) and false otherwise
- is_set_initial_status() - Method in class org.apache.storm.generated.SubmitOptions
-
Returns true if field initial_status is set (has been assigned a value) and false otherwise
- is_set_inputs() - Method in class org.apache.storm.generated.ComponentCommon
-
Returns true if field inputs is set (has been assigned a value) and false otherwise
- is_set_int_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- is_set_is_include_sys() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
-
Returns true if field is_include_sys is set (has been assigned a value) and false otherwise
- is_set_is_include_sys() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
-
Returns true if field is_include_sys is set (has been assigned a value) and false otherwise
- is_set_is_include_sys() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
-
Returns true if field is_include_sys is set (has been assigned a value) and false otherwise
- is_set_ise() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
-
Returns true if field ise is set (has been assigned a value) and false otherwise
- is_set_isLeader() - Method in class org.apache.storm.generated.NimbusSummary
-
Returns true if field isLeader is set (has been assigned a value) and false otherwise
- is_set_isolated_node_guarantee() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field isolated_node_guarantee is set (has been assigned a value) and false otherwise
- is_set_ite() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
-
Returns true if field ite is set (has been assigned a value) and false otherwise
- is_set_ite() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
-
Returns true if field ite is set (has been assigned a value) and false otherwise
- is_set_ite() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
-
Returns true if field ite is set (has been assigned a value) and false otherwise
- is_set_ite() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
-
Returns true if field ite is set (has been assigned a value) and false otherwise
- is_set_java_object() - Method in class org.apache.storm.generated.ComponentObject
- is_set_jdk_version() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field jdk_version is set (has been assigned a value) and false otherwise
- is_set_json_conf() - Method in class org.apache.storm.generated.ComponentCommon
-
Returns true if field json_conf is set (has been assigned a value) and false otherwise
- is_set_jsonConf() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
-
Returns true if field jsonConf is set (has been assigned a value) and false otherwise
- is_set_jsonConf() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
-
Returns true if field jsonConf is set (has been assigned a value) and false otherwise
- is_set_kae() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
-
Returns true if field kae is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_key() - Method in class org.apache.storm.generated.PrivateWorkerKey
-
Returns true if field key is set (has been assigned a value) and false otherwise
- is_set_keys() - Method in class org.apache.storm.generated.ListBlobsResult
-
Returns true if field keys is set (has been assigned a value) and false otherwise
- is_set_kill_options() - Method in class org.apache.storm.generated.TopologyActionOptions
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_knf() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
-
Returns true if field knf is set (has been assigned a value) and false otherwise
- is_set_last_error() - Method in class org.apache.storm.generated.ComponentAggregateStats
-
Returns true if field last_error is set (has been assigned a value) and false otherwise
- is_set_launch_time_secs() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field launch_time_secs is set (has been assigned a value) and false otherwise
- is_set_local_or_shuffle() - Method in class org.apache.storm.generated.Grouping
- is_set_location() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
-
Returns true if field location is set (has been assigned a value) and false otherwise
- is_set_location() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
-
Returns true if field location is set (has been assigned a value) and false otherwise
- is_set_long_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- is_set_master_code_dir() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field master_code_dir is set (has been assigned a value) and false otherwise
- is_set_mem_off_heap() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field mem_off_heap is set (has been assigned a value) and false otherwise
- is_set_mem_on_heap() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field mem_on_heap is set (has been assigned a value) and false otherwise
- is_set_memory_guarantee() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field memory_guarantee is set (has been assigned a value) and false otherwise
- is_set_memory_guarantee_remaining() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field memory_guarantee_remaining is set (has been assigned a value) and false otherwise
- is_set_memory_usage() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field memory_usage is set (has been assigned a value) and false otherwise
- is_set_message_blob() - Method in class org.apache.storm.generated.HBMessageData
- is_set_message_id() - Method in class org.apache.storm.generated.HBMessage
-
Returns true if field message_id is set (has been assigned a value) and false otherwise
- is_set_meta() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
-
Returns true if field meta is set (has been assigned a value) and false otherwise
- is_set_meta() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
-
Returns true if field meta is set (has been assigned a value) and false otherwise
- is_set_meta() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field meta is set (has been assigned a value) and false otherwise
- is_set_metricList() - Method in class org.apache.storm.generated.WorkerMetrics
-
Returns true if field metricList is set (has been assigned a value) and false otherwise
- is_set_metricName() - Method in class org.apache.storm.generated.WorkerMetricPoint
-
Returns true if field metricName is set (has been assigned a value) and false otherwise
- is_set_metrics() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
-
Returns true if field metrics is set (has been assigned a value) and false otherwise
- is_set_metrics() - Method in class org.apache.storm.generated.WorkerMetricList
-
Returns true if field metrics is set (has been assigned a value) and false otherwise
- is_set_metricValue() - Method in class org.apache.storm.generated.WorkerMetricPoint
-
Returns true if field metricValue is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.AlreadyAliveException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.AuthorizationException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.DRPCExecutionException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.HBAuthorizationException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.HBExecutionException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.IllegalStateException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.InvalidTopologyException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.KeyNotFoundException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_msg() - Method in exception org.apache.storm.generated.NotAliveException
-
Returns true if field msg is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.AccessControl
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.activate_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.deactivate_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.debug_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.killTopology_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.SharedMemory
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.ThriftSerializedObject
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_name() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field name is set (has been assigned a value) and false otherwise
- is_set_named_logger_level() - Method in class org.apache.storm.generated.LogConfig
-
Returns true if field named_logger_level is set (has been assigned a value) and false otherwise
- is_set_nimbuses() - Method in class org.apache.storm.generated.ClusterSummary
-
Returns true if field nimbuses is set (has been assigned a value) and false otherwise
- is_set_node() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
-
Returns true if field node is set (has been assigned a value) and false otherwise
- is_set_node() - Method in class org.apache.storm.generated.NodeInfo
-
Returns true if field node is set (has been assigned a value) and false otherwise
- is_set_node_host() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field node_host is set (has been assigned a value) and false otherwise
- is_set_nodeInfo() - Method in class org.apache.storm.generated.ProfileRequest
-
Returns true if field nodeInfo is set (has been assigned a value) and false otherwise
- is_set_nodes() - Method in class org.apache.storm.generated.HBMessageData
- is_set_none() - Method in class org.apache.storm.generated.Grouping
- is_set_num_err_choice() - Method in class org.apache.storm.generated.GetInfoOptions
-
Returns true if field num_err_choice is set (has been assigned a value) and false otherwise
- is_set_num_executors() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field num_executors is set (has been assigned a value) and false otherwise
- is_set_num_executors() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field num_executors is set (has been assigned a value) and false otherwise
- is_set_num_executors() - Method in class org.apache.storm.generated.RebalanceOptions
-
Returns true if field num_executors is set (has been assigned a value) and false otherwise
- is_set_num_executors() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field num_executors is set (has been assigned a value) and false otherwise
- is_set_num_executors() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field num_executors is set (has been assigned a value) and false otherwise
- is_set_num_executors() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field num_executors is set (has been assigned a value) and false otherwise
- is_set_num_tasks() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field num_tasks is set (has been assigned a value) and false otherwise
- is_set_num_tasks() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field num_tasks is set (has been assigned a value) and false otherwise
- is_set_num_tasks() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field num_tasks is set (has been assigned a value) and false otherwise
- is_set_num_tasks() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field num_tasks is set (has been assigned a value) and false otherwise
- is_set_num_used_workers() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field num_used_workers is set (has been assigned a value) and false otherwise
- is_set_num_workers() - Method in class org.apache.storm.generated.RebalanceOptions
-
Returns true if field num_workers is set (has been assigned a value) and false otherwise
- is_set_num_workers() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field num_workers is set (has been assigned a value) and false otherwise
- is_set_num_workers() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field num_workers is set (has been assigned a value) and false otherwise
- is_set_num_workers() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field num_workers is set (has been assigned a value) and false otherwise
- is_set_num_workers() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field num_workers is set (has been assigned a value) and false otherwise
- is_set_off_heap_node() - Method in class org.apache.storm.generated.SharedMemory
-
Returns true if field off_heap_node is set (has been assigned a value) and false otherwise
- is_set_off_heap_worker() - Method in class org.apache.storm.generated.SharedMemory
-
Returns true if field off_heap_worker is set (has been assigned a value) and false otherwise
- is_set_on_heap() - Method in class org.apache.storm.generated.SharedMemory
-
Returns true if field on_heap is set (has been assigned a value) and false otherwise
- is_set_options() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
-
Returns true if field options is set (has been assigned a value) and false otherwise
- is_set_options() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
-
Returns true if field options is set (has been assigned a value) and false otherwise
- is_set_options() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
-
Returns true if field options is set (has been assigned a value) and false otherwise
- is_set_options() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
-
Returns true if field options is set (has been assigned a value) and false otherwise
- is_set_options() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
-
Returns true if field options is set (has been assigned a value) and false otherwise
- is_set_output_fields() - Method in class org.apache.storm.generated.StreamInfo
-
Returns true if field output_fields is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.LocalAssignment
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_owner() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field owner is set (has been assigned a value) and false otherwise
- is_set_parallelism_hint() - Method in class org.apache.storm.generated.ComponentCommon
-
Returns true if field parallelism_hint is set (has been assigned a value) and false otherwise
- is_set_path() - Method in class org.apache.storm.generated.HBMessageData
- is_set_port() - Method in class org.apache.storm.generated.ErrorInfo
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_port() - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_port() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_port() - Method in class org.apache.storm.generated.NimbusSummary
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_port() - Method in class org.apache.storm.generated.NodeInfo
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_port() - Method in class org.apache.storm.generated.WorkerMetrics
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_port() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field port is set (has been assigned a value) and false otherwise
- is_set_prev_status() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field prev_status is set (has been assigned a value) and false otherwise
- is_set_principal() - Method in class org.apache.storm.generated.RebalanceOptions
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- is_set_principal() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- is_set_process_latency_ms() - Method in class org.apache.storm.generated.BoltAggregateStats
-
Returns true if field process_latency_ms is set (has been assigned a value) and false otherwise
- is_set_process_ms_avg() - Method in class org.apache.storm.generated.BoltStats
-
Returns true if field process_ms_avg is set (has been assigned a value) and false otherwise
- is_set_profileRequest() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
-
Returns true if field profileRequest is set (has been assigned a value) and false otherwise
- is_set_pulse() - Method in class org.apache.storm.generated.HBMessageData
- is_set_pulseIds() - Method in class org.apache.storm.generated.HBNodes
-
Returns true if field pulseIds is set (has been assigned a value) and false otherwise
- is_set_pulses() - Method in class org.apache.storm.generated.HBRecords
-
Returns true if field pulses is set (has been assigned a value) and false otherwise
- is_set_rate() - Method in class org.apache.storm.generated.ExecutorStats
-
Returns true if field rate is set (has been assigned a value) and false otherwise
- is_set_rebalance_options() - Method in class org.apache.storm.generated.TopologyActionOptions
- is_set_records() - Method in class org.apache.storm.generated.HBMessageData
- is_set_replication() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
-
Returns true if field replication is set (has been assigned a value) and false otherwise
- is_set_replication_count() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field replication_count is set (has been assigned a value) and false otherwise
- is_set_replication_count() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field replication_count is set (has been assigned a value) and false otherwise
- is_set_replication_count() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field replication_count is set (has been assigned a value) and false otherwise
- is_set_replication_factor() - Method in class org.apache.storm.generated.SettableBlobMeta
-
Returns true if field replication_factor is set (has been assigned a value) and false otherwise
- is_set_request_id() - Method in class org.apache.storm.generated.DRPCRequest
-
Returns true if field request_id is set (has been assigned a value) and false otherwise
- is_set_requested_cpu() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field requested_cpu is set (has been assigned a value) and false otherwise
- is_set_requested_cpu() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field requested_cpu is set (has been assigned a value) and false otherwise
- is_set_requested_cpu() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_cpu is set (has been assigned a value) and false otherwise
- is_set_requested_cpu() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field requested_cpu is set (has been assigned a value) and false otherwise
- is_set_requested_cpu() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field requested_cpu is set (has been assigned a value) and false otherwise
- is_set_requested_generic_resources() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_generic_resources is set (has been assigned a value) and false otherwise
- is_set_requested_generic_resources() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field requested_generic_resources is set (has been assigned a value) and false otherwise
- is_set_requested_memoffheap() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field requested_memoffheap is set (has been assigned a value) and false otherwise
- is_set_requested_memoffheap() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_memoffheap is set (has been assigned a value) and false otherwise
- is_set_requested_memoffheap() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field requested_memoffheap is set (has been assigned a value) and false otherwise
- is_set_requested_memoffheap() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field requested_memoffheap is set (has been assigned a value) and false otherwise
- is_set_requested_memonheap() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field requested_memonheap is set (has been assigned a value) and false otherwise
- is_set_requested_memonheap() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_memonheap is set (has been assigned a value) and false otherwise
- is_set_requested_memonheap() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field requested_memonheap is set (has been assigned a value) and false otherwise
- is_set_requested_memonheap() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field requested_memonheap is set (has been assigned a value) and false otherwise
- is_set_requested_off_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field requested_off_heap_memory is set (has been assigned a value) and false otherwise
- is_set_requested_on_heap_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field requested_on_heap_memory is set (has been assigned a value) and false otherwise
- is_set_requested_regular_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_regular_off_heap_memory is set (has been assigned a value) and false otherwise
- is_set_requested_regular_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_regular_on_heap_memory is set (has been assigned a value) and false otherwise
- is_set_requested_shared_off_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_shared_off_heap_memory is set (has been assigned a value) and false otherwise
- is_set_requested_shared_on_heap_memory() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field requested_shared_on_heap_memory is set (has been assigned a value) and false otherwise
- is_set_requested_total_memory() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field requested_total_memory is set (has been assigned a value) and false otherwise
- is_set_reset_log_level() - Method in class org.apache.storm.generated.LogLevel
-
Returns true if field reset_log_level is set (has been assigned a value) and false otherwise
- is_set_reset_log_level_timeout_epoch() - Method in class org.apache.storm.generated.LogLevel
-
Returns true if field reset_log_level_timeout_epoch is set (has been assigned a value) and false otherwise
- is_set_reset_log_level_timeout_secs() - Method in class org.apache.storm.generated.LogLevel
-
Returns true if field reset_log_level_timeout_secs is set (has been assigned a value) and false otherwise
- is_set_resources() - Method in class org.apache.storm.generated.LocalAssignment
-
Returns true if field resources is set (has been assigned a value) and false otherwise
- is_set_resources() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field resources is set (has been assigned a value) and false otherwise
- is_set_resources_map() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field resources_map is set (has been assigned a value) and false otherwise
- is_set_resources_map() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field resources_map is set (has been assigned a value) and false otherwise
- is_set_resources_map() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field resources_map is set (has been assigned a value) and false otherwise
- is_set_result() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
-
Returns true if field result is set (has been assigned a value) and false otherwise
- is_set_samplingpct() - Method in class org.apache.storm.generated.DebugOptions
-
Returns true if field samplingpct is set (has been assigned a value) and false otherwise
- is_set_samplingPercentage() - Method in class org.apache.storm.generated.Nimbus.debug_args
-
Returns true if field samplingPercentage is set (has been assigned a value) and false otherwise
- is_set_sched_status() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field sched_status is set (has been assigned a value) and false otherwise
- is_set_sched_status() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field sched_status is set (has been assigned a value) and false otherwise
- is_set_sched_status() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field sched_status is set (has been assigned a value) and false otherwise
- is_set_scheduler_meta() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field scheduler_meta is set (has been assigned a value) and false otherwise
- is_set_script() - Method in class org.apache.storm.generated.ShellComponent
-
Returns true if field script is set (has been assigned a value) and false otherwise
- is_set_secretVersion() - Method in class org.apache.storm.generated.WorkerTokenInfo
-
Returns true if field secretVersion is set (has been assigned a value) and false otherwise
- is_set_serialized_java() - Method in class org.apache.storm.generated.ComponentObject
- is_set_serialized_parts() - Method in class org.apache.storm.generated.LocalStateData
-
Returns true if field serialized_parts is set (has been assigned a value) and false otherwise
- is_set_server_port() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field server_port is set (has been assigned a value) and false otherwise
- is_set_serviceType() - Method in class org.apache.storm.generated.WorkerToken
-
Returns true if field serviceType is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.BeginDownloadResult
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.ListBlobsResult
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_session() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
-
Returns true if field session is set (has been assigned a value) and false otherwise
- is_set_settable() - Method in class org.apache.storm.generated.ReadableBlobMeta
-
Returns true if field settable is set (has been assigned a value) and false otherwise
- is_set_shared_mem_off_heap() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field shared_mem_off_heap is set (has been assigned a value) and false otherwise
- is_set_shared_mem_on_heap() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field shared_mem_on_heap is set (has been assigned a value) and false otherwise
- is_set_shared_memory() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field shared_memory is set (has been assigned a value) and false otherwise
- is_set_shared_resources() - Method in class org.apache.storm.generated.WorkerResources
-
Returns true if field shared_resources is set (has been assigned a value) and false otherwise
- is_set_shell() - Method in class org.apache.storm.generated.ComponentObject
- is_set_shuffle() - Method in class org.apache.storm.generated.Grouping
- is_set_sid_to_output_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field sid_to_output_stats is set (has been assigned a value) and false otherwise
- is_set_signature() - Method in class org.apache.storm.generated.WorkerToken
-
Returns true if field signature is set (has been assigned a value) and false otherwise
- is_set_specific() - Method in class org.apache.storm.generated.ExecutorStats
-
Returns true if field specific is set (has been assigned a value) and false otherwise
- is_set_specific_stats() - Method in class org.apache.storm.generated.ComponentAggregateStats
-
Returns true if field specific_stats is set (has been assigned a value) and false otherwise
- is_set_spout() - Method in class org.apache.storm.generated.ExecutorSpecificStats
- is_set_spout() - Method in class org.apache.storm.generated.SpecificAggregateStats
- is_set_spout_object() - Method in class org.apache.storm.generated.SpoutSpec
-
Returns true if field spout_object is set (has been assigned a value) and false otherwise
- is_set_spouts() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field spouts is set (has been assigned a value) and false otherwise
- is_set_state_spout_object() - Method in class org.apache.storm.generated.StateSpoutSpec
-
Returns true if field state_spout_object is set (has been assigned a value) and false otherwise
- is_set_state_spouts() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field state_spouts is set (has been assigned a value) and false otherwise
- is_set_stats() - Method in class org.apache.storm.generated.ExecutorAggregateStats
-
Returns true if field stats is set (has been assigned a value) and false otherwise
- is_set_stats() - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field stats is set (has been assigned a value) and false otherwise
- is_set_status() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field status is set (has been assigned a value) and false otherwise
- is_set_status() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field status is set (has been assigned a value) and false otherwise
- is_set_status() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field status is set (has been assigned a value) and false otherwise
- is_set_status() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field status is set (has been assigned a value) and false otherwise
- is_set_storm_assignment() - Method in class org.apache.storm.generated.SupervisorAssignments
-
Returns true if field storm_assignment is set (has been assigned a value) and false otherwise
- is_set_storm_id() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
-
Returns true if field storm_id is set (has been assigned a value) and false otherwise
- is_set_storm_id() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
-
Returns true if field storm_id is set (has been assigned a value) and false otherwise
- is_set_storm_version() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field storm_version is set (has been assigned a value) and false otherwise
- is_set_storm_version() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field storm_version is set (has been assigned a value) and false otherwise
- is_set_storm_version() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field storm_version is set (has been assigned a value) and false otherwise
- is_set_storm_version() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field storm_version is set (has been assigned a value) and false otherwise
- is_set_streamId() - Method in class org.apache.storm.generated.GlobalStreamId
-
Returns true if field streamId is set (has been assigned a value) and false otherwise
- is_set_streamId() - Method in class org.apache.storm.generated.WorkerMetricPoint
-
Returns true if field streamId is set (has been assigned a value) and false otherwise
- is_set_streams() - Method in class org.apache.storm.generated.ComponentCommon
-
Returns true if field streams is set (has been assigned a value) and false otherwise
- is_set_string_arg() - Method in class org.apache.storm.generated.JavaObjectArg
- is_set_success() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_success() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- is_set_supervisor_id() - Method in class org.apache.storm.generated.LSSupervisorId
-
Returns true if field supervisor_id is set (has been assigned a value) and false otherwise
- is_set_supervisor_id() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field supervisor_id is set (has been assigned a value) and false otherwise
- is_set_supervisor_id() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
-
Returns true if field supervisor_id is set (has been assigned a value) and false otherwise
- is_set_supervisor_id() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field supervisor_id is set (has been assigned a value) and false otherwise
- is_set_supervisor_summaries() - Method in class org.apache.storm.generated.SupervisorPageInfo
-
Returns true if field supervisor_summaries is set (has been assigned a value) and false otherwise
- is_set_supervisors() - Method in class org.apache.storm.generated.ClusterSummary
-
Returns true if field supervisors is set (has been assigned a value) and false otherwise
- is_set_target_log_level() - Method in class org.apache.storm.generated.LogLevel
-
Returns true if field target_log_level is set (has been assigned a value) and false otherwise
- is_set_task_end() - Method in class org.apache.storm.generated.ExecutorInfo
-
Returns true if field task_end is set (has been assigned a value) and false otherwise
- is_set_task_start() - Method in class org.apache.storm.generated.ExecutorInfo
-
Returns true if field task_start is set (has been assigned a value) and false otherwise
- is_set_time_secs() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
-
Returns true if field time_secs is set (has been assigned a value) and false otherwise
- is_set_time_secs() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
-
Returns true if field time_secs is set (has been assigned a value) and false otherwise
- is_set_time_secs() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field time_secs is set (has been assigned a value) and false otherwise
- is_set_time_secs() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
-
Returns true if field time_secs is set (has been assigned a value) and false otherwise
- is_set_time_secs() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field time_secs is set (has been assigned a value) and false otherwise
- is_set_time_stamp() - Method in class org.apache.storm.generated.LSTopoHistory
-
Returns true if field time_stamp is set (has been assigned a value) and false otherwise
- is_set_time_stamp() - Method in class org.apache.storm.generated.ProfileRequest
-
Returns true if field time_stamp is set (has been assigned a value) and false otherwise
- is_set_timestamp() - Method in class org.apache.storm.generated.WorkerMetricPoint
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- is_set_tlsPort() - Method in class org.apache.storm.generated.NimbusSummary
-
Returns true if field tlsPort is set (has been assigned a value) and false otherwise
- is_set_topo_history() - Method in class org.apache.storm.generated.LSTopoHistoryList
-
Returns true if field topo_history is set (has been assigned a value) and false otherwise
- is_set_topo_ids() - Method in class org.apache.storm.generated.TopologyHistoryInfo
-
Returns true if field topo_ids is set (has been assigned a value) and false otherwise
- is_set_topologies() - Method in class org.apache.storm.generated.ClusterSummary
-
Returns true if field topologies is set (has been assigned a value) and false otherwise
- is_set_topology() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
-
Returns true if field topology is set (has been assigned a value) and false otherwise
- is_set_topology() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
-
Returns true if field topology is set (has been assigned a value) and false otherwise
- is_set_topology_action_options() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field topology_action_options is set (has been assigned a value) and false otherwise
- is_set_topology_conf() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field topology_conf is set (has been assigned a value) and false otherwise
- is_set_topology_conf_overrides() - Method in class org.apache.storm.generated.RebalanceOptions
-
Returns true if field topology_conf_overrides is set (has been assigned a value) and false otherwise
- is_set_topology_id() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field topology_id is set (has been assigned a value) and false otherwise
- is_set_topology_id() - Method in class org.apache.storm.generated.LocalAssignment
-
Returns true if field topology_id is set (has been assigned a value) and false otherwise
- is_set_topology_id() - Method in class org.apache.storm.generated.LSTopoHistory
-
Returns true if field topology_id is set (has been assigned a value) and false otherwise
- is_set_topology_id() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
-
Returns true if field topology_id is set (has been assigned a value) and false otherwise
- is_set_topology_id() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
-
Returns true if field topology_id is set (has been assigned a value) and false otherwise
- is_set_topology_id() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field topology_id is set (has been assigned a value) and false otherwise
- is_set_topology_name() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field topology_name is set (has been assigned a value) and false otherwise
- is_set_topology_name() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field topology_name is set (has been assigned a value) and false otherwise
- is_set_topology_resources_overrides() - Method in class org.apache.storm.generated.RebalanceOptions
-
Returns true if field topology_resources_overrides is set (has been assigned a value) and false otherwise
- is_set_topology_stats() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field topology_stats is set (has been assigned a value) and false otherwise
- is_set_topology_status() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field topology_status is set (has been assigned a value) and false otherwise
- is_set_topology_version() - Method in class org.apache.storm.generated.StormBase
-
Returns true if field topology_version is set (has been assigned a value) and false otherwise
- is_set_topology_version() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field topology_version is set (has been assigned a value) and false otherwise
- is_set_topology_version() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field topology_version is set (has been assigned a value) and false otherwise
- is_set_topologyId() - Method in class org.apache.storm.generated.WorkerMetrics
-
Returns true if field topologyId is set (has been assigned a value) and false otherwise
- is_set_topologyId() - Method in class org.apache.storm.generated.WorkerTokenInfo
-
Returns true if field topologyId is set (has been assigned a value) and false otherwise
- is_set_topoOwner() - Method in class org.apache.storm.generated.Credentials
-
Returns true if field topoOwner is set (has been assigned a value) and false otherwise
- is_set_total_executors() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field total_executors is set (has been assigned a value) and false otherwise
- is_set_total_node_shared() - Method in class org.apache.storm.generated.LocalAssignment
-
Returns true if field total_node_shared is set (has been assigned a value) and false otherwise
- is_set_total_resources() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field total_resources is set (has been assigned a value) and false otherwise
- is_set_total_shared_off_heap() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field total_shared_off_heap is set (has been assigned a value) and false otherwise
- is_set_total_tasks() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field total_tasks is set (has been assigned a value) and false otherwise
- is_set_total_topologies() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field total_topologies is set (has been assigned a value) and false otherwise
- is_set_total_workers() - Method in class org.apache.storm.generated.OwnerResourceSummary
-
Returns true if field total_workers is set (has been assigned a value) and false otherwise
- is_set_transferred() - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field transferred is set (has been assigned a value) and false otherwise
- is_set_transferred() - Method in class org.apache.storm.generated.ExecutorStats
-
Returns true if field transferred is set (has been assigned a value) and false otherwise
- is_set_type() - Method in class org.apache.storm.generated.AccessControl
-
Returns true if field type is set (has been assigned a value) and false otherwise
- is_set_type() - Method in class org.apache.storm.generated.ComponentAggregateStats
-
Returns true if field type is set (has been assigned a value) and false otherwise
- is_set_type() - Method in exception org.apache.storm.generated.DRPCExecutionException
-
Returns true if field type is set (has been assigned a value) and false otherwise
- is_set_type() - Method in class org.apache.storm.generated.HBMessage
-
Returns true if field type is set (has been assigned a value) and false otherwise
- is_set_uploadedJarLocation() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
-
Returns true if field uploadedJarLocation is set (has been assigned a value) and false otherwise
- is_set_uploadedJarLocation() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
-
Returns true if field uploadedJarLocation is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.NimbusSummary
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.TopologyInfo
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.TopologySummary
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_uptime_secs() - Method in class org.apache.storm.generated.WorkerSummary
-
Returns true if field uptime_secs is set (has been assigned a value) and false otherwise
- is_set_used_cpu() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field used_cpu is set (has been assigned a value) and false otherwise
- is_set_used_generic_resources() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field used_generic_resources is set (has been assigned a value) and false otherwise
- is_set_used_mem() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field used_mem is set (has been assigned a value) and false otherwise
- is_set_used_ports() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field used_ports is set (has been assigned a value) and false otherwise
- is_set_user() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
-
Returns true if field user is set (has been assigned a value) and false otherwise
- is_set_userName() - Method in class org.apache.storm.generated.PrivateWorkerKey
-
Returns true if field userName is set (has been assigned a value) and false otherwise
- is_set_userName() - Method in class org.apache.storm.generated.WorkerTokenInfo
-
Returns true if field userName is set (has been assigned a value) and false otherwise
- is_set_users() - Method in class org.apache.storm.generated.LSTopoHistory
-
Returns true if field users is set (has been assigned a value) and false otherwise
- is_set_version() - Method in class org.apache.storm.generated.BeginDownloadResult
-
Returns true if field version is set (has been assigned a value) and false otherwise
- is_set_version() - Method in class org.apache.storm.generated.NimbusSummary
-
Returns true if field version is set (has been assigned a value) and false otherwise
- is_set_version() - Method in class org.apache.storm.generated.ReadableBlobMeta
-
Returns true if field version is set (has been assigned a value) and false otherwise
- is_set_version() - Method in class org.apache.storm.generated.SupervisorInfo
-
Returns true if field version is set (has been assigned a value) and false otherwise
- is_set_version() - Method in class org.apache.storm.generated.SupervisorSummary
-
Returns true if field version is set (has been assigned a value) and false otherwise
- is_set_wait_secs() - Method in class org.apache.storm.generated.KillOptions
-
Returns true if field wait_secs is set (has been assigned a value) and false otherwise
- is_set_wait_secs() - Method in class org.apache.storm.generated.RebalanceOptions
-
Returns true if field wait_secs is set (has been assigned a value) and false otherwise
- is_set_window() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
-
Returns true if field window is set (has been assigned a value) and false otherwise
- is_set_window() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
-
Returns true if field window is set (has been assigned a value) and false otherwise
- is_set_window_to_acked() - Method in class org.apache.storm.generated.TopologyStats
-
Returns true if field window_to_acked is set (has been assigned a value) and false otherwise
- is_set_window_to_complete_latencies_ms() - Method in class org.apache.storm.generated.TopologyStats
-
Returns true if field window_to_complete_latencies_ms is set (has been assigned a value) and false otherwise
- is_set_window_to_emitted() - Method in class org.apache.storm.generated.TopologyStats
-
Returns true if field window_to_emitted is set (has been assigned a value) and false otherwise
- is_set_window_to_failed() - Method in class org.apache.storm.generated.TopologyStats
-
Returns true if field window_to_failed is set (has been assigned a value) and false otherwise
- is_set_window_to_stats() - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field window_to_stats is set (has been assigned a value) and false otherwise
- is_set_window_to_transferred() - Method in class org.apache.storm.generated.TopologyStats
-
Returns true if field window_to_transferred is set (has been assigned a value) and false otherwise
- is_set_worker_heartbeats() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
-
Returns true if field worker_heartbeats is set (has been assigned a value) and false otherwise
- is_set_worker_hooks() - Method in class org.apache.storm.generated.StormTopology
-
Returns true if field worker_hooks is set (has been assigned a value) and false otherwise
- is_set_worker_resources() - Method in class org.apache.storm.generated.Assignment
-
Returns true if field worker_resources is set (has been assigned a value) and false otherwise
- is_set_worker_summaries() - Method in class org.apache.storm.generated.SupervisorPageInfo
-
Returns true if field worker_summaries is set (has been assigned a value) and false otherwise
- is_set_workers() - Method in class org.apache.storm.generated.TopologyPageInfo
-
Returns true if field workers is set (has been assigned a value) and false otherwise
- is_success() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- is_success() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
- isAbsolutePath(String) - Static method in class org.apache.storm.utils.ServerUtils
- isAcked(Object) - Method in class org.apache.storm.testing.AckFailMapTracker
- isActive() - Method in class org.apache.storm.nimbus.AssignmentDistributionService
- isActive() - Method in class org.apache.storm.StormTimer.StormTimerTask
- isAlive() - Method in class org.apache.storm.scheduler.multitenant.Node
- isAlive() - Method in class org.apache.storm.scheduler.resource.RasNode
- isAnyPosixProcessPidDirAlive(Collection<Long>, String) - Static method in class org.apache.storm.utils.ServerUtils
-
Find if the process is alive using the existence of /proc/<pid> directory owned by the supplied user.
- isAnyPosixProcessPidDirAlive(Collection<Long>, String, boolean) - Static method in class org.apache.storm.utils.ServerUtils
-
Find if the process is alive using the existence of /proc/<pid> directory owned by the supplied expectedUser.
- isAnyProcessAlive(Collection<Long>, int) - Static method in class org.apache.storm.utils.ServerUtils
-
Are any of the processes alive and running for the specified userId.
- isAnyProcessAlive(Collection<Long>, String) - Static method in class org.apache.storm.utils.ServerUtils
-
Are any of the processes alive and running for the specified user.
- isAreKeysSkewed() - Method in class org.apache.storm.loadgen.OutputStream.Builder
- ISaslClient - Interface in org.apache.storm.messaging.netty
- ISaslServer - Interface in org.apache.storm.messaging.netty
- isAssignmentsBackendSynchronized() - Method in interface org.apache.storm.cluster.IStormClusterState
-
Flag to indicate if the assignments synced successfully, see
IStormClusterState.syncRemoteAssignments(Map)
. - isAssignmentsBackendSynchronized() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- isAuthorizedLogUser(String, String) - Method in class org.apache.storm.daemon.logviewer.utils.ResourceAuthorizer
-
Checks whether user is authorized to access file.
- isAutoAck() - Method in class org.apache.storm.jms.example.GenericBolt
- isBatch() - Method in class org.apache.storm.streams.ProcessorNode
- isBlackListed(String) - Method in class org.apache.storm.scheduler.Cluster
- isBlackListed(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Check is a given supervisor is on a blacklisted host.
- isBlacklistedHost(String) - Method in class org.apache.storm.scheduler.Cluster
- isBlacklistedHost(String) - Method in interface org.apache.storm.scheduler.ISchedulingState
-
Check if a given host is blacklisted.
- isCheckpoint(Tuple) - Static method in class org.apache.storm.spout.CheckpointSpout
- IScheduler - Interface in org.apache.storm.scheduler
- ISchedulingPriorityStrategy - Interface in org.apache.storm.scheduler.resource.strategies.priority
- ISchedulingState - Interface in org.apache.storm.scheduler
-
An interface that provides access to the current scheduling state.
- ISchemableSpout - Interface in org.apache.storm.spout
- isClientAuthRequired(Map<String, Object>) - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- isComplete() - Method in class org.apache.storm.messaging.netty.KerberosSaslNettyClient
- isComplete() - Method in class org.apache.storm.messaging.netty.SaslNettyClient
- isComplete() - Method in class org.apache.storm.security.auth.plain.SaslPlainServer
-
Deprecated.
- isConnected() - Method in class org.apache.storm.drpc.DRPCInvocationsClient
- isConnectionReady(IConnection) - Static method in class org.apache.storm.daemon.worker.WorkerState
- isCpuExclusive() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isDebug - Variable in class org.apache.storm.executor.Executor
- isDecorated(String, String) - Static method in class org.apache.storm.st.utils.StringDecorator
- isDependencies(StormTopology._Fields) - Static method in class org.apache.storm.utils.ThriftTopologyUtils
- isDistributed() - Method in class org.apache.storm.jdbc.spout.UserSpout
- isDistributed() - Method in class org.apache.storm.jms.spout.JmsSpout
-
Returns if the spout is distributed.
- isDistributed() - Method in class org.apache.storm.redis.topology.WordSpout
- isDslTopology() - Method in class org.apache.storm.flux.model.TopologyDef
- ISE - Enum constant in enum class org.apache.storm.generated.Nimbus.deleteBlob_result._Fields
- isEmitNullTuples() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
- isEmpty() - Method in class org.apache.storm.clojure.ClojureTuple
- isEmpty() - Method in class org.apache.storm.clojure.IndifferentAccessMap
- isEmpty() - Method in class org.apache.storm.messaging.netty.MessageBuffer
- isEmpty() - Method in class org.apache.storm.utils.ListDelegate
- isEmptyOverflow() - Method in class org.apache.storm.utils.JCQueue
- isEnable() - Method in class org.apache.storm.container.cgroup.SubSystem
- isEndOfDataFromStorage() - Method in class org.apache.storm.redis.state.RedisKeyValueStateIterator
- isEndOfDataFromStorage() - Method in class org.apache.storm.state.BaseBinaryStateIterator
-
Check whether end of data is reached from storage state KVs.
- isEndOfDataFromStorage() - Method in class org.apache.storm.state.BaseStateIterator
-
Check whether end of data is reached from storage state KVs.
- isEquivalentTo(PortAndAssignment) - Method in interface org.apache.storm.localizer.PortAndAssignment
- ISerializer - Interface in org.apache.storm.multilang
-
The ISerializer interface describes the methods that an object should implement to provide serialization and de-serialization capabilities to non-JVM language components.
- IServer - Interface in org.apache.storm.messaging.netty
- IServerMessageHandler - Interface in org.apache.storm.pacemaker
- isEvery(Collection<T>, Predicate<T>) - Static method in class org.apache.storm.Testing
-
Convenience method for data.stream.allMatch(pred).
- isExecAssignmentToWorkerValid(ExecutorDetails, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
-
Check if the assignment of the executor to the worker is valid.
- isExecAssignmentToWorkerValid(ExecutorDetails, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy
-
Check if any constraints are violated if exec is scheduled on worker.
- isExecCompDifferentFromPrior() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.SchedulingSearcherState
-
Check if the current executor has a different component from the previous one.
- isExecutorAssigned(ExecutorDetails) - Method in interface org.apache.storm.scheduler.SchedulerAssignment
-
Is the executor assigned or not.
- isExecutorAssigned(ExecutorDetails) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
- isExhausted() - Method in interface org.apache.storm.testing.CompletableSpout
-
Check whether spout is exhausted.
- isExhausted() - Method in class org.apache.storm.testing.FixedTupleSpout
- isExhausted() - Method in class org.apache.storm.testing.TestEventLogSpout
- isExpiredResetOnTrue() - Method in class org.apache.storm.kafka.spout.internal.Timer
-
Checks if a call to this method occurs later than
period
since the timer was initiated or reset. - isFailed(Object) - Method in class org.apache.storm.testing.AckFailMapTracker
- isFailure() - Method in class org.apache.storm.scheduler.resource.SchedulingResult
- isFake() - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
- isFieldAllowed(Field) - Static method in class org.apache.storm.validation.ConfigValidation
- isFullyDownloaded() - Method in class org.apache.storm.localizer.LocalizedResource
- isFullyDownloaded() - Method in class org.apache.storm.localizer.LocallyCachedBlob
- isFullyDownloaded() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
- isGlobalGrouping(Grouping) - Static method in class org.apache.storm.Thrift
- IShellMetric - Interface in org.apache.storm.metric.api.rpc
- isImpersonating() - Method in class org.apache.storm.security.auth.ReqContext
-
Check whether context is impersonating.
- isImpersonationAllowed() - Method in class org.apache.storm.security.auth.digest.JassPasswordProvider
- isImpersonationAllowed() - Method in interface org.apache.storm.security.auth.sasl.PasswordProvider
-
Should impersonation be allowed by this password provider.
- isImpersonationAllowed() - Method in enum class org.apache.storm.security.auth.ThriftConnectionType
-
Check if SASL impersonation is allowed for this transport type.
- isKeep(TridentTuple) - Method in class org.apache.storm.trident.operation.builtin.Debug
- isKeep(TridentTuple) - Method in class org.apache.storm.trident.operation.builtin.Equals
- isKeep(TridentTuple) - Method in class org.apache.storm.trident.operation.builtin.FilterNull
- isKeep(TridentTuple) - Method in class org.apache.storm.trident.operation.builtin.Negate
- isKeep(TridentTuple) - Method in interface org.apache.storm.trident.operation.Filter
-
Determines if a tuple should be filtered out of a stream.
- isKeep(TridentTuple) - Method in class org.apache.storm.trident.operation.impl.TrueFilter
- isKeep(TridentTuple) - Method in class org.apache.storm.trident.testing.TrueFilter
- isLeader() - Method in interface org.apache.storm.nimbus.ILeaderElector
-
Decide if the caller currently has the leader lock.
- isLeader() - Method in class org.apache.storm.nimbus.NimbusInfo
- isLeader() - Method in class org.apache.storm.testing.MockLeaderElector
- isLeader() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
- isLocal - Variable in class org.apache.storm.utils.NimbusClient
-
Indicates if this is a special client that is overwritten for local mode.
- isLocalhostAddress(String) - Static method in class org.apache.storm.utils.Utils
- isLocalMode(Map<String, Object>) - Static method in class org.apache.storm.utils.ConfigUtils
- isLocalOverride() - Static method in class org.apache.storm.utils.DRPCClient
-
Check local override.
- isLocalOverride() - Static method in class org.apache.storm.utils.NimbusClient
-
Is the local override set or not.
- isMemExclusive() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isMemHardwall() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isMemMigrate() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isMemoryLimitViolated(LocalAssignment) - Method in class org.apache.storm.daemon.supervisor.BasicContainer
- isMemoryLimitViolated(LocalAssignment) - Method in class org.apache.storm.daemon.supervisor.Container
-
Check if the container is over its memory limit AND needs to be killed.
- isMemPressureEnabled() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isMemSpreadPage() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isMemSpreadSlab() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isMounted(Hierarchy) - Method in class org.apache.storm.container.cgroup.CgroupCenter
- isMounted(Hierarchy) - Method in interface org.apache.storm.container.cgroup.CgroupOperation
-
check if a hiearchy is mounted.
- isNegativeVInt(byte) - Static method in class org.apache.storm.utils.WritableUtils
-
Given the first byte of a vint/vlong, determine the sign.
- isNextOffset(FileOffset) - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
- isNextOffset(FileOffset) - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
- isNimbusDaemon() - Method in class org.apache.storm.testing.MkClusterParam
- isNullTuple() - Method in class org.apache.storm.kafka.spout.KafkaSpoutMessageId
- isOffsetCommittedByThisTopology(TopicPartition, OffsetAndMetadata, Map<TopicPartition, OffsetManager>) - Method in class org.apache.storm.kafka.spout.internal.CommitMetadataManager
-
Checks if
OffsetAndMetadata
was committed by aKafkaSpout
instance in this topology. - ISOLATED_NODE_GUARANTEE - Enum constant in enum class org.apache.storm.generated.OwnerResourceSummary._Fields
- IsolatedPool - Class in org.apache.storm.scheduler.multitenant
-
A pool of machines that can be used to run isolated topologies.
- IsolatedPool(int) - Constructor for class org.apache.storm.scheduler.multitenant.IsolatedPool
- ISOLATION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
-
RegularExpression Id.
- ISOLATION_SCHEDULER_MACHINES - Static variable in class org.apache.storm.DaemonConfig
-
A map from topology name to the number of machines that should be dedicated for that topology.
- IsolationScheduler - Class in org.apache.storm.scheduler
- IsolationScheduler() - Constructor for class org.apache.storm.scheduler.IsolationScheduler
- isOneway() - Method in class org.apache.storm.generated.DistributedRPC.AsyncProcessor.execute
- isOneway() - Method in class org.apache.storm.generated.DistributedRPC.Processor.execute
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequest
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.failRequestV2
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.fetchRequest
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor.result
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequest
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.failRequestV2
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.fetchRequest
- isOneway() - Method in class org.apache.storm.generated.DistributedRPCInvocations.Processor.result
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.activate
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginBlobDownload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginCreateBlob
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginFileUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.beginUpdateBlob
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.cancelBlobUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.createStateInZookeeper
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.deactivate
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.debug
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.deleteBlob
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadBlobChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.downloadChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.finishBlobUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.finishFileUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobMeta
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getBlobReplication
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getClusterInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPageInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getComponentPendingProfileActions
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getLeader
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getLogConfig
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getNimbusConf
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getOwnerResourceSummaries
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorAssignments
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getSupervisorPageInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyConf
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyHistory
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByName
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoByNameWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyInfoWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologyPageInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaries
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummary
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getTopologySummaryByName
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.getUserTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.isRemoteBlobExists
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.isTopologyNameAllowed
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.killTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.killTopologyWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.listBlobs
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.processWorkerMetrics
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.rebalance
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.sendSupervisorWorkerHeartbeat
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.sendSupervisorWorkerHeartbeats
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setBlobMeta
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setLogConfig
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.setWorkerProfiler
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.submitTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.submitTopologyWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.updateBlobReplication
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadBlobChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.AsyncProcessor.uploadNewCredentials
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.activate
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.beginBlobDownload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.beginCreateBlob
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.beginFileUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.beginUpdateBlob
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.cancelBlobUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.createStateInZookeeper
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.deactivate
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.debug
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.deleteBlob
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.downloadBlobChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.downloadChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.finishBlobUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.finishFileUpload
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getBlobMeta
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getBlobReplication
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getClusterInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getComponentPageInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getComponentPendingProfileActions
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getLeader
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getLogConfig
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getNimbusConf
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getOwnerResourceSummaries
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getSupervisorAssignments
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getSupervisorPageInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyConf
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyHistory
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByName
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoByNameWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyInfoWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologyPageInfo
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummaries
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummary
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getTopologySummaryByName
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.getUserTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.isRemoteBlobExists
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.isTopologyNameAllowed
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.killTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.killTopologyWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.listBlobs
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.processWorkerMetrics
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.rebalance
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.sendSupervisorWorkerHeartbeat
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.sendSupervisorWorkerHeartbeats
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.setBlobMeta
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.setLogConfig
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.setWorkerProfiler
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.submitTopology
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.submitTopologyWithOpts
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.updateBlobReplication
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.uploadBlobChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.uploadChunk
- isOneway() - Method in class org.apache.storm.generated.Nimbus.Processor.uploadNewCredentials
- isOneway() - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.getLocalAssignmentForStorm
- isOneway() - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.sendSupervisorAssignments
- isOneway() - Method in class org.apache.storm.generated.Supervisor.AsyncProcessor.sendSupervisorWorkerHeartbeat
- isOneway() - Method in class org.apache.storm.generated.Supervisor.Processor.getLocalAssignmentForStorm
- isOneway() - Method in class org.apache.storm.generated.Supervisor.Processor.sendSupervisorAssignments
- isOneway() - Method in class org.apache.storm.generated.Supervisor.Processor.sendSupervisorWorkerHeartbeat
- isOnLinux() - Static method in class org.apache.storm.container.cgroup.CgroupManager
-
Extracting out to mock it for tests.
- isOnlyKillable() - Method in enum class org.apache.storm.daemon.supervisor.Container.ContainerType
- isOnWindows() - Static method in class org.apache.storm.utils.Utils
- isOomControl() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
- isOpen() - Method in class org.apache.storm.daemon.nimbus.TimedWritableByteChannel
- isOpen() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
- isOrderByProximity(Map<String, Object>) - Static method in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
- isOverride() - Method in class org.apache.storm.flux.model.IncludeDef
- isPacemakerStateStore() - Method in interface org.apache.storm.cluster.IStormClusterState
-
Flag to indicate if the Pacameker is backend store.
- isPacemakerStateStore() - Method in class org.apache.storm.cluster.StormClusterStateImpl
- isPersistent() - Method in class org.apache.storm.topology.base.BaseStatefulWindowedBolt
- isPersistent() - Method in interface org.apache.storm.topology.IStatefulWindowedBolt
-
If the stateful windowed bolt should have its windows persisted in state and maintain a subset of events in memory.
- ISpout - Interface in org.apache.storm.spout
-
ISpout is the core interface for implementing spouts.
- ISpoutOutputCollector - Interface in org.apache.storm.spout
-
Methods are not expected to be thread safe.
- ISpoutPartition - Interface in org.apache.storm.trident.spout
- isPreservesKey() - Method in class org.apache.storm.streams.ProcessorNode
- isPrimary() - Method in class org.apache.storm.sql.runtime.FieldInfo
- isPrimitiveBoolean(Class) - Static method in class org.apache.storm.flux.FluxBuilder
- isPrimitiveNumber(Class) - Static method in class org.apache.storm.flux.FluxBuilder
- isProcessAlive(long, String) - Static method in class org.apache.storm.utils.ServerUtils
-
Is a process alive and running?.
- isPunctuation(Object) - Static method in class org.apache.storm.streams.StreamUtil
- ISqlStreamsDataSource - Interface in org.apache.storm.sql.runtime
-
An ISqlStreamsDataSource specifies how an external data source produces and consumes data.
- isRas(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerUtils
-
Check if the scheduler is resource aware or not.
- isReady(long) - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutCoordinator
- isReady(long) - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.EmptyCoordinator
- isReady(long) - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Coordinator
-
Indicates whether this coordinator is ready to commit the given transaction.
- isReady(long) - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Coordinator
- isReady(long) - Method in interface org.apache.storm.trident.spout.ITridentSpout.BatchCoordinator
-
hint to Storm if the spout is ready for the transaction id.
- isReady(long) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Coordinator
- isReady(long) - Method in class org.apache.storm.trident.testing.FeederBatchSpout.FeederCoordinator
- isReady(Set<String>) - Method in interface org.apache.storm.nimbus.IWorkerHeartbeatsRecoveryStrategy
-
Function to decide if the heartbeats is ready.
- isReady(Set<String>) - Method in class org.apache.storm.nimbus.TimeOutWorkerHeartbeatsRecoveryStrategy
- isReady(KafkaSpoutMessageId) - Method in class org.apache.storm.kafka.spout.KafkaSpoutRetryExponentialBackoff
- isReady(KafkaSpoutMessageId) - Method in interface org.apache.storm.kafka.spout.KafkaSpoutRetryService
-
Checks if a specific failed
KafkaSpoutMessageId
is ready to be retried, i.e is scheduled and has retry time that is less than current time. - isRecovery() - Method in enum class org.apache.storm.daemon.supervisor.Container.ContainerType
- isReference() - Method in class org.apache.storm.flux.model.PropertyDef
- isRemoteBlobExists() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.isRemoteBlobExists
- isRemoteBlobExists() - Constructor for class org.apache.storm.generated.Nimbus.Processor.isRemoteBlobExists
- isRemoteBlobExists(String) - Method in class org.apache.storm.blobstore.ClientBlobStore
-
Decide if the blob is deleted from cluster.
- isRemoteBlobExists(String) - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
- isRemoteBlobExists(String) - Method in class org.apache.storm.blobstore.NimbusBlobStore
- isRemoteBlobExists(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
- isRemoteBlobExists(String) - Method in class org.apache.storm.generated.Nimbus.Client
- isRemoteBlobExists(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
-
Decide if the blob is removed from cluster.
- isRemoteBlobExists(String) - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
- isRemoteBlobExists(String) - Method in class org.apache.storm.LocalCluster
- isRemoteBlobExists(String, AsyncMethodCallback<Boolean>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
- isRemoteBlobExists(String, AsyncMethodCallback<Boolean>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
- isRemoteBlobExists_args() - Constructor for class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- isRemoteBlobExists_args(String) - Constructor for class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
- isRemoteBlobExists_args(Nimbus.isRemoteBlobExists_args) - Constructor for class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
-
Performs a deep copy on other.
- isRemoteBlobExists_call(String, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.isRemoteBlobExists_call
- isRemoteBlobExists_result() - Constructor for class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- isRemoteBlobExists_result(boolean, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
- isRemoteBlobExists_result(Nimbus.isRemoteBlobExists_result) - Constructor for class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
-
Performs a deep copy on other.
- isReportDimensionsEnabled(Map<String, Object>) - Static method in class org.apache.storm.metrics2.reporters.ScheduledStormReporter
- isResource() - Method in class org.apache.storm.flux.model.IncludeDef
- isResourceManaged() - Method in class org.apache.storm.container.cgroup.CgroupManager
- isResourceManaged() - Method in class org.apache.storm.container.DefaultResourceIsolationManager
-
This class doesn't really manage resources.
- isResourceManaged() - Method in class org.apache.storm.container.docker.DockerManager
- isResourceManaged() - Method in class org.apache.storm.container.oci.RuncLibContainerManager
- isResourceManaged() - Method in interface org.apache.storm.container.ResourceIsolationInterface
-
Return true if resources are being managed.
- isRoot() - Method in class org.apache.storm.container.cgroup.CgroupCommon
- isRoot() - Static method in class org.apache.storm.container.cgroup.SystemOperation
- isSchedLoadBlance() - Method in class org.apache.storm.container.cgroup.core.CpusetCore
- isScheduled(KafkaSpoutMessageId) - Method in class org.apache.storm.kafka.spout.KafkaSpoutRetryExponentialBackoff
- isScheduled(KafkaSpoutMessageId) - Method in interface org.apache.storm.kafka.spout.KafkaSpoutRetryService
-
Checks if a specific failed
KafkaSpoutMessageId
is scheduled to be retried. - isSecureLogviewer(Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIHelpers
-
Check if logviewer is secure.
- isServing() - Method in class org.apache.storm.security.auth.ThriftServer
-
Check whether serving.
- isSet(AccessControl._Fields) - Method in class org.apache.storm.generated.AccessControl
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(AlreadyAliveException._Fields) - Method in exception org.apache.storm.generated.AlreadyAliveException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Assignment._Fields) - Method in class org.apache.storm.generated.Assignment
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(AuthorizationException._Fields) - Method in exception org.apache.storm.generated.AuthorizationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(BeginDownloadResult._Fields) - Method in class org.apache.storm.generated.BeginDownloadResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Bolt._Fields) - Method in class org.apache.storm.generated.Bolt
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(BoltAggregateStats._Fields) - Method in class org.apache.storm.generated.BoltAggregateStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(BoltStats._Fields) - Method in class org.apache.storm.generated.BoltStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClusterSummary._Fields) - Method in class org.apache.storm.generated.ClusterSummary
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClusterWorkerHeartbeat._Fields) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(CommonAggregateStats._Fields) - Method in class org.apache.storm.generated.CommonAggregateStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ComponentAggregateStats._Fields) - Method in class org.apache.storm.generated.ComponentAggregateStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ComponentCommon._Fields) - Method in class org.apache.storm.generated.ComponentCommon
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ComponentPageInfo._Fields) - Method in class org.apache.storm.generated.ComponentPageInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Credentials._Fields) - Method in class org.apache.storm.generated.Credentials
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DebugOptions._Fields) - Method in class org.apache.storm.generated.DebugOptions
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPC.execute_args._Fields) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPC.execute_result._Fields) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.failRequest_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.failRequest_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.failRequestV2_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.failRequestV2_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.fetchRequest_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.fetchRequest_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.result_args._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DistributedRPCInvocations.result_result._Fields) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DRPCExecutionException._Fields) - Method in exception org.apache.storm.generated.DRPCExecutionException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DRPCRequest._Fields) - Method in class org.apache.storm.generated.DRPCRequest
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ErrorInfo._Fields) - Method in class org.apache.storm.generated.ErrorInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ExecutorAggregateStats._Fields) - Method in class org.apache.storm.generated.ExecutorAggregateStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ExecutorInfo._Fields) - Method in class org.apache.storm.generated.ExecutorInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ExecutorStats._Fields) - Method in class org.apache.storm.generated.ExecutorStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ExecutorSummary._Fields) - Method in class org.apache.storm.generated.ExecutorSummary
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(GetInfoOptions._Fields) - Method in class org.apache.storm.generated.GetInfoOptions
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(GlobalStreamId._Fields) - Method in class org.apache.storm.generated.GlobalStreamId
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(HBAuthorizationException._Fields) - Method in exception org.apache.storm.generated.HBAuthorizationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(HBExecutionException._Fields) - Method in exception org.apache.storm.generated.HBExecutionException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(HBMessage._Fields) - Method in class org.apache.storm.generated.HBMessage
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(HBNodes._Fields) - Method in class org.apache.storm.generated.HBNodes
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(HBPulse._Fields) - Method in class org.apache.storm.generated.HBPulse
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(HBRecords._Fields) - Method in class org.apache.storm.generated.HBRecords
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IllegalStateException._Fields) - Method in exception org.apache.storm.generated.IllegalStateException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(InvalidTopologyException._Fields) - Method in exception org.apache.storm.generated.InvalidTopologyException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(JavaObject._Fields) - Method in class org.apache.storm.generated.JavaObject
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KeyAlreadyExistsException._Fields) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KeyNotFoundException._Fields) - Method in exception org.apache.storm.generated.KeyNotFoundException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KillOptions._Fields) - Method in class org.apache.storm.generated.KillOptions
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ListBlobsResult._Fields) - Method in class org.apache.storm.generated.ListBlobsResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LocalAssignment._Fields) - Method in class org.apache.storm.generated.LocalAssignment
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LocalStateData._Fields) - Method in class org.apache.storm.generated.LocalStateData
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LogConfig._Fields) - Method in class org.apache.storm.generated.LogConfig
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LogLevel._Fields) - Method in class org.apache.storm.generated.LogLevel
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LSApprovedWorkers._Fields) - Method in class org.apache.storm.generated.LSApprovedWorkers
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LSSupervisorAssignments._Fields) - Method in class org.apache.storm.generated.LSSupervisorAssignments
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LSSupervisorId._Fields) - Method in class org.apache.storm.generated.LSSupervisorId
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LSTopoHistory._Fields) - Method in class org.apache.storm.generated.LSTopoHistory
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LSTopoHistoryList._Fields) - Method in class org.apache.storm.generated.LSTopoHistoryList
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(LSWorkerHeartbeat._Fields) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.activate_args._Fields) - Method in class org.apache.storm.generated.Nimbus.activate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.activate_result._Fields) - Method in class org.apache.storm.generated.Nimbus.activate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginBlobDownload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginBlobDownload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginCreateBlob_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginCreateBlob_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginFileUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginFileUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginUpdateBlob_args._Fields) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.beginUpdateBlob_result._Fields) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.cancelBlobUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.cancelBlobUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.createStateInZookeeper_args._Fields) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.createStateInZookeeper_result._Fields) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.deactivate_args._Fields) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.deactivate_result._Fields) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.debug_args._Fields) - Method in class org.apache.storm.generated.Nimbus.debug_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.debug_result._Fields) - Method in class org.apache.storm.generated.Nimbus.debug_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.deleteBlob_args._Fields) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.deleteBlob_result._Fields) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.downloadBlobChunk_args._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.downloadBlobChunk_result._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.downloadChunk_args._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.downloadChunk_result._Fields) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.finishBlobUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.finishBlobUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.finishFileUpload_args._Fields) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.finishFileUpload_result._Fields) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getBlobMeta_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getBlobMeta_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getBlobReplication_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getBlobReplication_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getClusterInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getClusterInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getComponentPageInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getComponentPageInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getComponentPendingProfileActions_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getComponentPendingProfileActions_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getLeader_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getLeader_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getLogConfig_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getLogConfig_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getNimbusConf_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getNimbusConf_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getOwnerResourceSummaries_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getOwnerResourceSummaries_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getSupervisorAssignments_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getSupervisorAssignments_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getSupervisorPageInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getSupervisorPageInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyConf_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyConf_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyHistory_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyHistory_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfoByName_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfoByName_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByName_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfoByNameWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfoByNameWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoByNameWithOpts_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfoWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyInfoWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyPageInfo_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologyPageInfo_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologySummaries_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologySummaries_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaries_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologySummary_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologySummary_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummary_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologySummaryByName_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getTopologySummaryByName_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getTopologySummaryByName_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getUserTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.getUserTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.isRemoteBlobExists_args._Fields) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.isRemoteBlobExists_result._Fields) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.isTopologyNameAllowed_args._Fields) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.isTopologyNameAllowed_result._Fields) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.killTopology_args._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.killTopology_result._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.killTopologyWithOpts_args._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.killTopologyWithOpts_result._Fields) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.listBlobs_args._Fields) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.listBlobs_result._Fields) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.processWorkerMetrics_args._Fields) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.processWorkerMetrics_result._Fields) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.rebalance_args._Fields) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.rebalance_result._Fields) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.sendSupervisorWorkerHeartbeat_args._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.sendSupervisorWorkerHeartbeat_result._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.sendSupervisorWorkerHeartbeats_args._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.sendSupervisorWorkerHeartbeats_result._Fields) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.setBlobMeta_args._Fields) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.setBlobMeta_result._Fields) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.setLogConfig_args._Fields) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Nimbus.setLogConfig_result._Fields) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
HdfsSpout.setArchiveDir(String)