Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W 

A

abort() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
abruptClose() - Method in class org.thales.punch.libraries.storm.bolt.impl.AsyncKafkaProducer
 
AbstractArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
 
AbstractArchiveBuffer(int, int, List<ArchiveDevice>) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
AbstractFileInput - Class in org.thales.punch.libraries.storm.spout
The file spout feeds messages into Storm from one or several files.
AbstractFileInput(NodeSettings, Logger) - Constructor for class org.thales.punch.libraries.storm.spout.AbstractFileInput
Ctor.
AbstractFileInput.Item - Class in org.thales.punch.libraries.storm.spout
Whenever something is read, it is enqueued so that stom can come pick it in nextTuple().
AbstractFileOutput - Class in org.thales.punch.libraries.storm.bolt
The file bolt writes the incoming tuples into archives.
AbstractFileOutput(NodeSettings, List<ArchiveDevice>, IFileNameSupplier, ArchiveFormatSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Ctor.
AbstractJDBCOutput - Class in org.thales.punch.libraries.storm.bolt
AbstractJDBCBolt provides common JDBC configuration (host, username, port, etc...).
AbstractJDBCOutput(NodeSettings, String) - Constructor for class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
AbstractKafkaNode - Class in org.thales.punch.libraries.storm.spout
Common kafka input node base class with standard kafka properties definition.
AbstractKafkaNode(NodeSettings, String, Logger) - Constructor for class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
Create a new Kafka spout
AbstractKafkaOutput - Class in org.thales.punch.libraries.storm.bolt
The KafkaBolt writes the content of storm tuples to Kafka topics.
AbstractKafkaOutput(NodeSettings, Properties) - Constructor for class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
The properties must only contain string.
AbstractKafkaOutput.Topic - Class in org.thales.punch.libraries.storm.bolt
Gather any information related to a topic.
AbstractSocketInput<T> - Class in org.thales.punch.libraries.storm.spout
Base class for socket servers spouts : http, lumberjack relp and plain syslog.
AbstractSocketInput(NodeSettings, Logger) - Constructor for class org.thales.punch.libraries.storm.spout.AbstractSocketInput
A Spout constructor is in charge of setting the fields that will be required later on when the spout will be effectively started and run somewhere in the cluster.
ack(Object) - Method in interface org.thales.punch.libraries.storm.core.topology.light.LightAcker
Ack a (spout) tuple.
ack(Tuple) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
This method is thread safe.
ack(Object) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
ack() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
Only after all anchors have acked will the tuple be acked to the originating spout.
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.AbstractSocketInput
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.AzureBlobStorageSpout
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.GeneratorInput
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.HttpInput
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.KafkaInput
 
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.SFTPSpout
commit will be done only if all emitted data have been ack If at least one emitted file is not ack, this topology will fail
ack(Object) - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
ackAll() - Method in class org.thales.punch.libraries.storm.bolt.OmniSciOutput
 
ackDocument(ElasticDocument) - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
ackFail - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
action - Variable in class org.thales.punch.libraries.storm.bolt.elasticsearch.FailureHandler
 
activate() - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
addBolt(LightBoltRunner) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
Register a bolt as part of this topology.
addBoltDispatcher(String, LightBoltDispatcher) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
addListeningAddress(ISettingsMap, LinkedBlockingQueue<INettyTuple<Map<String, String>>>) - Method in class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
 
addListeningAddress(ISettingsMap, ISyslogReceiver<T>) - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
Add a listening address to this server.
addLogFileTailerListener(LogFileTailerListener) - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
add a listener
addPunchletsBlock(List<String>, List<String>, int, String) - Method in class org.thales.punch.libraries.storm.util.PunchletConfig
 
addRuntimeData(Object, int, Object) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
 
addSpout(String, ISpout) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
Add a spout to the topology.
addSubscriber(LightBoltDispatcher, String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
A bolt dispatcher comes in to subscribe to tuples from a given stream
addSubscription(TopologyGraphNode) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
addTupleToQuery(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
Add a tuple to INSERT query.
allGrouping(String, String) - Method in interface org.thales.punch.libraries.storm.core.topology.IBoltDeclarer
 
allGrouping(String, String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDeclarer
 
allGrouping(String, String) - Method in class org.thales.punch.libraries.storm.core.topology.StormBoltDeclarer
 
archiveFormatSettings - Variable in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
The archive format settings.
ArchiveReaderNode - Class in org.thales.punch.libraries.storm.bolt
Node to read archive from provided metadata
ArchiveReaderNode(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.ArchiveReaderNode
Ctor
ArchiveReaderNodeFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build Archive Reader.
ArchiveReaderNodeFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.ArchiveReaderNodeFactory
Default constructor.
archiveTuple(Tuple, long, Iterable<String>) - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Marshal this tuple into the archive(s).
ArchiveUtils - Class in org.thales.punch.libraries.storm.util
 
AsyncKafkaProducer - Class in org.thales.punch.libraries.storm.bolt.impl
When writing to Kafka using the asynchronous API, in case of write error it is best to close the producer and reinit a new one.
AsyncKafkaProducer(Producer<byte[], byte[]>) - Constructor for class org.thales.punch.libraries.storm.bolt.impl.AsyncKafkaProducer
 
AtLeastOnceFileOutput - Class in org.thales.punch.libraries.storm.bolt.impl
The "At least once" version of the FileBolt.
In case of a topology failure/restart, duplicated Tuples will be found.
AtLeastOnceFileOutput(NodeSettings, List<ArchiveDevice>, IFileNameSupplier, ArchiveFormatSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.impl.AtLeastOnceFileOutput
Ctor
AvroParquetArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
The AvroParquetArchiveBuffer writes its content into S3 cluster or Filesystem.
AvroParquetArchiveBuffer(int, int, List<ArchiveDevice>, IRecordWriterBuilder<Map<String, Object>>, boolean) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
AzureBlobStorageSpout - Class in org.thales.punch.libraries.storm.spout
The AzureBlobStorageSpout enable you to pull data from a given container located in an Azure Blob Storage.
AzureBlobStorageSpout(NodeSettings, boolean) - Constructor for class org.thales.punch.libraries.storm.spout.AzureBlobStorageSpout
Constructor.
AzureBlobStorageSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Factory for the azure blob storage spout
AzureBlobStorageSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.AzureBlobStorageSpoutFactory
Ctor

B

BatchArchiver - Class in org.thales.punch.libraries.storm.bolt.file
An BatchArchiver is in charge of writing the incoming data to one or several destination.
BatchArchiver(BatchMetadata, ArchiveFormatSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Ctor.
BatchMap<T> - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
BatchMap(long, long) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
BatchMapKey - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
Unique ids for a batch are simply built by concatenating the batch number (monotonically increasing counter set up by the Kafka Spout) with the source partition number.
BatchMapKey(long, long) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMapKey
 
bind(String, Class<T>) - Static method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomBoltFactory
Jackson mapper
bind(String, Class<T>) - Static method in class org.thales.punch.libraries.storm.spout.factory.WrapperCustomSpoutFactory
Jackson mapper
boltFactories - Variable in class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
The registered bolt factories by type.
boltFactoryFor(String) - Method in class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
 
boltProducer - Variable in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
The Kafka producer used to send the message/records
build() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.ReporterBuilder
 
buildName(ITopologySettings) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
 
bulkSize - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
byteProducer - Variable in class org.thales.punch.libraries.storm.bolt.impl.AsyncKafkaProducer
the underlying kafka producer

C

cancel(LastEventOperator) - Static method in class org.thales.punch.libraries.storm.util.WatchDog
Stop verifying a watchdog lastEventOperator.
CephGzipArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
The CephGzipArchiveBuffer writes its content into a Ceph cluster.
CephGzipArchiveBuffer(int, int, List<ArchiveDevice>, IRecordEncoder<Map<String, Object>>, IRecordEncoder.RecordFormat) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.CephGzipArchiveBuffer
 
charset - Variable in class org.thales.punch.libraries.storm.spout.AbstractSocketInput
 
check() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
Check if this tuple has been emitted at least once.
CHECKPOINT_APPLICATION_RUNTIME_ID - Static variable in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
CHECKPOINT_ES_INDEX_PREFIX - Static variable in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
CHECKPOINT_ES_NODES - Static variable in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
CHECKPOINT_SETTINGS - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
checkStormStreamWiring(ISettingsMap, StormSettings) - Static method in class org.thales.punch.libraries.storm.bolt.factory.SyslogBoltFactory
This function checks that the storm streams declared in the storm settings of a bolt are inline with the ones contained in the destination settings.
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomOutput
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.FilterNode
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.impl.JdbcHandle
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.LumberjackOutput
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.ModuleNode
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.OmniSciOutput
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.PunchNode
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.RetentionNode
 
cleanup() - Method in class org.thales.punch.libraries.storm.bolt.SplitNode
 
CLEANUP - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
ClickHouseBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
ClickHouseBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.ClickHouseBoltFactory
 
ClickHouseOutput - Class in org.thales.punch.libraries.storm.bolt
This bolt will enable you to insert data into a ClickHouse database.
ClickHouseOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.ClickHouseOutput
 
close(List<String>) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
close(List<String>) - Method in interface org.thales.punch.libraries.storm.bolt.file.buffer.IArchiveBuffer
Close this archive buffer.
close(List<String>) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
close(List<String>) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
close() - Method in class org.thales.punch.libraries.storm.bolt.impl.KafkaOutputBoltPartitioner
 
close() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
close() - Method in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
close() - Method in class org.thales.punch.libraries.storm.spout.HttpInput
Close callback, notified by Storm runtime at topology deactivation.
close() - Method in class org.thales.punch.libraries.storm.spout.impl.HttpServer
 
close() - Method in class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
 
close() - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
Close the server
close() - Method in class org.thales.punch.libraries.storm.spout.impl.UdpSyslogServer
Close the server
close() - Method in class org.thales.punch.libraries.storm.spout.LumberjackInput
Close callback, notified by Storm runtime at topology deactivation.
close() - Method in class org.thales.punch.libraries.storm.spout.RelpInput
 
close() - Method in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
close() - Method in class org.thales.punch.libraries.storm.spout.SmtpInput
Close callback, notified by Storm runtime at topology deactivation.
close() - Method in class org.thales.punch.libraries.storm.spout.SyslogInput
Close callback, notified by Storm runtime at topology deactivation.
close() - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
closeRequested() - Method in class org.thales.punch.libraries.storm.bolt.impl.AsyncKafkaProducer
 
COLUMN_NAME_WRAPPER_CHAR_SETTING - Static variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
column_name_wrapper_char: This optional setting provides a DB-specific character that will be used around column names to allow for special characters in column names, like @
COLUMN_NAMES_SETTING - Static variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
Settings
COLUMN_TYPE_CAST - Static variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
COLUMN_TYPE_FUNCTION - Static variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
columnNames - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
columnNameWrapper - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
columnsNamesSeparator - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
componentId - Variable in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
compress(String) - Static method in class org.thales.punch.libraries.storm.impl.CompressionHelper
 
CompressionHelper - Class in org.thales.punch.libraries.storm.impl
This class provides methods to compress/decompress hasn maps.
CompressionHelper() - Constructor for class org.thales.punch.libraries.storm.impl.CompressionHelper
 
compressResources(Map<String, Object>) - Static method in class org.thales.punch.libraries.storm.impl.CompressionHelper
Compress all the String resources.
compute(Tuple, List<Operation>) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Record
Run the sequence of operations on an incoming tuple.
configure(Map<String, ?>) - Method in class org.thales.punch.libraries.storm.bolt.impl.KafkaOutputBoltPartitioner
 
ConstantAdditionalValue - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
A constant key value IAdditionalValue.
ConstantAdditionalValue(Object, String) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.ConstantAdditionalValue
Ctor.
CONSUMER_MODE - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
CONSUMER_MODE_DEFAULT - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
contains(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
convert(Tuple) - Method in interface org.thales.punch.libraries.storm.bolt.impl.IInputTupleConverter
 
convert(StreamDeclaration, T) - Method in interface org.thales.punch.libraries.storm.bolt.impl.IOutputTupleConverter
 
convert(Tuple) - Method in class org.thales.punch.libraries.storm.converter.InputTupleConverterImpl
Transformation between Storm Tuple to Punch Tuple
convert(StreamDeclaration, Tuple) - Method in class org.thales.punch.libraries.storm.converter.OutputTupleConverterImpl
Transformation between Punch Tuple from module to Object List
CONVERT_BOOLEAN_TO_INT_SETTING - Static variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
convert_boolean_to_int: if true, then the boolean value will be converted to 0 or 1 integer value at insert
convertBooleanToInt - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
CountFieldOperation - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
CountFieldOperation(String, String) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.CountFieldOperation
 
CountFieldValueOperation - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
CountFieldValueOperation(String, String, long, String) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.CountFieldValueOperation
 
CountOperation - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
CountOperation(String) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.CountOperation
 
createArchiver(BatchMetadata) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Create correct BatchArchiver from metadata
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.ArchiveReaderNodeFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.ClickHouseBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.DistinctLogCounterBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.ElasticSearchOutputFactory
Create en ElasticSearch bolt.
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.FileOutputFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.FileTransferBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.FilterBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.HttpBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.KafkaBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.LumberjackBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.OmniSciBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.PostgresqlBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltDispatcherFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.RawPacketBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.RetentionBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.RythmerBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.SplitBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.SyslogBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.SyslogUdpBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.TestBoltFactory
 
createBolt(IPlatform, NodeSettings, ITopologySettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomBoltFactory
 
createComponentSettings(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.bolt.factory.KafkaBoltFactory
Creates settings needed by the Kafka producer.
createConfig(ITopologySettings) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
Creates a Storm topology configuration from an PunchPlatform configuration.
createEmbeddedTopology(ITopologySettings, List<String>) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
 
createLocalTopology(ITopologySettings, List<String>) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
 
createRemoteTopology(ITopologySettings, String, List<String>) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
 
createRoot - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.AzureBlobStorageSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.ExtractionInputFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.FileSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.GeneratorSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.HttpSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.KafkaSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.LumberjackSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.NSGAzureBlobStorageSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.SnmpSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.SyslogSpoutFactory
 
createSpout(NodeSettings, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.spout.factory.WrapperCustomSpoutFactory
 
createTopology(ITopologyBuilder, ITopologySettings, IPunchPlatformProperties) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
Build a Storm or embedded topology from an PunchPlatform configuration.

D

database - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
DATE_PATTERN - Static variable in class org.thales.punch.libraries.storm.core.topology.TopologyFactory
The pattern appended to the topology name.
DateAdditionalValue - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
A small utility builder class to efficiently generate a json line containing the current time as a correctly formatted string.
DateAdditionalValue(String, String, String) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.DateAdditionalValue
 
deactivate() - Method in class org.thales.punch.libraries.storm.spout.HttpInput
 
deactivate() - Method in class org.thales.punch.libraries.storm.spout.LumberjackInput
 
deactivate() - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
declare(Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightOutputDeclarer
 
declare(boolean, Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightOutputDeclarer
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.bolt.LumberjackOutput
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.bolt.ModuleNode
This bolt does not add any new field to the stream.
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.bolt.SplitNode
This bolt does not add any new field to the stream.
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.bolt.SyslogOutput
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.bolt.SyslogUdpOutput
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
declareStream(String, Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
Make this component publish some fields over a stream
declareStream(String, Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightOutputDeclarer
 
declareStream(String, boolean, Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightOutputDeclarer
 
decompress(byte[]) - Static method in class org.thales.punch.libraries.storm.impl.CompressionHelper
 
decPendingCount() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
DEFAULT_HOST - Static variable in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
DEFAULT_MODE - Static variable in class org.thales.punch.libraries.storm.spout.factory.ExtractionInputFactory
 
DEFAULT_PORT - Static variable in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
deserialize(EthernetPacket) - Method in enum org.thales.punch.libraries.storm.bolt.rawpacket.EthernetPacketDeserializers
 
deserialize(EthernetPacket) - Method in interface org.thales.punch.libraries.storm.bolt.rawpacket.IEthernetPacketDeserializer
 
deserialize(byte[]) - Method in class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
 
deserialize(ByteBuffer) - Method in class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
 
deserializeString(byte[]) - Static method in class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
 
destinations - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
DirWatcher - Class in org.thales.punch.libraries.storm.util
DirWatcher is a TimerTask class that periodically watch changes on a defined directory.
DirWatcher(String, String) - Constructor for class org.thales.punch.libraries.storm.util.DirWatcher
Constructor of the class.
DirWatcher(String, String, FileTime) - Constructor for class org.thales.punch.libraries.storm.util.DirWatcher
Constructor of the class.
DistinctLogCounterBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a the distinct log counter bolt
DistinctLogCounterBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.DistinctLogCounterBoltFactory
Default constructor.
DistinctLogCounterNode - Class in org.thales.punch.libraries.storm.bolt
Count the distinct log, differentiated with their sequence identifier
DistinctLogCounterNode(NodeSettings, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.bolt.DistinctLogCounterNode
Create a new SplitBolt
DOWNLOAD_ADD_SUFFIX - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
DOWNLOAD_IGNORE_SUFFIX - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
DOWNLOAD_PATH - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
drainNextLogs() - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
 

E

EArchiverType - Enum in org.thales.punch.libraries.storm.bolt.file
Defines the supported archiver implementation.
ElasticBulkRequest - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
This class only takes care of executing a single bulk request for the regular input document.
ElasticBulkRequest(ElasticsearchOutput, RestHighLevelClient, BulkRequest, ElasticDocument[], int) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
ElasticDocument - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
A transient data structure to hold a document in the pipe to be sent to elasticsearch
ElasticDocument(Tuple, String, String, String, String) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
ElasticDocumentBuilder - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
A utility class to build the final json document from the fields received in a storm tuple.
ElasticDocumentBuilder(ISettingsMap) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
 
ElasticErrorBulkRequest - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
This class only takes care of executing a single bulk request to reindex error documents.
ElasticErrorBulkRequest(ElasticsearchOutput, RestHighLevelClient, BulkRequest, List<ElasticDocument>) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticErrorBulkRequest
 
ElasticRequestRunnable - Class in org.thales.punch.libraries.storm.spout.es.wrapper.plugins
 
ElasticRequestRunnable(LinkedBlockingQueue<String>, ElasticClientWrapper, ConcurrentMap<String, Object>) - Constructor for class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.ElasticRequestRunnable
 
ElasticsearchOutput - Class in org.thales.punch.libraries.storm.bolt
The Elasticsearch output node sends tuples to Elasticsearch.
ElasticsearchOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
Constructor
ElasticSearchOutputFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Setup an elasticsearch bolt.
ElasticSearchOutputFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.ElasticSearchOutputFactory
Default constructor.
emit(String, Collection<Tuple>, List<Object>) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
Emit a new tuple, anchored by another one.
emit(String, List<Object>, LightTuple) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltRunner
Emit a tuple from a bolt.
emit(String, List<Object>, Object) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
Emit a spout tuple.
emit(String, List<Object>, Object) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
 
emitDirect(int, String, List<Object>, Object) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
emitNextLine(String, Map<String, String>) - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
 
equals(Object) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMapKey
 
equals(Object) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.RecordKey
 
equals(Object) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
errorStream - Variable in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
The error stream is used to forward error documents
EthernetPacketDeserializers - Enum in org.thales.punch.libraries.storm.bolt.rawpacket
 
execute(Timer.Context, Counter, Every) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
execute(Timer.Context, Counter, Every) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticErrorBulkRequest
 
exit(Exception) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
Exit archiving.
exit(Exception) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
exitOnFailure - Variable in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
Make the process exit if the writing to Kafka fails
expirationTimeout - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
ExtractionInput - Class in org.thales.punch.libraries.storm.spout
Light topology elastic input node designed for extraction
ExtractionInput(NodeSettings, List<ISettingsMap>, List<ISettingsMap>, ISettingsMap, ISettingsMap, String) - Constructor for class org.thales.punch.libraries.storm.spout.ExtractionInput
 
ExtractionInputFactory - Class in org.thales.punch.libraries.storm.spout.factory
 
ExtractionInputFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.ExtractionInputFactory
 

F

factory(ISettingsMap) - Static method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Operation
 
fail(Object) - Method in interface org.thales.punch.libraries.storm.core.topology.light.LightAcker
Fail a (spout) tuple.
fail(Tuple) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
This method is thread safe.
fail(Object) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
fail() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
Once a tuple is failed, subsequent fail or acks are discarded.
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.AbstractSocketInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.AzureBlobStorageSpout
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.GeneratorInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.HttpInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.KafkaInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.LumberjackInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.SyslogInput
 
fail(Object) - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
failAll() - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
failDocument(ElasticDocument) - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
failed - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
Ths queue holds failed tuples, the failed lines of data that must be reemitted.
failSleep - Variable in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
True to make the input_node sleep in case it receives a failed tuple
failStop - Variable in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
True to make the input_node exit in case it receives a failed tuple
FailureHandler - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
 
FailureHandler(String, String) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.FailureHandler
 
FailureHandler.FailureAction - Enum in org.thales.punch.libraries.storm.bolt.elasticsearch
 
failuresDelayMs - Variable in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
Time to sleep in ms after it receives a failed tuple
fatalException(Exception) - Static method in class org.thales.punch.libraries.storm.util.ArchiveUtils
Log a fatal exception and exit.
FieldAdditionalValue - Class in org.thales.punch.libraries.storm.bolt.elasticsearch
A key value IAdditionalValue that takes its value from a storm tuple.
FieldAdditionalValue(String, String) - Constructor for class org.thales.punch.libraries.storm.bolt.elasticsearch.FieldAdditionalValue
 
fieldIndex(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
fieldName - Variable in class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
 
fieldsGrouping(String, String, Fields) - Method in interface org.thales.punch.libraries.storm.core.topology.IBoltDeclarer
 
fieldsGrouping(String, String, Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDeclarer
 
fieldsGrouping(String, String, Fields) - Method in class org.thales.punch.libraries.storm.core.topology.StormBoltDeclarer
 
FILE_COMPLETE_MARKER - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
filename - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
fileNameSupplier - Variable in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
This supplier is in charge of providing us with the identifier of each batch.
FileOutputFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build correct FileBolt.
FileOutputFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.FileOutputFactory
Default constructor.
FileRecord - Class in org.thales.punch.libraries.storm.util
This class holds a file and keeps track of what has been read so far.
FileRecord(File) - Constructor for class org.thales.punch.libraries.storm.util.FileRecord
Creates a new FileRecord
FileSpout - Class in org.thales.punch.libraries.storm.spout.impl
The original implementation of the File Spout.
FileSpout(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.impl.FileSpout
 
FileSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Create regular and watcher file spouts.
FileSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.FileSpoutFactory
Default constructor.
FileSpoutWatcher - Class in org.thales.punch.libraries.storm.spout.impl
The "Watcher" implementation of the File Spout.
FileSpoutWatcher(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.impl.FileSpoutWatcher
Ctor.
FileTransferBolt - Class in org.thales.punch.libraries.storm.bolt
This node enable you to transfer file located on your filesystem to somewhere else: S3, Hadoop, FileSystem (based on supported sink point of avro-parquet lib)
FileTransferBolt(NodeSettings, String, String, ISettingsMap) - Constructor for class org.thales.punch.libraries.storm.bolt.FileTransferBolt
 
FileTransferBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
FileTransferBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.FileTransferBoltFactory
 
FilterBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
FilterBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.FilterBoltFactory
 
FilterNode - Class in org.thales.punch.libraries.storm.bolt
The Filter bolt provides useful, simple, yet efficient filtering capabilities with low cpu usage.
FilterNode(NodeSettings, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.bolt.FilterNode
Create a new Filter
fire(long, Logger) - Static method in class org.thales.punch.libraries.storm.util.WatchDog
Return a punch LastEventOperator register into a singleton watchdog.
fireNewLogFileLine(String, Map<String, String>) - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
 
flush(BatchArchiver) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Flush this batch, i.e.
flush() - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Flush your archive.
flush() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
 
flush() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
formatColumnForAutoCast(Object) - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
formatColumnForAutoCast(Object) - Method in class org.thales.punch.libraries.storm.bolt.PostgresqlOutput
 
formatColumnForFunction(Object) - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
forwardOrFailDocument(ElasticDocument, String) - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 

G

GeneratorInput - Class in org.thales.punch.libraries.storm.spout
The generator publishes fake data in configurable streams.
GeneratorInput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.GeneratorInput
Create a new Generator spout
GeneratorSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Generator Spout factory
GeneratorSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.GeneratorSpoutFactory
Default constructor.
get(String) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
get() - Method in class org.thales.punch.libraries.storm.bolt.file.ObjectStorageFileNameSupplier
 
getAdditionalValue(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ConstantAdditionalValue
This method returns a ready to use ",\"key\": value" string
getAdditionalValue(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.DateAdditionalValue
This method returns a ready to be inserted timestamp json line.
getAdditionalValue(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.FieldAdditionalValue
This method returns a ready to be inserted value
getAdditionalValue(Tuple) - Method in interface org.thales.punch.libraries.storm.bolt.elasticsearch.IAdditionalValue
This method returns a ready to use "\"key\":value" string
getAnchor() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getAnchoredTuple() - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Getter for anchored tuple
getAttachement() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
The attachement is an arbitrary object attached to that tuple.
getBatchMetadata() - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
An BatchArchiver is handling a single batch.
getBatchOutputPath() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
Return full batch path from metadata.
getBinary(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getBinaryByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getBloomFilterFields() - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Getter for bloom fields.
getBoltDispatcherById(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getBoltRcvQueueSize() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getBoltTuple(String, String, List<Object>, Fields, LightTuple) - Static method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
Build a new bolt tuple.
getBoolean(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getBooleanByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getByte(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getByteArray() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.GzipArchiveBuffer
 
getByteArray() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
Get final byte array
getByteByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getBytes(Long) - Method in class org.thales.punch.libraries.storm.util.FileRecord
Reads the file
getClonedBoltInstance() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDispatcher
This method re-serialize a fresh new tuple instance from the original bolt.
getCodec(ISettingsMap) - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
Build specific codec from config
getCodec(ISettingsMap) - Static method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
Build specific codec from the caller configuration.
getComponentById(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomOutput
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.impl.AtLeastOnceFileOutput
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.OmniSciOutput
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.PunchNode
We request from storm a regular callback.
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.bolt.RetentionNode
 
getComponentConfiguration() - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
getComponentId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDispatcher
 
getComponentId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
getComponentNode(String) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraph
 
getComponentTasks(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
getContext() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getCreatedTime() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getDefaultColumnNameWrapperChar() - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
getDefaultColumnNameWrapperChar() - Method in class org.thales.punch.libraries.storm.bolt.ClickHouseOutput
 
getDefaultConvertBooleanToInt() - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
getDefaultConvertBooleanToInt() - Method in class org.thales.punch.libraries.storm.bolt.ClickHouseOutput
 
getDeserializer(String) - Static method in enum org.thales.punch.libraries.storm.bolt.rawpacket.EthernetPacketDeserializers
 
getDigest() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
getDigest() - Method in interface org.thales.punch.libraries.storm.bolt.file.buffer.IArchiveBuffer
Return the digest of written bytes
getDigest() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
getDigest() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
getDocumentIdField() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
 
getDocumentType() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
Type mapping are deprecated since ES7, but we still need compatibility with older clusters.
getDocumentValue(Tuple, String) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
 
getDouble(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getDoubleByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getEarliest() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
getElapsedTime() - Method in class org.thales.punch.libraries.storm.util.LoadControlItem
 
getEmitterNodeId() - Method in class org.thales.punch.libraries.storm.core.topology.StreamSubscription
 
getErrorDocument(String, String, String) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
getExecutors() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDispatcher
 
getExpirationCause() - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Getter for expiration cause
getFields() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getFile() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getFileAttributes() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getFloat(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getFloatByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getGroks() - Method in class org.thales.punch.libraries.storm.util.PunchletConfig
 
getHashId() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Key
 
getId() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
getId(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
 
getId() - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
getIndex() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
getIndex(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
Return the target index depending on the input configuration
getInputQueue() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDispatcher
 
getInstance() - Static method in class org.thales.punch.libraries.storm.util.WhiteBoard
The getInstance method is in charge of returning the singleton static instance of the whiteboard object.
getInstanceId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getInteger(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getIntegerByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getJdbcClient() - Method in class org.thales.punch.libraries.storm.bolt.impl.JdbcHandle
 
getJsonResources() - Method in class org.thales.punch.libraries.storm.util.PunchletConfig
 
getKey() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ConstantAdditionalValue
 
getKey() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.DateAdditionalValue
 
getKey() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.FieldAdditionalValue
 
getKey() - Method in interface org.thales.punch.libraries.storm.bolt.elasticsearch.IAdditionalValue
 
getLastModTime() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getLastRead() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getLatest() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
getLightOutputCollector() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltRunner
 
getLightSpoutOutputCollector() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
getLine() - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput.Item
 
getListFiles(File) - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
This method constructs a list of files to process from different format, in subfolders or compressed.
getLong(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getLongByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getLongField(ITuple, String, Long) - Static method in class org.thales.punch.libraries.storm.util.ArchiveUtils
 
getMandatoryIntegerField(ITuple, String) - Static method in class org.thales.punch.libraries.storm.util.ArchiveUtils
Fast fail if a mandatory integer field is missing.
getMandatoryLongField(ITuple, String) - Static method in class org.thales.punch.libraries.storm.util.ArchiveUtils
Fast fail if a mandatory long field is missing.
getMaxSpoutPending() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getMessageId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getMessageId() - Method in class org.thales.punch.libraries.storm.util.LoadControlItem
 
getMessageTimeoutSec() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getName() - Method in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput.Topic
 
getName() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Operation
 
getOutputFields() - Method in class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
 
getPayload() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
getPendingCount() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
getProperties() - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput.Item
 
getPublishedStreamConfig(NodeSettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.KafkaBoltFactory
 
getPublishedStreamConfig(NodeSettings) - Method in class org.thales.punch.libraries.storm.bolt.factory.LumberjackBoltFactory
 
getPublishedStreamConfig(NodeSettings) - Method in class org.thales.punch.libraries.storm.spout.factory.GeneratorSpoutFactory
 
getPublishedStreamConfig(NodeSettings) - Method in class org.thales.punch.libraries.storm.spout.factory.KafkaSpoutFactory
 
getPublishedStreams() - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
getPunchletBlocks() - Method in class org.thales.punch.libraries.storm.util.PunchletConfig
 
getPunchletConfig(ISettingsMap, String, String, ITopologySettings) - Static method in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltFactory
Load all the required resource and punchlet files and return a ready to use PunchletConfig.
getPunchletConfig(ISettingsMap, String, String, ITopologySettings, String, Path) - Static method in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltFactory
This method looks for punchlets in a local configuration directory.
getPunchletConfig(ISettingsMap, ITopologySettings, String) - Static method in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltFactory
 
getQueue() - Method in class org.thales.punch.libraries.storm.spout.impl.HttpServer
 
getRefCount() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getRuntimeData(Object, int) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
 
getShort(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getShortByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getSiddhiRules() - Method in class org.thales.punch.libraries.storm.util.PunchletConfig
 
getSize() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
getSize() - Method in interface org.thales.punch.libraries.storm.bolt.file.buffer.IArchiveBuffer
Return the size, compressed if compression enabled, of written bytes
getSize() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
getSize() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
getSize() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getSizeLeft() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getSocketHostAddress(InetSocketAddress) - Method in class org.thales.punch.libraries.storm.spout.AbstractSocketInput
 
getSourceComponent() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getSourceGlobalStreamId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getSourceStreamId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getSourceTask() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getSpout() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
getSpoutById(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getSpoutTuple(String, String, List<Object>, Fields, Object) - Static method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
Build a new spout tuple.
getStormId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getStormId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
getStormTopology() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getStormTopologyPluginsJarPaths() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
getStreamId() - Method in class org.thales.punch.libraries.storm.core.topology.StreamSubscription
 
getString(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getStringByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getStringResources() - Method in class org.thales.punch.libraries.storm.util.PunchletConfig
 
getSubscriptions() - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
getTargetTopic(String) - Method in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
 
getThisComponentId() - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
getThisTaskIndex() - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
getThisWorkerPort() - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
getThisWorkerTasks() - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
getTickTuple() - Static method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getTimestampFromTuple(ITuple) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Extracts a timestamp from the received tuple.
getTmpName() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
getTopology() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopologyBuilder
 
getTopology() - Method in class org.thales.punch.libraries.storm.core.topology.StormTopologyBuilder
 
getTopologyContext() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
The associated topology context is actually per component, as it provides per component informations such as the component identifier.
getTuple() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
getTupleId(Object, boolean) - Method in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
Every tuple is acked or failed, even when working with batches.
getType() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
getType() - Method in class org.thales.punch.libraries.storm.spout.impl.HttpServer
 
getType() - Method in class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
 
getType() - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
 
getType() - Method in class org.thales.punch.libraries.storm.spout.impl.UdpSyslogServer
 
getType() - Method in class org.thales.punch.libraries.storm.spout.RelpInput
 
getUncompressedSize() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
getUncompressedSize() - Method in interface org.thales.punch.libraries.storm.bolt.file.buffer.IArchiveBuffer
Return the size, uncompressed if compression enabled, of written bytes
getUncompressedSize() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
getUncompressedSize() - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
getUuid() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getValue() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Timestamp
 
getValue(int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getValueByField(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
getValues() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
GzipArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
The Gzip archiver creates a RAM byte array with gzip compressed batch content before writing to file (no streaming).
GzipArchiveBuffer(int, int, List<ArchiveDevice>, IRecordEncoder<Map<String, Object>>, IRecordEncoder.RecordFormat, boolean) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.GzipArchiveBuffer
Ctor

H

handleDeviceFailure(String, String, Exception, int) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
When device fails to open, write or close, the device is considered down.
hasExpired(long, long) - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Check if this batch has expired, given an expiration timeout.
hashCode() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMapKey
 
hashCode() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.RecordKey
 
hashCode() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
hikariConfigMaps - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
hosts - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
HttpBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a HttpNode from NodeSettings, ITopologySettings.
HttpBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.HttpBoltFactory
 
HttpInput - Class in org.thales.punch.libraries.storm.spout
The Http spout receives http requests and forwards them as tuple.
HttpInput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.HttpInput
A Spout constructor is in charge of setting the fields that will be required later on when the spout will be effectively started and run somewhere in the cluster.
HttpNode - Class in org.thales.punch.libraries.storm.bolt
Send http request for each tuple.
HttpNode(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.HttpNode
 
HttpServer - Class in org.thales.punch.libraries.storm.spout.impl
This http server puts all the received event lines in a queue, ready to be consumed by a storm spout.
HttpServer(ISettingsMap, int, IMetricContext) - Constructor for class org.thales.punch.libraries.storm.spout.impl.HttpServer
 
HttpSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Build a SyslogInput from NodeSettings.
HttpSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.HttpSpoutFactory
Default constructor.

I

IAdditionalValue - Interface in org.thales.punch.libraries.storm.bolt.elasticsearch
The elasticsearch bolt needs to add additional key values at the end of the json document to insert.
IArchiveBuffer - Interface in org.thales.punch.libraries.storm.bolt.file.buffer
This interface defines the contract for marshaling incoming data (i.e.
IBoltDeclarer - Interface in org.thales.punch.libraries.storm.core.topology
The bolt declarer interface.
IEthernetPacketDeserializer - Interface in org.thales.punch.libraries.storm.bolt.rawpacket
 
IFileNameSupplier - Interface in org.thales.punch.libraries.storm.bolt.file
Each batch receives a unique file name (or object name).
IInputTupleConverter<T> - Interface in org.thales.punch.libraries.storm.bolt.impl
Input Tuple Converter interface.
inc() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
increaseSleepTime(long) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
initMetadata(long) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Common metadata initialization
inputQueue - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
Internal FileSpout queue to put read items before doing the actual processing.
inputQueues - Static variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
Keep track of internal queues based on the Storm component ID.
InputTupleConverterImpl - Class in org.thales.punch.libraries.storm.converter
Implementation of InputTupleConverter.
InputTupleConverterImpl() - Constructor for class org.thales.punch.libraries.storm.converter.InputTupleConverterImpl
 
IOutputTupleConverter<T> - Interface in org.thales.punch.libraries.storm.bolt.impl
Output Tuple Converter interface.
isAborted() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
isCompleted() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
isEnabled() - Method in class org.thales.punch.libraries.storm.bolt.impl.JdbcHandle
 
isEnabledMessageTimeout() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
isNullIdsAreErrors() - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocumentBuilder
 
isRunning - Variable in class org.thales.punch.libraries.storm.bolt.RythmerNode
use to verify if the consummer is aldreay running
isSlowRateOnFailures() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
isSpoutTuple() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
This method is thread-safe.
isStarted() - Method in class org.thales.punch.libraries.storm.util.FileRecord
 
ISubscription - Interface in org.thales.punch.libraries.storm.util
 
ISyslogReceiver<T> - Interface in org.thales.punch.libraries.storm.spout.impl
 
ISyslogServer - Interface in org.thales.punch.libraries.storm.spout.impl
 
Item(String, Map<String, String>) - Constructor for class org.thales.punch.libraries.storm.spout.AbstractFileInput.Item
 
ITopologyBuilder - Interface in org.thales.punch.libraries.storm.core.topology
 
IWhiteBoard - Interface in org.thales.punch.libraries.storm.util
 

J

JdbcHandle - Class in org.thales.punch.libraries.storm.bolt.impl
 
JdbcHandle(Map<String, Object>, int) - Constructor for class org.thales.punch.libraries.storm.bolt.impl.JdbcHandle
Create a JDBC handle.
jdbcHandleIterator - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
JsonKafkaOutput - Class in org.thales.punch.libraries.storm.bolt.impl
 
JsonKafkaOutput(NodeSettings, Properties) - Constructor for class org.thales.punch.libraries.storm.bolt.impl.JsonKafkaOutput
 
JsonToNDJson - Class in org.thales.punch.libraries.storm.spout.es.wrapper.plugins
 
JsonToNDJson(List<ISettingsMap>, List<ISettingsMap>) - Constructor for class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.JsonToNDJson
 
JsonToNDJson.Mode - Enum in org.thales.punch.libraries.storm.spout.es.wrapper.plugins
 

K

KafkaBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a Storm topology.
KafkaBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.KafkaBoltFactory
Default constructor.
KafkaHeaderReader - Class in org.thales.punch.libraries.storm.util
This static class allows to decode kafka headers according to storm configuration 'headers_fields' The resulting HeaderDeclaration object is used to cast the header value according to its type, encoding or byte ordering
KafkaInput - Class in org.thales.punch.libraries.storm.spout
The KafkaInput node reads records from a topic and forwards them into a punchline.
KafkaInput(NodeSettings, String) - Constructor for class org.thales.punch.libraries.storm.spout.KafkaInput
Create a new Kafka node
KafkaOutputBoltPartitioner - Class in org.thales.punch.libraries.storm.bolt.impl
The partitioner is in charge of telling the kafka producer to which partition the next message should go to.
KafkaOutputBoltPartitioner() - Constructor for class org.thales.punch.libraries.storm.bolt.impl.KafkaOutputBoltPartitioner
 
KafkaSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Build a KafkaInput from NodeSettings, ITopologySettings.
KafkaSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.KafkaSpoutFactory
Default constructor.
Key - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
Key(Tuple, List<String>) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.Key
 

L

lastCommittedWriter() - Method in class org.thales.punch.libraries.storm.spout.AzureBlobStorageSpout
will be use to write last_committed on success
lastUpdateTimestamp - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
LightAcker - Interface in org.thales.punch.libraries.storm.core.topology.light
 
LightBoltDeclarer - Class in org.thales.punch.libraries.storm.core.topology.light
The LightBoltDeclarer is in charge of wiring the topology graph.
LightBoltDeclarer(LightTopology, String, IRichBolt, int) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightBoltDeclarer
Ctor.
LightBoltDispatcher - Class in org.thales.punch.libraries.storm.core.topology.light
To each bolt is associated one LightBoltDispatcher.
LightBoltDispatcher(LightTopology, TopologyContext, String, IRichBolt, int) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightBoltDispatcher
 
LightBoltOutputCollector - Class in org.thales.punch.libraries.storm.core.topology.light
 
LightBoltOutputCollector(LightBoltRunner) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
 
LightBoltRunner - Class in org.thales.punch.libraries.storm.core.topology.light
A LightBoltRunner is in charge of running one instance of a bolt.
LightBoltRunner(LightTopology, TopologyContext, LightBoltDispatcher, IRichBolt) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightBoltRunner
 
LightComponent - Class in org.thales.punch.libraries.storm.core.topology.light
A (bolt or spout) component.
LightComponent(LightTopology, String, TopologyContext) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
LightOutputDeclarer - Class in org.thales.punch.libraries.storm.core.topology.light
 
LightOutputDeclarer(LightTopology, String) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightOutputDeclarer
 
LightOutputDeclarer(LightComponent) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightOutputDeclarer
 
LightSpout - Class in org.thales.punch.libraries.storm.core.topology.light
 
LightSpout(LightTopology, String, ISpout, TopologyContext) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
LightSpoutOutputCollector - Class in org.thales.punch.libraries.storm.core.topology.light
This class is the output collector used by the light storm engine.
LightSpoutOutputCollector(LightSpout) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
LightTopology - Class in org.thales.punch.libraries.storm.core.topology.light
 
LightTopology(ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
LightTopologyBuilder - Class in org.thales.punch.libraries.storm.core.topology.light
Builder class for light topologies.
LightTopologyBuilder(ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LightTopologyBuilder
 
LightTuple - Class in org.thales.punch.libraries.storm.core.topology.light
These are the (storm compatible) tuples given to bolts.
LigthTopologyContext - Class in org.thales.punch.libraries.storm.core.topology.light
The ligthweigth topology context implementation.
LigthTopologyContext(String, String, int) - Constructor for class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
LoadControlItem<T> - Class in org.thales.punch.libraries.storm.util
This class helps you keep track of the time it takes to acknowledge or fail a tuple.
LoadControlItem(T) - Constructor for class org.thales.punch.libraries.storm.util.LoadControlItem
Create a new LoadControlItem.
localOrShuffleGrouping(String, String) - Method in interface org.thales.punch.libraries.storm.core.topology.IBoltDeclarer
 
localOrShuffleGrouping(String, String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDeclarer
 
localOrShuffleGrouping(String, String) - Method in class org.thales.punch.libraries.storm.core.topology.StormBoltDeclarer
 
LogFileTailer - Class in org.thales.punch.libraries.storm.spout.impl
A log file tailer is designed to monitor a log file and send notifications when new lines are added to the log file.
LogFileTailer(ISettingsMap, Logger, File, long, boolean) - Constructor for class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
Creates a new log file tailer
LogFileTailerListener - Interface in org.thales.punch.libraries.storm.spout.impl
Provides listener notification methods when a tailed log file is updated
logStartFailure(String) - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
logStartProcessing() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
logStartSuccess() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
logStatistics(ISettingsMap) - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
logStopFailure(String) - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
logStopProcessing() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
logStopSuccess() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
LruCache<K,V> - Class in org.thales.punch.libraries.storm.spout.impl
 
LruCache(int) - Constructor for class org.thales.punch.libraries.storm.spout.impl.LruCache
 
LumberjackBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Setup a Syslog bolt.
LumberjackBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.LumberjackBoltFactory
 
LumberjackInput - Class in org.thales.punch.libraries.storm.spout
The Lumberjack spout receives and decodes lumberjack frames, emitted in turn as tuples.
LumberjackInput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.LumberjackInput
A Spout constructor is in charge of setting the fields that will be required later on when the spout will be effectively started and run somewhere in the cluster.
LumberjackInputRecordType - Enum in org.thales.punch.libraries.storm.spout.impl
The possible type of lumberjack records we receive.
LumberjackKafkaOutput - Class in org.thales.punch.libraries.storm.bolt.impl
 
LumberjackKafkaOutput(NodeSettings, Properties) - Constructor for class org.thales.punch.libraries.storm.bolt.impl.LumberjackKafkaOutput
The properties must only contain string.
LumberjackOutput - Class in org.thales.punch.libraries.storm.bolt
The PunchPlatformBolt forwards messages to a next hop PunchPlatformSpout.
LumberjackOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.LumberjackOutput
Constructor.
LumberjackServer - Class in org.thales.punch.libraries.storm.spout.impl
This lumberjack server puts all the received log lines in a queue, ready to be consumed by a storm spout.
LumberjackServer(ISettingsMap, LinkedBlockingQueue<INettyTuple<Map<String, String>>>, int, IMetricContext) - Constructor for class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
Ctor.
LumberjackSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Build a SyslogInput from NodeSettings.
LumberjackSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.LumberjackSpoutFactory
Default constructor.

M

maxTopologyMessageTimeout() - Method in class org.thales.punch.libraries.storm.core.topology.light.LigthTopologyContext
 
maxWrites - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
messagesProducingRate - Variable in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput.Topic
 
minWrites - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
ModuleNode<T,V> - Class in org.thales.punch.libraries.storm.bolt
A simple module bolt.
ModuleNode(NodeSettings, Serializable, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.bolt.ModuleNode
 
mustCallNextTuple() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 

N

newLogFileLine(String, Map<String, String>) - Method in interface org.thales.punch.libraries.storm.spout.impl.LogFileTailerListener
A new line has been added to the tailed log file
nextTuple() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
Callback to feed the topology with tuples.
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.AzureBlobStorageSpout
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.GeneratorInput
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.HttpInput
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.KafkaInput
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.LumberjackInput
Callback to feed the topology with tuples.
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.RelpInput
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.SmtpInput
 
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.SyslogInput
Callback to feed the topology with tuples.
nextTuple() - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
NSGAzureBlobStorageSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
 
NSGAzureBlobStorageSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.NSGAzureBlobStorageSpoutFactory
 
NULL_VALUE - Static variable in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.JsonToNDJson
 

O

ObjectStorageFileNameSupplier - Class in org.thales.punch.libraries.storm.bolt.file
A filename supplier for archiving.
ObjectStorageFileNameSupplier(String, String, int) - Constructor for class org.thales.punch.libraries.storm.bolt.file.ObjectStorageFileNameSupplier
Ctor
OmniSciBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
OmniSciBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.OmniSciBoltFactory
 
OmniSciOutput - Class in org.thales.punch.libraries.storm.bolt
This bolt will enable you to insert data into a MapD (OmniSci) database.
OmniSciOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.OmniSciOutput
 
onActive(ChannelHandlerContext) - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
 
onChange(File, String) - Method in class org.thales.punch.libraries.storm.impl.Watcher
 
onChange(File, String) - Method in class org.thales.punch.libraries.storm.util.DirWatcher
 
OneByOneFileOutput - Class in org.thales.punch.libraries.storm.bolt.impl
The "Exactly once" version of the FileBolt.
A special variation of the FileBolt that creates a dedicated file batch object for each Tuple.
OneByOneFileOutput(NodeSettings, List<ArchiveDevice>, IFileNameSupplier, ArchiveFormatSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.impl.OneByOneFileOutput
Ctor.
onInactive(ChannelHandlerContext) - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
 
onReceive(ChannelHandlerContext, INettyTuple<Map<String, Object>>) - Method in class org.thales.punch.libraries.storm.spout.impl.HttpServer
 
onReceive(NettyTupleImpl<T>) - Method in interface org.thales.punch.libraries.storm.spout.impl.ISyslogReceiver
 
onReceive(ChannelHandlerContext, INettyTuple<Map<String, String>>) - Method in class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
 
onReceive(ChannelHandlerContext, INettyTuple<T>) - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
 
onReceive(ChannelHandlerContext, INettyTuple<T>) - Method in class org.thales.punch.libraries.storm.spout.impl.UdpSyslogServer
 
onReceive(IPartition, ConsumerRecord<byte[], byte[]>) - Method in class org.thales.punch.libraries.storm.spout.KafkaInput
 
onReceive(ChannelHandlerContext, INettyTuple<RELPFrame>) - Method in class org.thales.punch.libraries.storm.spout.RelpInput
 
onReceive(NettyTupleImpl<T>) - Method in class org.thales.punch.libraries.storm.spout.SyslogInput
 
onReceive(Object) - Method in interface org.thales.punch.libraries.storm.util.ISubscription
 
onReceiveTuple() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.AbstractSocketInput
Setup this spout before it starts receiving data and emitting tuples into the topology.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.AzureBlobStorageSpout
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.GeneratorInput
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.HttpInput
Setup this spout before it starts receiving data and emitting tuples into the topology.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.impl.FileSpout
Setup this spout before it starts receiving data and emitting tuples into the topology.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.impl.FileSpoutWatcher
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.KafkaInput
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.LumberjackInput
Setup this spout before it starts receiving data and emitting tuples into the topology.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.RelpInput
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.SFTPSpout
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.SmtpInput
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.SyslogInput
Setup this spout before it starts receiving data and emitting tuples into the topology.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
Operation - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
Operation(String) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.Operation
 
orderedRead - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
If set to true, every files will be proceed one by one in a single thread starting with the oldest files first.
org.thales.punch.libraries.storm.bolt - package org.thales.punch.libraries.storm.bolt
Punchplatform bolts package.
org.thales.punch.libraries.storm.bolt.aggregator.impl - package org.thales.punch.libraries.storm.bolt.aggregator.impl
 
org.thales.punch.libraries.storm.bolt.elasticsearch - package org.thales.punch.libraries.storm.bolt.elasticsearch
 
org.thales.punch.libraries.storm.bolt.factory - package org.thales.punch.libraries.storm.bolt.factory
 
org.thales.punch.libraries.storm.bolt.file - package org.thales.punch.libraries.storm.bolt.file
 
org.thales.punch.libraries.storm.bolt.file.buffer - package org.thales.punch.libraries.storm.bolt.file.buffer
 
org.thales.punch.libraries.storm.bolt.impl - package org.thales.punch.libraries.storm.bolt.impl
 
org.thales.punch.libraries.storm.bolt.rawpacket - package org.thales.punch.libraries.storm.bolt.rawpacket
 
org.thales.punch.libraries.storm.converter - package org.thales.punch.libraries.storm.converter
 
org.thales.punch.libraries.storm.core.topology - package org.thales.punch.libraries.storm.core.topology
 
org.thales.punch.libraries.storm.core.topology.light - package org.thales.punch.libraries.storm.core.topology.light
 
org.thales.punch.libraries.storm.impl - package org.thales.punch.libraries.storm.impl
 
org.thales.punch.libraries.storm.spout - package org.thales.punch.libraries.storm.spout
Punchplatform spouts package.
org.thales.punch.libraries.storm.spout.es.wrapper.plugins - package org.thales.punch.libraries.storm.spout.es.wrapper.plugins
 
org.thales.punch.libraries.storm.spout.factory - package org.thales.punch.libraries.storm.spout.factory
 
org.thales.punch.libraries.storm.spout.impl - package org.thales.punch.libraries.storm.spout.impl
 
org.thales.punch.libraries.storm.util - package org.thales.punch.libraries.storm.util
 
outgoingBytesRate - Variable in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput.Topic
 
outputStream - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
OutputTupleConverterImpl - Class in org.thales.punch.libraries.storm.converter
Implementation of OutputTupleConverter.
OutputTupleConverterImpl() - Constructor for class org.thales.punch.libraries.storm.converter.OutputTupleConverterImpl
 

P

partition(Object, int) - Method in class org.thales.punch.libraries.storm.bolt.impl.KafkaOutputBoltPartitioner
 
partition(String, Object, byte[], Object, byte[], Cluster) - Method in class org.thales.punch.libraries.storm.bolt.impl.KafkaOutputBoltPartitioner
 
password - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
path - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
The file or folder path to consume.
pathRegexPattern - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
The regualar expression pattern that any file must match to be proceed.
PlainArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
The plain archiver simply creates a RAM byte array with the batch content.
PlainArchiveBuffer(int, int, List<ArchiveDevice>, IRecordEncoder<Map<String, Object>>, IRecordEncoder.RecordFormat, boolean) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
Ctor
pool - Variable in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
poolName - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
poolSize - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
PostgresqlBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
PostgresqlBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.PostgresqlBoltFactory
 
PostgresqlOutput - Class in org.thales.punch.libraries.storm.bolt
This bolt will enable you to insert data into a Postgresql database.
PostgresqlOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.PostgresqlOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.ArchiveReaderNode
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.ClickHouseOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.DistinctLogCounterNode
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomOutput
 
prepare(Supplier<IArchiveBuffer>, IMetricContext) - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Prepare this instance.
prepare(BatchMetadata) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AbstractArchiveBuffer
 
prepare(BatchMetadata) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
prepare(BatchMetadata) - Method in interface org.thales.punch.libraries.storm.bolt.file.buffer.IArchiveBuffer
Before using the archive buffer call this.
prepare(BatchMetadata) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
prepare(BatchMetadata) - Method in interface org.thales.punch.libraries.storm.bolt.file.IFileNameSupplier
Prepare this supplier before you use it to get a new batch identifier.
prepare(BatchMetadata) - Method in class org.thales.punch.libraries.storm.bolt.file.ObjectStorageFileNameSupplier
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.FileTransferBolt
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.FilterNode
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.HttpNode
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.impl.AtLeastOnceFileOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.impl.JsonKafkaOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.impl.LumberjackKafkaOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.impl.OneByOneFileOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.LumberjackOutput
Setup this spout before starting emitting Tuples into the topology.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.ModuleNode
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.OmniSciOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.PostgresqlOutput
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.PunchDispatcherNode
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.PunchNode
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.RawPacketNode
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.RetentionNode
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.RythmerNode
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.SplitNode
Prepare this bolt.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.SyslogOutput
Setup this spout before starting emitting Tuples into the topology.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.thales.punch.libraries.storm.bolt.SyslogUdpOutput
Setup this spout before starting emitting Tuples into the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.ArchiveReaderNode
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.DistinctLogCounterNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.FileTransferBolt
File that will be transfer are read line by line.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.FilterNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.HttpNode
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.impl.AtLeastOnceFileOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.impl.JsonKafkaOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.impl.LumberjackKafkaOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.impl.OneByOneFileOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.LumberjackOutput
Storm gives us tuple one by one.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.ModuleNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.OmniSciOutput
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.PunchDispatcherNode
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.PunchNode
 
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.RawPacketNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.RetentionNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.RythmerNode
Before sending the tuple to the consumer, the time difference between the previous message is calculated.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.SplitNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.SyslogOutput
The Syslog bolt expects a single field, and forwards that field to the destination.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.SyslogUdpOutput
The Syslog bolt expects a single field, and forwards that field to the destination.
process(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.TestNode
The execute method is called by storm whenever some new tuples traverse the topology.
process(Object, ConsumerRecord<byte[], byte[]>, KafkaBatchAttachement) - Method in class org.thales.punch.libraries.storm.spout.AbstractKafkaNode
Process a received record.
processAlreadyExisting - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
If true, the watcher will start by process any already existing file is the path.
producerProperties - Variable in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
The Kafka producer properties
publish(String, Object) - Method in interface org.thales.punch.libraries.storm.util.IWhiteBoard
 
publish(String, Object) - Method in class org.thales.punch.libraries.storm.util.WhiteBoard
The publish method is called by the producer when it receives data to call back the consumer.
publishersOfType(String) - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
publishStream(String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
PunchBoltDispatcherFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a punch dispatcher bolt.
PunchBoltDispatcherFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.PunchBoltDispatcherFactory
Default constructor.
PunchBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Punch Node factory class.
PunchBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.PunchBoltFactory
Default constructor.
PunchDispatcherNode - Class in org.thales.punch.libraries.storm.bolt
The PunchDispatcherNode simply dispatches incoming tuples to different punchlet(s), based on one of the received fields.
PunchDispatcherNode(NodeSettings, Map<String, PunchNode>) - Constructor for class org.thales.punch.libraries.storm.bolt.PunchDispatcherNode
Ctor
PunchletConfig - Class in org.thales.punch.libraries.storm.util
 
PunchletConfig(String, Map<String, String>, Map<String, String>, Map<String, String>) - Constructor for class org.thales.punch.libraries.storm.util.PunchletConfig
 
PunchNode - Class in org.thales.punch.libraries.storm.bolt
The punch bolt executes punchlet(s) on the fly.
PunchNode(NodeSettings, PunchletConfig) - Constructor for class org.thales.punch.libraries.storm.bolt.PunchNode
Constructor.
put(String, T) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
put(Map<String, Object>) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.AvroParquetArchiveBuffer
 
put(Map<String, Object>) - Method in interface org.thales.punch.libraries.storm.bolt.file.buffer.IArchiveBuffer
Add a single item in the archive buffer.
put(Map<String, Object>) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
 
put(Map<String, Object>) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
putBytes(byte[]) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.GzipArchiveBuffer
 
putBytes(byte[]) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
Write bytes to correct buffer

Q

queryQueueTime - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
queueSize - Variable in class org.thales.punch.libraries.storm.spout.AbstractFileInput
The maximum amount of input lines we accept to accumulate in our server queues.

R

RawPacketBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a Test Bolt.
RawPacketBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.RawPacketBoltFactory
Default constructor.
RawPacketNode - Class in org.thales.punch.libraries.storm.bolt
 
RawPacketNode(NodeSettings, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.bolt.RawPacketNode
Create a new SplitBolt
readFile() - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
Use this method to read a file in a synchronous way.
readOneFile(File) - Method in class org.thales.punch.libraries.storm.spout.AbstractFileInput
Read a file using with a single or multi thread manner.
readValue(Header, HeaderDeclaration) - Static method in class org.thales.punch.libraries.storm.util.KafkaHeaderReader
Return a header value according to its configured declaration For accepted value type and encodings, check @HeaderDeclaration class
reconnectionTimeout - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
Record - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
A Record keeps track of the various counter associated to the keys identifying one aggregation.
Record(Tuple, List<Operation>, List<String>) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.Record
Create a new aggregation record.
RecordKey - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
RecordKey(long, long) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.RecordKey
 
registerBoltFactory(String, Class<? extends IBoltFactory>) - Method in class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
Adds a bolt factory to the registry.
registerNextTupleCallback(INextTupleCallback) - Method in class org.thales.punch.libraries.storm.spout.HttpInput
 
registerNextTupleCallback(INextTupleCallback) - Method in class org.thales.punch.libraries.storm.spout.impl.HttpServer
Register the callback to receive the data.
registerNextTupleCallback(INextTupleCallback) - Method in class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
 
registerNextTupleCallback(INextTupleCallback) - Method in class org.thales.punch.libraries.storm.spout.LumberjackInput
 
registerNextTupleCallback(INextTupleCallback) - Method in class org.thales.punch.libraries.storm.spout.SyslogInput
 
registerSpoutFactory(String, Class<? extends ISpoutFactory>) - Method in class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
Adds a spout factory to the registry.
reindex(List<ElasticDocument>) - Method in class org.thales.punch.libraries.storm.bolt.ElasticsearchOutput
 
RelpInput - Class in org.thales.punch.libraries.storm.spout
The Relp listening spout.
RelpInput(NodeSettings, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.spout.RelpInput
Create a new Relp spout
removeEldestEntry(Map.Entry<K, V>) - Method in class org.thales.punch.libraries.storm.spout.impl.LruCache
 
removeLogFileTailerListener(LogFileTailerListener) - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
remove a listener
Reporter - Class in org.thales.punch.libraries.storm.spout.es.wrapper.plugins
 
Reporter(ISettingsMap, ReporterGroup) - Constructor for class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.Reporter
 
ReporterBuilder - Class in org.thales.punch.libraries.storm.spout.es.wrapper.plugins
 
ReporterBuilder(ISettingsMap, ISettingsMap) - Constructor for class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.ReporterBuilder
 
reportError(Throwable) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
 
reportError(Throwable) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpoutOutputCollector
 
requestClose() - Method in class org.thales.punch.libraries.storm.bolt.impl.AsyncKafkaProducer
request the closing of this producer.
resetTimeout(Tuple) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltOutputCollector
 
resolve(String) - Method in class org.thales.punch.libraries.storm.bolt.factory.ResourcePathResolver
 
ResourcePathResolver - Class in org.thales.punch.libraries.storm.bolt.factory
IN a punch node resources are identified using various schemes:
ResourcePathResolver(String, String, Path) - Constructor for class org.thales.punch.libraries.storm.bolt.factory.ResourcePathResolver
 
RetentionBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
RetentionBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.RetentionBoltFactory
 
RetentionNode - Class in org.thales.punch.libraries.storm.bolt
Overview
RetentionNode(NodeSettings, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.bolt.RetentionNode
Create a new retention bolt
run(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.CountFieldOperation
 
run(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.CountFieldValueOperation
 
run(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.CountOperation
 
run(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Operation
 
run(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.SumOperation
 
run() - Method in class org.thales.punch.libraries.storm.bolt.impl.JdbcHandle
 
run() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltRunner
 
run() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopology
Running a light topology never returns.
run() - Method in class org.thales.punch.libraries.storm.impl.Watcher
 
run() - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.ElasticRequestRunnable
 
run() - Method in class org.thales.punch.libraries.storm.spout.impl.HttpServer
 
run() - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
 
run() - Method in class org.thales.punch.libraries.storm.spout.impl.LumberjackServer
 
run() - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
 
run() - Method in class org.thales.punch.libraries.storm.spout.impl.UdpSyslogServer
 
run() - Method in class org.thales.punch.libraries.storm.util.DirWatcher
Run the thread.
RythmerBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
RythmerBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.RythmerBoltFactory
 
RythmerNode - Class in org.thales.punch.libraries.storm.bolt
The rythmer bolt emits messages according to a provided timestamp.
RythmerNode(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.RythmerNode
 

S

S3ArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
The plain archiver simply creates a RAM byte array with the batch content.
S3ArchiveBuffer(int, int, List<ArchiveDevice>, IRecordEncoder<Map<String, Object>>, IRecordEncoder.RecordFormat) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.S3ArchiveBuffer
 
select(Fields) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
sendKafkaMessage(Tuple, AbstractKafkaOutput.Topic, byte[]) - Method in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
Call the Kafka producer to send the message
setAcker(LightAcker) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
Only a spout is interested to know when this tuple ack or fail.
setAnchoredTuple(Tuple) - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
In the exactly once mode, the first tuple of each batch is kept unacknowledged until the batch is flushed.
setBloomParameters(int, double) - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Use this to make your BatchArchiver instance compute bloom filters.
setBolt(String, IRichBolt, int) - Method in interface org.thales.punch.libraries.storm.core.topology.ITopologyBuilder
 
setBolt(String, IRichBolt, int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopologyBuilder
 
setBolt(String, IRichBolt, int) - Method in class org.thales.punch.libraries.storm.core.topology.StormTopologyBuilder
 
setBulkFailureHandler(FailureHandler) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
setChannel(Object) - Method in interface org.thales.punch.libraries.storm.util.ISubscription
 
setClassName(String) - Method in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomBoltFactory
 
setClassName(String) - Method in class org.thales.punch.libraries.storm.spout.factory.WrapperCustomSpoutFactory
 
setConvertors(IInputTupleConverter<T>, IOutputTupleConverter<V>) - Method in class org.thales.punch.libraries.storm.bolt.ModuleNode
 
setError(String) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticDocument
 
setFailedDocumentReindexation(boolean) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
setFailedDocumentReindexationForMappingExceptionsOnly(boolean) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
setFailTupleWhenErrorNotIndexed(boolean) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
setFailTupleWhenErrorNotIndexed(boolean) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticErrorBulkRequest
 
setSpout(String, ISpout, int) - Method in interface org.thales.punch.libraries.storm.core.topology.ITopologyBuilder
 
setSpout(String, ISpout, int) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTopologyBuilder
 
setSpout(String, ISpout, int) - Method in class org.thales.punch.libraries.storm.core.topology.StormTopologyBuilder
 
setTailling(boolean) - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
enable/disable file tailing
setTickFrequency(Integer) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltRunner
 
settings - Variable in class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput
these are the bolt settings as revamped by the factory
setUnavailabilityFailureHandler(FailureHandler) - Method in class org.thales.punch.libraries.storm.bolt.elasticsearch.ElasticBulkRequest
 
SFTP_SETTINGS - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
SFTPSpout - Class in org.thales.punch.libraries.storm.spout
SFTPSpout downloads files that matches a certain regex expression.
SFTPSpout(NodeSettings, ISettingsMap, boolean, String, String, String, ISettingsMap, String) - Constructor for class org.thales.punch.libraries.storm.spout.SFTPSpout
 
SFTPSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
 
SFTPSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
shuffleGrouping(String, String) - Method in interface org.thales.punch.libraries.storm.core.topology.IBoltDeclarer
 
shuffleGrouping(String, String) - Method in class org.thales.punch.libraries.storm.core.topology.light.LightBoltDeclarer
 
shuffleGrouping(String, String) - Method in class org.thales.punch.libraries.storm.core.topology.StormBoltDeclarer
 
SimpleTopologyRegistry - Class in org.thales.punch.libraries.storm.core.topology
A simple registry for various configuration artifacts.
SimpleTopologyRegistry() - Constructor for class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
Default constructor.
size() - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
 
size() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
SmtpInput - Class in org.thales.punch.libraries.storm.spout
The SMTP listening spout.
SmtpInput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.SmtpInput
 
SnmpInput - Class in org.thales.punch.libraries.storm.spout
The SNMP spout is able to receive SNMP Traps over UDP It decodes the SNMP Traps messages into a JSON format - cf.
SnmpInput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.SnmpInput
 
SnmpSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Build a SnmpInput from NodeSettings.
SnmpSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.SnmpSpoutFactory
Default constructor.
SOURCE_TUPLE_FIELD_SETTING - Static variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
source_tuple_field: This optional setting provides the name of an input tuple field that is expected to contain a map-like object, providing all fields, instead of having many fields in the storm stream.
sourceTupleField - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
SplitBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a Test Bolt.
SplitBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.SplitBoltFactory
 
SplitNode - Class in org.thales.punch.libraries.storm.bolt
A simple splitter bolt.
SplitNode(NodeSettings, ITopologySettings) - Constructor for class org.thales.punch.libraries.storm.bolt.SplitNode
Create a new SplitBolt
spoutFactories - Variable in class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
The registered spout factories by type.
spoutFactoryFor(String) - Method in class org.thales.punch.libraries.storm.core.topology.SimpleTopologyRegistry
 
startAsync() - Method in class org.thales.punch.libraries.storm.bolt.impl.JdbcHandle
 
StormBoltDeclarer - Class in org.thales.punch.libraries.storm.core.topology
Default bolt declarer.
StormBoltDeclarer(BoltDeclarer) - Constructor for class org.thales.punch.libraries.storm.core.topology.StormBoltDeclarer
Ctor
StormTopologyBuilder - Class in org.thales.punch.libraries.storm.core.topology
 
StormTopologyBuilder() - Constructor for class org.thales.punch.libraries.storm.core.topology.StormTopologyBuilder
 
stream - Variable in class org.thales.punch.libraries.storm.bolt.elasticsearch.FailureHandler
 
streamDeclaration - Variable in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
StreamingGzipArchiveBuffer - Class in org.thales.punch.libraries.storm.bolt.file.buffer
A streaming gzip output file archiver.
StreamingGzipArchiveBuffer(int, int, List<ArchiveDevice>, IRecordEncoder<Map<String, Object>>, IRecordEncoder.RecordFormat, boolean) - Constructor for class org.thales.punch.libraries.storm.bolt.file.buffer.StreamingGzipArchiveBuffer
 
StreamSubscription - Class in org.thales.punch.libraries.storm.core.topology
 
StreamSubscription(String, String) - Constructor for class org.thales.punch.libraries.storm.core.topology.StreamSubscription
 
StringKafkaSpoutScheme - Class in org.thales.punch.libraries.storm.spout.impl
This is what is needed to get the message avalaible under the a given tuple field.
StringKafkaSpoutScheme(String) - Constructor for class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
Associated a field to this scheme so that the spout will emit tuple with the value under that field name.
subscribe(String, ISubscription) - Method in interface org.thales.punch.libraries.storm.util.IWhiteBoard
 
subscribe(String, ISubscription) - Method in class org.thales.punch.libraries.storm.util.WhiteBoard
The subscribe method is called by the consumer when it receives data.
subscribersPerStreamId - Variable in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
Subscriptions - Class in org.thales.punch.libraries.storm.util
 
Subscriptions() - Constructor for class org.thales.punch.libraries.storm.util.Subscriptions
 
subscriptions - Variable in class org.thales.punch.libraries.storm.util.WhiteBoard
 
SumOperation - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
SumOperation(String, String) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.SumOperation
 
SyslogBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Setup a Syslog bolt.
SyslogBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.SyslogBoltFactory
 
SyslogInput<T> - Class in org.thales.punch.libraries.storm.spout
The Syslog input reads lines from tcp/udp and emits them as tuples.
SyslogInput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.spout.SyslogInput
A Spout constructor is in charge of setting the fields that will be required later on when the spout will be effectively started and run somewhere in the cluster.
SyslogInput(NodeSettings, Logger) - Constructor for class org.thales.punch.libraries.storm.spout.SyslogInput
Alternative constructor to use a Logger coming from the subclass
SyslogOutput - Class in org.thales.punch.libraries.storm.bolt
The Syslog bolt forwards messages to a next hop UDP server.
SyslogOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.SyslogOutput
Public constructor.
SyslogSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Build a SyslogInput from NodeSettings.
SyslogSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.SyslogSpoutFactory
Default constructor.
SyslogUdpBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Setup a Syslog UDP bolt.
SyslogUdpBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.SyslogUdpBoltFactory
 
SyslogUdpOutput - Class in org.thales.punch.libraries.storm.bolt
The Syslog udp bolt forwards messages to a next hop UDP server.
SyslogUdpOutput(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.SyslogUdpOutput
Public constructor.

T

table - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
TcpSyslogServer<T> - Class in org.thales.punch.libraries.storm.spout.impl
This syslog server puts all the received log lines in a queue, ready to be consumed by a storm spout.
TcpSyslogServer(ISettingsMap, IMetricContext, ISyslogReceiver<T>) - Constructor for class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
 
TestBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
Build a Test Bolt.
TestBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.TestBoltFactory
Default constructor.
TestNode - Class in org.thales.punch.libraries.storm.bolt
A simple test vbolt.
TestNode(NodeSettings) - Constructor for class org.thales.punch.libraries.storm.bolt.TestNode
Ctor
tick() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightSpout
When a spout returned no tuple, or if the max pending limit has been reached, the inactiveSpoutSleepInterval increases to avoid calling the spout.
tick() - Method in interface org.thales.punch.libraries.storm.spout.impl.ISyslogServer
 
tick() - Method in class org.thales.punch.libraries.storm.spout.impl.LogFileTailer
Flush buffer after timeout, tick is only implement for multiline codec
tick() - Method in class org.thales.punch.libraries.storm.spout.impl.TcpSyslogServer
Flush buffers after timeout, tick is only implemented for multiline codecs
Timestamp - Class in org.thales.punch.libraries.storm.bolt.aggregator.impl
 
Timestamp(Tuple, String) - Constructor for class org.thales.punch.libraries.storm.bolt.aggregator.impl.Timestamp
 
toInt(byte[], HeaderDeclaration) - Static method in class org.thales.punch.libraries.storm.util.KafkaHeaderReader
byte kafka header content to integer value according to byte ordering in header declaration
toLong(byte[], HeaderDeclaration) - Static method in class org.thales.punch.libraries.storm.util.KafkaHeaderReader
byte kafka header content to long value according to byte ordering in header declaration
toObjectList(List<String>, List<Operation>, String) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Record
 
Topic(String) - Constructor for class org.thales.punch.libraries.storm.bolt.AbstractKafkaOutput.Topic
 
topologyContext - Variable in class org.thales.punch.libraries.storm.core.topology.light.LightComponent
 
TopologyFactory - Class in org.thales.punch.libraries.storm.core.topology
Build a Storm topology.
TopologyFactory(ITopologyRegistry, IPlatform, String) - Constructor for class org.thales.punch.libraries.storm.core.topology.TopologyFactory
Default constructor.
TopologyGraph - Class in org.thales.punch.libraries.storm.core.topology
 
TopologyGraph(List<NodeSettings>, List<NodeSettings>) - Constructor for class org.thales.punch.libraries.storm.core.topology.TopologyGraph
 
TopologyGraphNode - Class in org.thales.punch.libraries.storm.core.topology
This class makes it possible to build a graph from a topology configuration,
TopologyGraphNode(String, String, List<StreamDeclaration>) - Constructor for class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
toString() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMapKey
 
toString() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.Key
 
toString() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.RecordKey
 
toString() - Method in class org.thales.punch.libraries.storm.core.topology.light.LightTuple
 
toString() - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraph
 
toString() - Method in class org.thales.punch.libraries.storm.core.topology.TopologyGraphNode
 
toString() - Method in class org.thales.punch.libraries.storm.spout.impl.StringKafkaSpoutScheme
 
toString(byte[], HeaderDeclaration) - Static method in class org.thales.punch.libraries.storm.util.KafkaHeaderReader
byte kafka header content to string value according to value type in header declaration
transform(LinkedBlockingQueue<String>, String) - Method in class org.thales.punch.libraries.storm.spout.es.wrapper.plugins.JsonToNDJson
Receives ES query results, extract hits.hits for every result, format every tuple and return them as list.
tupleRtt - Variable in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
Time to process tuple metric
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.ArchiveReaderNodeFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.ClickHouseBoltFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.DistinctLogCounterBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.ElasticSearchOutputFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.FileOutputFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.FileTransferBoltFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.FilterBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.HttpBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.KafkaBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.LumberjackBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.OmniSciBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.PostgresqlBoltFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltDispatcherFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.PunchBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.RawPacketBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.RetentionBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.RythmerBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.SplitBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.SyslogBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.SyslogUdpBoltFactory
The key referencing the associated bolt.
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.TestBoltFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomBoltFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomOutput
 
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.AzureBlobStorageSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.ExtractionInputFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.FileSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.GeneratorSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.HttpSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.KafkaSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.LumberjackSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.NSGAzureBlobStorageSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.SFTPSpoutFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.SnmpSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.SyslogSpoutFactory
The key referencing the associated spout.
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.factory.WrapperCustomSpoutFactory
 
TYPE - Static variable in class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 

U

UdpSyslogServer<T> - Class in org.thales.punch.libraries.storm.spout.impl
This syslog server puts all the received log lines in a queue, ready to be consumed by a storm spout.
UdpSyslogServer(ISettingsMap, IMetricContext, ISyslogReceiver<T>) - Constructor for class org.thales.punch.libraries.storm.spout.impl.UdpSyslogServer
 
uncompressResources(Map<String, Object>) - Static method in class org.thales.punch.libraries.storm.impl.CompressionHelper
Take a resource map, and if items are marked as compressed, uncompress them.
UNDERSCORE_ID - Static variable in class org.thales.punch.libraries.storm.spout.factory.ExtractionInputFactory
 
UNDERSCORE_SEARCH - Static variable in class org.thales.punch.libraries.storm.spout.ExtractionInput
 
unsubscribe(String) - Method in interface org.thales.punch.libraries.storm.util.IWhiteBoard
 
unsubscribe(String) - Method in class org.thales.punch.libraries.storm.util.WhiteBoard
The unsubscribe method is called by the producer when the subscription does not need to be maintained, its role is over.
update(File) - Method in class org.thales.punch.libraries.storm.util.FileRecord
Updates the current FileRecord to match the given file.
updateBloom(ITuple, Iterable<String>) - Method in class org.thales.punch.libraries.storm.bolt.file.BatchArchiver
Update the bloom filter with the new fields values
updateTimestamp(Long) - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
username - Variable in class org.thales.punch.libraries.storm.bolt.AbstractJDBCOutput
 
userStream - Variable in class org.thales.punch.libraries.storm.bolt.AbstractFileOutput
The user stream where to publish the batches metadata.

V

valueOf(String) - Static method in enum org.thales.punch.libraries.storm.bolt.elasticsearch.FailureHandler.FailureAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.thales.punch.libraries.storm.bolt.file.EArchiverType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.thales.punch.libraries.storm.bolt.rawpacket.EthernetPacketDeserializers
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.thales.punch.libraries.storm.spout.es.wrapper.plugins.JsonToNDJson.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.thales.punch.libraries.storm.spout.impl.LumberjackInputRecordType
Returns the enum constant of this type with the specified name.
values() - Method in class org.thales.punch.libraries.storm.bolt.aggregator.impl.BatchMap
 
values() - Static method in enum org.thales.punch.libraries.storm.bolt.elasticsearch.FailureHandler.FailureAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.thales.punch.libraries.storm.bolt.file.EArchiverType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.thales.punch.libraries.storm.bolt.rawpacket.EthernetPacketDeserializers
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.thales.punch.libraries.storm.spout.es.wrapper.plugins.JsonToNDJson.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.thales.punch.libraries.storm.spout.impl.LumberjackInputRecordType
Returns an array containing the constants of this enum type, in the order they are declared.

W

WatchDog - Class in org.thales.punch.libraries.storm.util
This class provides a simple and robust watchdog mechanism.
WatchDog() - Constructor for class org.thales.punch.libraries.storm.util.WatchDog
 
Watcher - Class in org.thales.punch.libraries.storm.impl
This watcher is designed to monitor creation events in a specific directory.
Watcher(String, boolean) - Constructor for class org.thales.punch.libraries.storm.impl.Watcher
Constructor
WhiteBoard - Class in org.thales.punch.libraries.storm.util
The WhiteBoard is in charge of maintain subscriptions used by consumer (HttpSpout) and producer (WhiteBoardBolt) to communicate.
withDefaultRoot(Path) - Method in class org.thales.punch.libraries.storm.bolt.factory.ResourcePathResolver
 
WrapperCustomBoltFactory - Class in org.thales.punch.libraries.storm.bolt.factory
 
WrapperCustomBoltFactory() - Constructor for class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomBoltFactory
 
WrapperCustomBoltFactory(String) - Constructor for class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomBoltFactory
 
WrapperCustomInput - Class in org.thales.punch.libraries.storm.spout
Wrapper input node to convert custom node with public API to legacy node with private API
WrapperCustomInput(NodeSettings, PunchInputNode) - Constructor for class org.thales.punch.libraries.storm.spout.WrapperCustomInput
 
WrapperCustomOutput - Class in org.thales.punch.libraries.storm.bolt.factory
Wrapper input node to convert custom node with public API to legacy node with private API
WrapperCustomOutput(NodeSettings, PunchProcessingNode) - Constructor for class org.thales.punch.libraries.storm.bolt.factory.WrapperCustomOutput
 
WrapperCustomSpoutFactory - Class in org.thales.punch.libraries.storm.spout.factory
Wrapper factory to convert custom node with public API to legacy node with private API
WrapperCustomSpoutFactory() - Constructor for class org.thales.punch.libraries.storm.spout.factory.WrapperCustomSpoutFactory
Used by DynamicTopologyRegistry
WrapperCustomSpoutFactory(String) - Constructor for class org.thales.punch.libraries.storm.spout.factory.WrapperCustomSpoutFactory
 
writeToDestination(ArchiveDevice, byte[]) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.CephGzipArchiveBuffer
 
writeToDestination(ArchiveDevice, byte[]) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.PlainArchiveBuffer
Write byte array to provided destination.
writeToDestination(ArchiveDevice, byte[]) - Method in class org.thales.punch.libraries.storm.bolt.file.buffer.S3ArchiveBuffer
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2023. All rights reserved.