You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@metron.apache.org by ce...@apache.org on 2016/02/18 21:58:00 UTC

[6/6] incubator-metron git commit: METRON-38 Add license header to source closes apache/incubator-metron#24

METRON-38 Add license header to source closes apache/incubator-metron#24


Project: http://git-wip-us.apache.org/repos/asf/incubator-metron/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-metron/commit/c4954e8a
Tree: http://git-wip-us.apache.org/repos/asf/incubator-metron/tree/c4954e8a
Diff: http://git-wip-us.apache.org/repos/asf/incubator-metron/diff/c4954e8a

Branch: refs/heads/master
Commit: c4954e8af7d5cab59ec6fdc4d9a0bb07c794afd6
Parents: 657665c
Author: cestella <ce...@gmail.com>
Authored: Thu Feb 18 15:57:24 2016 -0500
Committer: cstella <ce...@gmail.com>
Committed: Thu Feb 18 15:57:24 2016 -0500

----------------------------------------------------------------------
 bro-plugin-kafka/Makefile                       | 16 ++++++++++
 bro-plugin-kafka/configure                      | 17 ++++++++++
 metron-streaming/Metron-Alerts/pom.xml          |  7 +++--
 .../apache/metron/alerts/AbstractAlertBolt.java |  7 +++--
 .../metron/alerts/TelemetryAlertsBolt.java      | 17 +++++-----
 .../alerts/adapters/AbstractAlertAdapter.java   |  5 +--
 .../metron/alerts/adapters/AllAlertAdapter.java | 18 +++++++++++
 .../alerts/adapters/CIFAlertsAdapter.java       | 17 ++++++++++
 .../adapters/HbaseWhiteAndBlacklistAdapter.java | 17 ++++++++++
 .../alerts/adapters/KeywordsAlertAdapter.java   | 17 ++++++++++
 .../metron/alerts/adapters/RangeChecker.java    | 17 ++++++++++
 .../alerts/adapters/ThreatAlertsAdapter.java    | 18 +++++++++++
 .../metron/tagging/AbstractTaggerBolt.java      |  7 +++--
 .../metron/tagging/TelemetryTaggerBolt.java     | 17 +++++-----
 .../tagging/adapters/AbstractTaggerAdapter.java |  4 +--
 .../metron/tagging/adapters/RegexTagger.java    |  4 +--
 .../tagging/adapters/StaticAllTagger.java       |  4 +--
 .../metron/tagging/adapters/TaggerAdapter.java  | 17 ++++++++++
 .../resources/AllAlertAdapterTest.properties    | 16 ++++++++++
 metron-streaming/Metron-Common/pom.xml          |  7 +++--
 .../metron/alerts/interfaces/AlertsAdapter.java | 17 ++++++++++
 .../alerts/interfaces/AlertsInterface.java      | 17 ++++++++++
 .../metron/alerts/interfaces/TaggerAdapter.java | 17 ++++++++++
 .../java/org/apache/metron/bolt/JoinBolt.java   | 17 ++++++++++
 .../java/org/apache/metron/bolt/SplitBolt.java  | 17 ++++++++++
 .../configuration/ConfigurationManager.java     | 19 ++++++++++-
 .../dataloads/interfaces/ThreatIntelSource.java | 17 ++++++++++
 .../org/apache/metron/domain/Enrichment.java    | 17 ++++++++++
 .../enrichment/EnrichmentSplitterBolt.java      | 17 ++++++++++
 .../interfaces/EnrichmentAdapter.java           | 15 ++++-----
 .../java/org/apache/metron/hbase/Connector.java | 17 ++++++++++
 .../java/org/apache/metron/hbase/HBaseBolt.java | 19 ++++++++++-
 .../metron/hbase/HBaseStreamPartitioner.java    | 19 ++++++++++-
 .../apache/metron/hbase/HTableConnector.java    | 20 +++++++++++-
 .../org/apache/metron/hbase/HTableProvider.java | 17 ++++++++++
 .../org/apache/metron/hbase/TableConfig.java    | 21 +++++++++++--
 .../org/apache/metron/hbase/TableProvider.java  | 20 ++++++++++--
 .../apache/metron/hbase/TupleTableConfig.java   | 19 ++++++++++-
 .../metron/helpers/services/PcapServiceCli.java | 17 ++++++++++
 .../org/apache/metron/helpers/topology/Cli.java | 17 ++++++++++
 .../metron/helpers/topology/ErrorGenerator.java | 17 ++++++++++
 .../metron/helpers/topology/SettingsLoader.java | 17 ++++++++++
 .../metron/index/interfaces/IndexAdapter.java   | 17 ++++++++++
 .../org/apache/metron/ise/parser/ISEParser.java | 17 ++++++++++
 .../metron/ise/parser/ISEParserConstants.java   | 17 ++++++++++
 .../ise/parser/ISEParserTokenManager.java       | 17 ++++++++++
 .../metron/ise/parser/JavaCharStream.java       | 17 ++++++++++
 .../metron/ise/parser/ParseException.java       | 17 ++++++++++
 .../org/apache/metron/ise/parser/Token.java     | 17 ++++++++++
 .../apache/metron/ise/parser/TokenMgrError.java | 17 ++++++++++
 .../json/serialization/JSONDecoderHelper.java   | 16 +++++-----
 .../json/serialization/JSONEncoderHelper.java   | 14 +++++----
 .../json/serialization/JSONKafkaSerializer.java | 15 ++++-----
 .../json/serialization/JSONKryoSerializer.java  | 16 +++++-----
 .../apache/metron/metrics/MetricReporter.java   | 17 ++++++++++
 .../apache/metron/metrics/MyMetricReporter.java | 17 ++++++++++
 .../org/apache/metron/metrics/NullReporter.java | 17 ++++++++++
 .../metron/parser/interfaces/MessageFilter.java | 17 ++++++++++
 .../metron/parser/interfaces/MessageParser.java | 17 ++++++++++
 .../java/org/apache/metron/pcap/Constants.java  | 19 ++++++++++-
 .../org/apache/metron/pcap/IEEE_802_1Q.java     | 19 ++++++++++-
 .../metron/pcap/MetronEthernetDecoder.java      | 19 ++++++++++-
 .../java/org/apache/metron/pcap/PacketInfo.java | 19 ++++++++++-
 .../apache/metron/pcap/PcapByteInputStream.java | 19 ++++++++++-
 .../metron/pcap/PcapByteOutputStream.java       | 17 ++++++++++
 .../java/org/apache/metron/pcap/PcapMerger.java | 19 ++++++++++-
 .../metron/pcap/PcapPacketComparator.java       | 17 ++++++++++
 .../java/org/apache/metron/pcap/PcapUtils.java  | 19 ++++++++++-
 .../apache/metron/reference/lookup/Lookup.java  | 20 ++++++++++--
 .../metron/reference/lookup/LookupKey.java      | 20 ++++++++++--
 .../lookup/accesstracker/AccessTracker.java     | 20 ++++++++++--
 .../lookup/accesstracker/AccessTrackerUtil.java | 20 ++++++++++--
 .../accesstracker/BloomAccessTracker.java       | 20 ++++++++++--
 .../accesstracker/PersistentAccessTracker.java  | 20 ++++++++++--
 .../reference/lookup/handler/Handler.java       | 20 ++++++++++--
 .../apache/metron/test/AbstractConfigTest.java  | 16 +++++-----
 .../apache/metron/test/AbstractSchemaTest.java  | 17 +++++-----
 .../apache/metron/test/AbstractTestContext.java | 15 ++++-----
 .../metron/threatintel/ThreatIntelKey.java      | 20 ++++++++++--
 .../metron/threatintel/ThreatIntelResults.java  | 20 ++++++++++--
 .../metron/threatintel/hbase/Converter.java     | 20 ++++++++++--
 .../threatintel/hbase/ThreatIntelLookup.java    | 20 ++++++++++--
 .../metron/tldextractor/BasicTldExtractor.java  | 19 ++++++++++-
 .../org/apache/metron/AbstractConfigTest.java   |  2 --
 .../org/apache/metron/AbstractSchemaTest.java   |  2 --
 .../org/apache/metron/AbstractTestContext.java  |  2 --
 .../tldextractor/BasicTldExtractorTest.java     |  2 --
 metron-streaming/Metron-DataLoads/pom.xml       |  7 +++--
 .../src/main/bash/threatintel_bulk_load.sh      | 17 ++++++++++
 .../src/main/bash/threatintel_bulk_prune.sh     | 18 ++++++++++-
 .../dataloads/LeastRecentlyUsedPruner.java      | 20 ++++++++++--
 .../metron/dataloads/ThreatIntelBulkLoader.java | 20 ++++++++++--
 .../metron/dataloads/ThreatIntelLoader.java     | 17 ++++++++++
 .../metron/dataloads/cif/HBaseTableLoad.java    | 19 ++++++++++-
 .../metron/dataloads/extractor/Extractor.java   | 20 ++++++++++--
 .../dataloads/extractor/ExtractorCreator.java   | 20 ++++++++++--
 .../dataloads/extractor/ExtractorHandler.java   | 20 ++++++++++--
 .../metron/dataloads/extractor/Extractors.java  | 20 ++++++++++--
 .../dataloads/extractor/csv/CSVExtractor.java   | 20 ++++++++++--
 .../extractor/inputformat/Formats.java          | 20 ++++++++++--
 .../inputformat/InputFormatHandler.java         | 20 ++++++++++--
 .../extractor/inputformat/WholeFileFormat.java  | 20 ++++++++++--
 .../dataloads/extractor/stix/StixExtractor.java | 20 ++++++++++--
 .../stix/types/AbstractObjectTypeHandler.java   | 20 ++++++++++--
 .../extractor/stix/types/AddressHandler.java    | 20 ++++++++++--
 .../extractor/stix/types/DomainHandler.java     | 20 ++++++++++--
 .../extractor/stix/types/HostnameHandler.java   | 21 +++++++++++--
 .../extractor/stix/types/ObjectTypeHandler.java | 20 ++++++++++--
 .../stix/types/ObjectTypeHandlers.java          | 20 ++++++++++--
 .../dataloads/hbase/mr/BulkLoadMapper.java      | 20 ++++++++++--
 .../metron/dataloads/hbase/mr/PrunerMapper.java | 20 ++++++++++--
 .../dataloads/extractor/ExtractorTest.java      | 20 ++++++++++--
 .../extractor/csv/CSVExtractorTest.java         | 20 ++++++++++--
 .../extractor/stix/StixExtractorTest.java       | 20 ++++++++++--
 .../dataloads/hbase/HBaseConverterTest.java     | 20 ++++++++++--
 .../hbase/mr/BulkLoadMapperIntegrationTest.java | 20 ++++++++++--
 .../dataloads/hbase/mr/BulkLoadMapperTest.java  | 20 ++++++++++--
 .../metron/dataloads/hbase/mr/HBaseUtil.java    | 20 ++++++++++--
 .../LeastRecentlyUsedPrunerIntegrationTest.java | 20 ++++++++++--
 metron-streaming/Metron-DataServices/pom.xml    | 12 +++++++
 .../metron/alerts/server/AlertsCacheReaper.java | 19 ++++++++++-
 .../alerts/server/AlertsFilterCacheEntry.java   | 17 ++++++++++
 .../alerts/server/AlertsProcessingServer.java   | 19 ++++++++++-
 .../metron/alerts/server/AlertsSearcher.java    | 19 ++++++++++-
 .../org/apache/metron/dataservices/Main.java    | 19 ++++++++++-
 .../metron/dataservices/auth/AuthToken.java     | 17 ++++++++++
 .../dataservices/auth/AuthTokenFilter.java      | 17 ++++++++++
 .../dataservices/auth/CustomDomainADRealm.java  | 17 ++++++++++
 .../auth/RestSecurityInterceptor.java           | 19 ++++++++++-
 .../dataservices/common/MetronService.java      | 17 ++++++++++
 .../dataservices/kafkaclient/KafkaClient.java   | 17 ++++++++++
 .../dataservices/kafkaclient/KafkaConsumer.java | 17 ++++++++++
 .../kafkaclient/poll/PollingKafkaClient.java    | 19 ++++++++++-
 .../kafkaclient/poll/PollingKafkaConsumer.java  | 19 ++++++++++-
 .../modules/guice/AlertsServerModule.java       | 19 ++++++++++-
 .../modules/guice/DefaultServletModule.java     | 19 ++++++++++-
 .../modules/guice/DefaultShiroWebModule.java    | 19 ++++++++++-
 .../modules/guice/RestEasyModule.java           | 17 ++++++++++
 .../modules/guice/ServiceModule.java            | 17 ++++++++++
 .../apache/metron/dataservices/rest/Index.java  | 19 ++++++++++-
 .../metron/dataservices/rest/RestServices.java  | 19 ++++++++++-
 .../dataservices/servlet/LoginServlet.java      | 19 ++++++++++-
 .../dataservices/servlet/LogoutServlet.java     | 19 ++++++++++-
 .../websocket/KafkaMessageSenderServlet.java    | 19 ++++++++++-
 .../websocket/KafkaMessageSenderSocket.java     | 19 ++++++++++-
 .../websocket/KafkaWebSocketCreator.java        | 19 ++++++++++-
 .../pcapservice/CellTimestampComparator.java    | 17 ++++++++++
 .../metron/pcapservice/ConfigurationUtil.java   | 17 ++++++++++
 .../pcapservice/HBaseConfigConstants.java       | 17 ++++++++++
 .../pcapservice/HBaseConfigurationUtil.java     | 16 +++++++++-
 .../apache/metron/pcapservice/IPcapGetter.java  | 16 +++++++++-
 .../apache/metron/pcapservice/IPcapScanner.java | 17 ++++++++++
 .../metron/pcapservice/PcapGetterHBaseImpl.java | 17 ++++++++++
 .../apache/metron/pcapservice/PcapHelper.java   | 17 ++++++++++
 .../pcapservice/PcapReceiverImplRestEasy.java   | 17 ++++++++++
 .../pcapservice/PcapScannerHBaseImpl.java       | 17 ++++++++++
 .../metron/pcapservice/PcapsResponse.java       | 16 +++++++++-
 .../metron/pcapservice/RestTestingUtil.java     | 17 ++++++++++
 .../pcapservice/rest/JettyServiceRunner.java    | 19 ++++++++++-
 .../metron/pcapservice/rest/PcapService.java    | 19 ++++++++++-
 .../ElasticSearch_KafkaAlertsService.java       | 17 ++++++++++
 .../alerts/Solr_KafkaAlertsService.java         | 17 ++++++++++
 .../CellTimestampComparatorTest.java            | 17 ++++++++++
 .../Metron-EnrichmentAdapters/pom.xml           |  7 +++--
 .../adapters/cif/AbstractCIFAdapter.java        | 15 ++++-----
 .../adapters/cif/CIFHbaseAdapter.java           | 15 ++++-----
 .../enrichment/adapters/geo/GeoAdapter.java     | 17 ++++++++++
 .../adapters/host/AbstractHostAdapter.java      | 15 ++++-----
 .../adapters/host/HostFromJSONListAdapter.java  | 17 ++++++++++
 .../host/HostFromPropertiesFileAdapter.java     | 15 ++++-----
 .../adapters/jdbc/BaseJdbcConfig.java           | 17 ++++++++++
 .../enrichment/adapters/jdbc/JdbcAdapter.java   | 17 ++++++++++
 .../enrichment/adapters/jdbc/JdbcConfig.java    | 17 ++++++++++
 .../enrichment/adapters/jdbc/MySqlConfig.java   | 17 ++++++++++
 .../adapters/threat/AbstractThreatAdapter.java  | 15 ++++-----
 .../adapters/threat/ThreatHbaseAdapter.java     | 15 ++++-----
 .../adapters/whois/WhoisHBaseAdapter.java       | 15 ++++-----
 .../enrichment/bolt/EnrichmentJoinBolt.java     | 17 ++++++++++
 .../enrichment/bolt/GenericEnrichmentBolt.java  | 17 +++++-----
 .../metron/threatintel/ThreatIntelAdapter.java  | 20 ++++++++++--
 .../metron/threatintel/ThreatIntelConfig.java   | 20 ++++++++++--
 .../adapters/cif/CIFHbaseAdapterTest.java       |  2 --
 .../adapters/whois/WhoisHBaseAdapterTest.java   |  2 --
 .../resources/CIFHbaseAdapterTest.properties    | 16 ++++++++++
 .../resources/GeoMysqlAdapterTest.properties    | 16 ++++++++++
 .../resources/WhoisHbaseAdapterTest.properties  | 17 ++++++++++
 metron-streaming/Metron-Indexing/pom.xml        |  7 +++--
 .../metron/indexing/AbstractIndexingBolt.java   |  5 +--
 .../metron/indexing/TelemetryIndexingBolt.java  | 17 +++++-----
 .../indexing/adapters/AbstractIndexAdapter.java | 17 ++++++++++
 .../indexing/adapters/ESBaseBulkAdapter.java    | 17 ++++++++++
 .../adapters/ESBulkRotatingAdapter.java         | 17 ++++++++++
 .../adapters/ESTimedRotatingAdapter.java        | 17 ++++++++++
 .../metron/indexing/adapters/SolrAdapter.java   | 17 ++++++++++
 metron-streaming/Metron-MessageParsers/pom.xml  |  7 +++--
 .../org/apache/metron/bolt/PcapParserBolt.java  | 17 ++++++++++
 .../apache/metron/bolt/TelemetryParserBolt.java | 17 ++++++++++
 .../apache/metron/filters/BroMessageFilter.java | 19 ++++++++++-
 .../metron/filters/GenericMessageFilter.java    | 17 ++++++++++
 .../metron/parsing/parsers/BasicBroParser.java  | 15 ++++-----
 .../parsing/parsers/BasicFireEyeParser.java     | 19 ++++++++++-
 .../metron/parsing/parsers/BasicIseParser.java  | 16 +++++-----
 .../parsing/parsers/BasicLancopeParser.java     | 15 ++++-----
 .../parsing/parsers/BasicLogstashParser.java    | 17 ++++++++++
 .../parsers/BasicPaloAltoFirewallParser.java    | 19 ++++++++++-
 .../metron/parsing/parsers/BasicParser.java     | 17 ++++++++++
 .../parsing/parsers/BasicSnortParser.java       | 17 ++++++++++
 .../parsing/parsers/BasicSourcefireParser.java  | 15 ++++-----
 .../metron/parsing/parsers/BasicYafParser.java  | 20 ++++++++++--
 .../metron/parsing/parsers/GrokAsaParser.java   | 19 ++++++++++-
 .../parsing/parsers/GrokSourcefireParser.java   | 17 ++++++++++
 .../metron/parsing/parsers/JSONCleaner.java     | 17 ++++++++++
 .../metron/parsing/parsers/MetronConverter.java | 17 ++++++++++
 .../metron/parsing/parsers/MetronGarbage.java   | 19 ++++++++++-
 .../metron/parsing/parsers/MetronGrok.java      | 19 ++++++++++-
 .../metron/parsing/parsers/MetronMatch.java     | 19 ++++++++++-
 .../metron/parsing/parsers/PcapParser.java      | 19 ++++++++++-
 .../apache/metron/parsing/utils/GrokUtils.java  | 19 ++++++++++-
 .../metron/parsing/utils/ParserUtils.java       | 17 ++++++++++
 .../metron/parsing/test/BasicBroParserTest.java | 17 ++++++++++
 .../parsing/test/BasicFireEyeParserTest.java    | 18 +++++++++--
 .../parsing/test/BasicLancopeParserTest.java    |  2 +-
 .../test/BasicPaloAltoFirewallParserTest.java   | 19 ++++++++++-
 .../parsing/test/BasicSourcefireParserTest.java | 18 +++++++++--
 .../metron/parsing/test/BroParserTest.java      | 17 ++++++++++
 .../metron/parsing/test/GrokAsaParserTest.java  | 19 ++++++++++-
 metron-streaming/Metron-Pcap_Service/pom.xml    | 12 +++++++
 .../OnlyDeleteExpiredFilesCompactionPolicy.java | 17 ++++++++++
 .../pcapservice/CellTimestampComparator.java    | 17 ++++++++++
 .../metron/pcapservice/ConfigurationUtil.java   | 17 ++++++++++
 .../pcapservice/HBaseConfigConstants.java       | 17 ++++++++++
 .../pcapservice/HBaseConfigurationUtil.java     | 16 +++++++++-
 .../apache/metron/pcapservice/IPcapGetter.java  | 16 +++++++++-
 .../apache/metron/pcapservice/IPcapScanner.java | 17 ++++++++++
 .../metron/pcapservice/PcapGetterHBaseImpl.java | 17 ++++++++++
 .../apache/metron/pcapservice/PcapHelper.java   | 17 ++++++++++
 .../pcapservice/PcapReceiverImplRestEasy.java   | 17 ++++++++++
 .../pcapservice/PcapScannerHBaseImpl.java       | 17 ++++++++++
 .../metron/pcapservice/PcapsResponse.java       | 16 +++++++++-
 .../metron/pcapservice/RestTestingUtil.java     | 17 ++++++++++
 .../pcapservice/rest/JettyServiceRunner.java    | 19 ++++++++++-
 .../metron/pcapservice/rest/PcapService.java    | 19 ++++++++++-
 .../resources/hbase-config-default.properties   | 17 ++++++++++
 .../src/main/resources/log4j.properties         | 17 ++++++++++
 .../CellTimestampComparatorTest.java            | 17 ++++++++++
 .../pcapservice/ConfigurationUtilTest.java      | 17 ++++++++++
 .../pcapservice/HBaseConfigurationUtilTest.java | 17 ++++++++++
 .../pcapservice/HBaseIntegrationTest.java       | 16 +++++++++-
 .../pcapservice/PcapGetterHBaseImplTest.java    | 17 ++++++++++
 .../metron/pcapservice/PcapHelperTest.java      | 16 +++++++++-
 .../pcapservice/PcapScannerHBaseImplTest.java   | 17 ++++++++++
 .../src/test/resources/hbase-config.properties  | 17 ++++++++++
 metron-streaming/Metron-Topologies/pom.xml      |  7 +++--
 .../apache/metron/test/bolts/PrintingBolt.java  | 15 ++++-----
 .../test/converters/BinaryConverters.java       | 20 ++++++++++--
 .../test/converters/HexStringConverter.java     | 20 ++++++++++--
 .../metron/test/converters/IConverter.java      | 20 ++++++++++--
 .../metron/test/filereaders/FileReader.java     | 15 ++++-----
 .../test/spouts/GenericInternalTestSpout.java   | 15 ++++-----
 .../metron/test/spouts/PcapSimulatorSpout.java  | 19 ++++++++++-
 .../Metron_Configs/etc/env/config.properties    | 17 ++++++++++
 .../Metron_Configs/topologies/asa/local.yaml    | 18 ++++++++++-
 .../Metron_Configs/topologies/asa/remote.yaml   | 18 ++++++++++-
 .../Metron_Configs/topologies/bro/local.yaml    | 16 ++++++++++
 .../Metron_Configs/topologies/bro/remote.yaml   | 16 ++++++++++
 .../topologies/fireeye/local.yaml               | 18 ++++++++++-
 .../topologies/fireeye/remote.yaml              | 18 ++++++++++-
 .../Metron_Configs/topologies/ise/local.yaml    | 16 ++++++++++
 .../Metron_Configs/topologies/ise/remote.yaml   | 16 ++++++++++
 .../topologies/lancope/local.yaml               | 18 ++++++++++-
 .../topologies/lancope/remote.yaml              | 18 ++++++++++-
 .../topologies/paloalto/local.yaml              | 16 ++++++++++
 .../topologies/paloalto/remote.yaml             | 16 ++++++++++
 .../Metron_Configs/topologies/pcap/local.yaml   | 16 ++++++++++
 .../Metron_Configs/topologies/pcap/remote.yaml  | 16 ++++++++++
 .../Metron_Configs/topologies/snort/local.yaml  | 16 ++++++++++
 .../Metron_Configs/topologies/snort/remote.yaml | 16 ++++++++++
 .../topologies/sourcefire/local.yaml            | 18 ++++++++++-
 .../topologies/sourcefire/remote.yaml           | 18 ++++++++++-
 .../Metron_Configs/topologies/yaf/local.yaml    | 16 ++++++++++
 .../Metron_Configs/topologies/yaf/remote.yaml   | 16 ++++++++++
 .../integration/pcap/PcapIntegrationTest.java   | 20 ++++++++++--
 .../metron/integration/util/UnitTestHelper.java | 20 ++++++++++--
 .../util/integration/ComponentRunner.java       | 20 ++++++++++--
 .../util/integration/InMemoryComponent.java     | 20 ++++++++++--
 .../integration/util/integration/Processor.java | 20 ++++++++++--
 .../util/integration/ReadinessState.java        | 20 ++++++++++--
 .../integration/UnableToStartException.java     | 20 ++++++++++--
 .../components/ElasticSearchComponent.java      | 20 ++++++++++--
 .../components/FluxTopologyComponent.java       | 20 ++++++++++--
 .../integration/util/mock/MockGeoAdapter.java   | 17 ++++++++++
 .../util/mock/MockHBaseConnector.java           | 20 ++++++++++--
 .../integration/util/mock/MockHTable.java       | 19 ++++++-----
 .../util/threatintel/ThreatIntelHelper.java     | 20 ++++++++++--
 metron-streaming/pom.xml                        | 28 +++++++++++++++--
 metron-streaming/style/LICENSE.config           | 16 ++++++++++
 metron-streaming/style/LICENSE.java             | 17 ++++++++++
 metron-streaming/style/checkstyle.xml           | 33 ++++++++++++++++++++
 298 files changed, 4565 insertions(+), 479 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/bro-plugin-kafka/Makefile
----------------------------------------------------------------------
diff --git a/bro-plugin-kafka/Makefile b/bro-plugin-kafka/Makefile
index e083d5b..977937d 100644
--- a/bro-plugin-kafka/Makefile
+++ b/bro-plugin-kafka/Makefile
@@ -1,3 +1,19 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 #
 # Convenience Makefile providing a few common top-level targets.
 #

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/bro-plugin-kafka/configure
----------------------------------------------------------------------
diff --git a/bro-plugin-kafka/configure b/bro-plugin-kafka/configure
index b9addf4..20d98f9 100755
--- a/bro-plugin-kafka/configure
+++ b/bro-plugin-kafka/configure
@@ -1,4 +1,21 @@
 #!/bin/sh
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+
 #
 # Wrapper for viewing/setting options that the plugin's CMake
 # scripts will recognize.

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/pom.xml
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/pom.xml b/metron-streaming/Metron-Alerts/pom.xml
index 22c75ea..ec921ee 100644
--- a/metron-streaming/Metron-Alerts/pom.xml
+++ b/metron-streaming/Metron-Alerts/pom.xml
@@ -1,4 +1,6 @@
-<?xml version="1.0" encoding="UTF-8"?><!-- Licensed to the Apache Software 
+<?xml version="1.0" encoding="UTF-8"?>
+<!-- 
+  Licensed to the Apache Software 
 	Foundation (ASF) under one or more contributor license agreements. See the 
 	NOTICE file distributed with this work for additional information regarding 
 	copyright ownership. The ASF licenses this file to You under the Apache License, 
@@ -7,7 +9,8 @@
 	Unless required by applicable law or agreed to in writing, software distributed 
 	under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES 
 	OR CONDITIONS OF ANY KIND, either express or implied. See the License for 
-	the specific language governing permissions and limitations under the License. -->
+  the specific language governing permissions and limitations under the License. 
+  -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/AbstractAlertBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/AbstractAlertBolt.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/AbstractAlertBolt.java
index 8d32795..f482c2a 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/AbstractAlertBolt.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/AbstractAlertBolt.java
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package org.apache.metron.alerts;
 
 import java.io.IOException;
@@ -115,4 +116,4 @@ public abstract class AbstractAlertBolt extends BaseRichBolt {
 	abstract void doPrepare(Map conf, TopologyContext topologyContext,
 			OutputCollector collector) throws IOException;
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/TelemetryAlertsBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/TelemetryAlertsBolt.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/TelemetryAlertsBolt.java
index 1ad6d14..fd898e3 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/TelemetryAlertsBolt.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/TelemetryAlertsBolt.java
@@ -1,10 +1,11 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
  *
@@ -250,4 +251,4 @@ public class TelemetryAlertsBolt extends AbstractAlertBolt {
 		}
 	}
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AbstractAlertAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AbstractAlertAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AbstractAlertAdapter.java
index 0e9ef4b..6c1b8d1 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AbstractAlertAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AbstractAlertAdapter.java
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -16,6 +16,7 @@
  * limitations under the License.
  */
 
+
 package org.apache.metron.alerts.adapters;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AllAlertAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AllAlertAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AllAlertAdapter.java
index dc03834..b527991 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AllAlertAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/AllAlertAdapter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.metron.alerts.adapters;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/CIFAlertsAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/CIFAlertsAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/CIFAlertsAdapter.java
index 690944b..4e8e025 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/CIFAlertsAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/CIFAlertsAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.adapters;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/HbaseWhiteAndBlacklistAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/HbaseWhiteAndBlacklistAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/HbaseWhiteAndBlacklistAdapter.java
index 68f2e3d..3673138 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/HbaseWhiteAndBlacklistAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/HbaseWhiteAndBlacklistAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.adapters;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/KeywordsAlertAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/KeywordsAlertAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/KeywordsAlertAdapter.java
index 7922e1f..9204240 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/KeywordsAlertAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/KeywordsAlertAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.adapters;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/RangeChecker.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/RangeChecker.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/RangeChecker.java
index 68d94bf..0807371 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/RangeChecker.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/RangeChecker.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.adapters;
 
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/ThreatAlertsAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/ThreatAlertsAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/ThreatAlertsAdapter.java
index 393269c..3e10db3 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/ThreatAlertsAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/alerts/adapters/ThreatAlertsAdapter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.metron.alerts.adapters;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/AbstractTaggerBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/AbstractTaggerBolt.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/AbstractTaggerBolt.java
index be60508..274d7cc 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/AbstractTaggerBolt.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/AbstractTaggerBolt.java
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package org.apache.metron.tagging;
 
 import java.io.IOException;
@@ -90,4 +91,4 @@ public abstract class AbstractTaggerBolt extends BaseRichBolt {
 	abstract void doPrepare(Map conf, TopologyContext topologyContext,
 			OutputCollector collector) throws IOException;
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/TelemetryTaggerBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/TelemetryTaggerBolt.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/TelemetryTaggerBolt.java
index c8d05d2..d20fcec 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/TelemetryTaggerBolt.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/TelemetryTaggerBolt.java
@@ -1,10 +1,11 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
  *
@@ -196,4 +197,4 @@ public class TelemetryTaggerBolt extends AbstractTaggerBolt {
 		declearer.declare(new Fields(this.OutputFieldName));
 
 	}
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/AbstractTaggerAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/AbstractTaggerAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/AbstractTaggerAdapter.java
index acf81ef..8ea6807 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/AbstractTaggerAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/AbstractTaggerAdapter.java
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/RegexTagger.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/RegexTagger.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/RegexTagger.java
index da40135..adc46ce 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/RegexTagger.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/RegexTagger.java
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/StaticAllTagger.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/StaticAllTagger.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/StaticAllTagger.java
index e5277fd..1e9c6c4 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/StaticAllTagger.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/StaticAllTagger.java
@@ -1,4 +1,4 @@
-/*
+/**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -7,7 +7,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/TaggerAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/TaggerAdapter.java b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/TaggerAdapter.java
index 7af15de..4fecb90 100644
--- a/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/TaggerAdapter.java
+++ b/metron-streaming/Metron-Alerts/src/main/java/org/apache/metron/tagging/adapters/TaggerAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.tagging.adapters;
 
 import org.json.simple.JSONArray;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Alerts/src/test/resources/AllAlertAdapterTest.properties
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Alerts/src/test/resources/AllAlertAdapterTest.properties b/metron-streaming/Metron-Alerts/src/test/resources/AllAlertAdapterTest.properties
index 8b13789..da6584f 100644
--- a/metron-streaming/Metron-Alerts/src/test/resources/AllAlertAdapterTest.properties
+++ b/metron-streaming/Metron-Alerts/src/test/resources/AllAlertAdapterTest.properties
@@ -1 +1,17 @@
+#  Licensed to the Apache Software Foundation (ASF) under one
+#  or more contributor license agreements.  See the NOTICE file
+#  distributed with this work for additional information
+#  regarding copyright ownership.  The ASF licenses this file
+#  to you under the Apache License, Version 2.0 (the
+#  "License"); you may not use this file except in compliance
+#  with the License.  You may obtain a copy of the License at
+#
+#      http://www.apache.org/licenses/LICENSE-2.0
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
+
 

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/pom.xml
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/pom.xml b/metron-streaming/Metron-Common/pom.xml
index f7738cb..c9918a2 100644
--- a/metron-streaming/Metron-Common/pom.xml
+++ b/metron-streaming/Metron-Common/pom.xml
@@ -1,4 +1,6 @@
-<?xml version="1.0" encoding="UTF-8"?><!-- Licensed to the Apache Software 
+<?xml version="1.0" encoding="UTF-8"?>
+<!-- 
+  Licensed to the Apache Software 
 	Foundation (ASF) under one or more contributor license agreements. See the 
 	NOTICE file distributed with this work for additional information regarding 
 	copyright ownership. The ASF licenses this file to You under the Apache License, 
@@ -7,7 +9,8 @@
 	Unless required by applicable law or agreed to in writing, software distributed 
 	under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES 
 	OR CONDITIONS OF ANY KIND, either express or implied. See the License for 
-	the specific language governing permissions and limitations under the License. -->
+  the specific language governing permissions and limitations under the License. 
+  -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsAdapter.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsAdapter.java
index ea305b4..a26054a 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsAdapter.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.interfaces;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsInterface.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsInterface.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsInterface.java
index 7a4ac36..575ad2c 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsInterface.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/AlertsInterface.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.interfaces;
 
 import org.json.simple.JSONObject;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/TaggerAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/TaggerAdapter.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/TaggerAdapter.java
index bc9a3bb..1ccdf24 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/TaggerAdapter.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/alerts/interfaces/TaggerAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.alerts.interfaces;
 
 import org.json.simple.JSONArray;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/JoinBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/JoinBolt.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/JoinBolt.java
index aec3fd0..dc84473 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/JoinBolt.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/JoinBolt.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.bolt;
 
 import backtype.storm.task.OutputCollector;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/SplitBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/SplitBolt.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/SplitBolt.java
index ad4edb7..d3d2cf3 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/SplitBolt.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/bolt/SplitBolt.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.bolt;
 
 import backtype.storm.task.OutputCollector;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/configuration/ConfigurationManager.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/configuration/ConfigurationManager.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/configuration/ConfigurationManager.java
index 2b5c28d..0989150 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/configuration/ConfigurationManager.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/configuration/ConfigurationManager.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.configuration;
 
 
@@ -116,4 +133,4 @@ public class ConfigurationManager {
         + config.getString("storm.topology.dpi.bolt.es-index.index.name"));
   }
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/dataloads/interfaces/ThreatIntelSource.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/dataloads/interfaces/ThreatIntelSource.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/dataloads/interfaces/ThreatIntelSource.java
index 3bccacc..4e87a1c 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/dataloads/interfaces/ThreatIntelSource.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/dataloads/interfaces/ThreatIntelSource.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.dataloads.interfaces;
 
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/domain/Enrichment.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/domain/Enrichment.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/domain/Enrichment.java
index 8567357..d75e9a3 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/domain/Enrichment.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/domain/Enrichment.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.domain;
 
 import org.apache.metron.enrichment.interfaces.EnrichmentAdapter;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/EnrichmentSplitterBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/EnrichmentSplitterBolt.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/EnrichmentSplitterBolt.java
index 503d3ae..967970f 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/EnrichmentSplitterBolt.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/EnrichmentSplitterBolt.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.enrichment;
 
 import backtype.storm.task.TopologyContext;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/interfaces/EnrichmentAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/interfaces/EnrichmentAdapter.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/interfaces/EnrichmentAdapter.java
index a51bebd..28f9956 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/interfaces/EnrichmentAdapter.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/enrichment/interfaces/EnrichmentAdapter.java
@@ -1,10 +1,11 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
  *

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/Connector.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/Connector.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/Connector.java
index a025e70..35da040 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/Connector.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/Connector.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 import org.apache.hadoop.hbase.client.Put;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseBolt.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseBolt.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseBolt.java
index e026b18..7aa02c5 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseBolt.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseBolt.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 
@@ -162,4 +179,4 @@ public class HBaseBolt implements IRichBolt {
   public void setAutoAck(boolean autoAck) {
     this.autoAck = autoAck;
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseStreamPartitioner.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseStreamPartitioner.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseStreamPartitioner.java
index 2e92e94..519f76c 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseStreamPartitioner.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HBaseStreamPartitioner.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 import java.io.IOException;
@@ -143,4 +160,4 @@ public class HBaseStreamPartitioner implements CustomStreamGrouping {
       }
     }
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableConnector.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableConnector.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableConnector.java
index 74c6acf..d1a9327 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableConnector.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableConnector.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.metron.hbase;
 
 import java.io.IOException;
@@ -145,4 +163,4 @@ public class HTableConnector extends Connector implements Serializable{
       LOG.error("Unable to close connection to HBase table " + tableName, ex);
     }
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableProvider.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableProvider.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableProvider.java
index f7e066c..9055837 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableProvider.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/HTableProvider.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 import org.apache.hadoop.conf.Configuration;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableConfig.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableConfig.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableConfig.java
index 8c0966b..de2e929 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableConfig.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableConfig.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 import java.io.Serializable;
@@ -5,9 +22,7 @@ import java.util.HashMap;
 import java.util.Map;
 import java.util.Set;
 
-/**
- * Created by cstella on 2/11/16.
- */
+
 public class TableConfig implements Serializable {
     static final long serialVersionUID = -1L;
     private String tableName;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableProvider.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableProvider.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableProvider.java
index d643a83..dc0569e 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableProvider.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TableProvider.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 import org.apache.hadoop.conf.Configuration;
@@ -6,9 +23,6 @@ import org.apache.hadoop.hbase.client.HTableInterface;
 import java.io.IOException;
 import java.io.Serializable;
 
-/**
- * Created by cstella on 2/11/16.
- */
 public interface TableProvider extends Serializable {
     HTableInterface getTable(Configuration config, String tableName) throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TupleTableConfig.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TupleTableConfig.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TupleTableConfig.java
index 6bacfb8..a9ec20a 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TupleTableConfig.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/hbase/TupleTableConfig.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.hbase;
 
 import java.io.IOException;
@@ -256,4 +273,4 @@ public class TupleTableConfig extends TableConfig implements Serializable {
   public String getTupleRowKeyField() {
     return tupleRowKeyField;
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/services/PcapServiceCli.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/services/PcapServiceCli.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/services/PcapServiceCli.java
index df3ee5c..79b8067 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/services/PcapServiceCli.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/services/PcapServiceCli.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.helpers.services;
 
 import org.apache.commons.cli.BasicParser;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/Cli.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/Cli.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/Cli.java
index f68bfb8..1c3940c 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/Cli.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/Cli.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.helpers.topology;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/ErrorGenerator.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/ErrorGenerator.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/ErrorGenerator.java
index 2919bcf..8ec940a 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/ErrorGenerator.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/ErrorGenerator.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.helpers.topology;
 
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/SettingsLoader.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/SettingsLoader.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/SettingsLoader.java
index e95f7fa..6977bfa 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/SettingsLoader.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/helpers/topology/SettingsLoader.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.helpers.topology;
 
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/c4954e8a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/index/interfaces/IndexAdapter.java
----------------------------------------------------------------------
diff --git a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/index/interfaces/IndexAdapter.java b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/index/interfaces/IndexAdapter.java
index dc7d0c5..3c2781a 100644
--- a/metron-streaming/Metron-Common/src/main/java/org/apache/metron/index/interfaces/IndexAdapter.java
+++ b/metron-streaming/Metron-Common/src/main/java/org/apache/metron/index/interfaces/IndexAdapter.java
@@ -1,3 +1,20 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package org.apache.metron.index.interfaces;
 
 import java.util.Map;