Skip to content

Commit

Permalink
STORM-4005 - Checkstyle
Browse files Browse the repository at this point in the history
  • Loading branch information
rzo1 committed Dec 4, 2023
1 parent c15a156 commit 3aa254e
Show file tree
Hide file tree
Showing 3 changed files with 14 additions and 10 deletions.
Original file line number Diff line number Diff line change
@@ -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
Expand All @@ -24,7 +24,9 @@

import org.apache.storm.Config;
import org.apache.storm.StormSubmitter;
import org.apache.storm.elasticsearch.common.*;
import org.apache.storm.elasticsearch.common.DefaultEsTupleMapper;
import org.apache.storm.elasticsearch.common.EsConfig;
import org.apache.storm.elasticsearch.common.EsTupleMapper;
import org.apache.storm.generated.AlreadyAliveException;
import org.apache.storm.generated.AuthorizationException;
import org.apache.storm.generated.InvalidTopologyException;
Expand Down Expand Up @@ -73,7 +75,7 @@ public static void main(final String[] args) throws AlreadyAliveException,
TopologyBuilder builder = new TopologyBuilder();
UserDataSpout spout = new UserDataSpout();
builder.setSpout(SPOUT_ID, spout, 1);
EsTupleMapper tupleMapper =new DefaultEsTupleMapper();
EsTupleMapper tupleMapper = new DefaultEsTupleMapper();
EsConfig esConfig = new EsConfig("http://localhost:9300");
builder.setBolt(BOLT_ID, new EsIndexBolt(esConfig, tupleMapper), 1)
.shuffleGrouping(SPOUT_ID);
Expand Down Expand Up @@ -127,8 +129,8 @@ public void declareOutputFields(final OutputFieldsDeclarer declarer) {
*/
@Override
public void open(final Map<String, Object> config,
final TopologyContext context,
final SpoutOutputCollector collectorArg) {
final TopologyContext context,
final SpoutOutputCollector collectorArg) {
this.collector = collectorArg;
this.pending = new ConcurrentHashMap<>();
}
Expand Down
Original file line number Diff line number Diff line change
@@ -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
Expand Down
Original file line number Diff line number Diff line change
@@ -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
Expand Down Expand Up @@ -26,7 +26,9 @@

import org.apache.storm.Config;
import org.apache.storm.StormSubmitter;
import org.apache.storm.elasticsearch.common.*;
import org.apache.storm.elasticsearch.common.DefaultEsTupleMapper;
import org.apache.storm.elasticsearch.common.EsConfig;
import org.apache.storm.elasticsearch.common.EsTupleMapper;
import org.apache.storm.generated.AlreadyAliveException;
import org.apache.storm.generated.AuthorizationException;
import org.apache.storm.generated.InvalidTopologyException;
Expand Down Expand Up @@ -141,7 +143,7 @@ public Fields getOutputFields() {
*/
@Override
public void open(final Map<String, Object> conf,
final TopologyContext context) {
final TopologyContext context) {
index = 0;
}

Expand All @@ -152,7 +154,7 @@ public void open(final Map<String, Object> conf,
*/
@Override
public void emitBatch(final long batchId,
final TridentCollector collector) {
final TridentCollector collector) {
List<List<Object>> batch = this.batches.get(batchId);
if (batch == null) {
batch = new ArrayList<List<Object>>();
Expand Down

0 comments on commit 3aa254e

Please sign in to comment.