You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jmeter.apache.org by fs...@apache.org on 2015/12/10 20:10:08 UTC

svn commit: r1719185 [5/8] - in /jmeter/trunk/src/core/org/apache/jmeter/report: config/ core/ dashboard/ processor/ processor/graph/ processor/graph/impl/

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/RequestsSummaryConsumer.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/RequestsSummaryConsumer.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/RequestsSummaryConsumer.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/RequestsSummaryConsumer.java Thu Dec 10 19:10:06 2015
@@ -1,79 +1,79 @@
-/*
- * 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.jmeter.report.processor;
-
-import org.apache.jmeter.report.core.Sample;
-
-/**
- * <p>
- * The class GrapherConsumer provides a consumer that count succeeded and failed
- * samples.
- * </p>
- * 
- * @since 2.14
- */
-public class RequestsSummaryConsumer extends AbstractSampleConsumer {
-
-    private long count;
-    private long errorCount;
-
-    /* (non-Javadoc)
-     * @see org.apache.jmeter.report.processor.SampleConsumer#startConsuming()
-     */
-    @Override
-    public void startConsuming() {
-        count = 0L;
-        errorCount = 0L;
-
-        // Broadcast metadata to consumes for each channel
-        int channelCount = getConsumedChannelCount();
-        for (int i = 0; i < channelCount; i++) {
-            super.setProducedMetadata(getConsumedMetadata(i), i);
-        }
-
-        super.startProducing();
-    }
-
-    /* (non-Javadoc)
-     * @see org.apache.jmeter.report.processor.SampleConsumer#consume(org.apache.jmeter.report.core.Sample, int)
-     */
-    @Override
-    public void consume(Sample sample, int channel) {
-        count++;
-        if (sample.getSuccess() == false) {
-            errorCount++;
-        }
-        super.produce(sample, channel);
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.processor.SampleConsumer#stopConsuming()
-     */
-    @Override
-    public void stopConsuming() {
-        MapResultData result = new MapResultData();
-        result.setResult("KoPercent", new ValueResultData((double) errorCount
-                * 100 / count));
-        result.setResult("OkPercent", new ValueResultData(
-                (double) (count - errorCount) * 100 / count));
-        setDataToContext(getName(), result);
-        super.stopProducing();
-    }
-}
+/*
+ * 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.jmeter.report.processor;
+
+import org.apache.jmeter.report.core.Sample;
+
+/**
+ * <p>
+ * The class GrapherConsumer provides a consumer that count succeeded and failed
+ * samples.
+ * </p>
+ * 
+ * @since 2.14
+ */
+public class RequestsSummaryConsumer extends AbstractSampleConsumer {
+
+    private long count;
+    private long errorCount;
+
+    /* (non-Javadoc)
+     * @see org.apache.jmeter.report.processor.SampleConsumer#startConsuming()
+     */
+    @Override
+    public void startConsuming() {
+        count = 0L;
+        errorCount = 0L;
+
+        // Broadcast metadata to consumes for each channel
+        int channelCount = getConsumedChannelCount();
+        for (int i = 0; i < channelCount; i++) {
+            super.setProducedMetadata(getConsumedMetadata(i), i);
+        }
+
+        super.startProducing();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jmeter.report.processor.SampleConsumer#consume(org.apache.jmeter.report.core.Sample, int)
+     */
+    @Override
+    public void consume(Sample sample, int channel) {
+        count++;
+        if (sample.getSuccess() == false) {
+            errorCount++;
+        }
+        super.produce(sample, channel);
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.processor.SampleConsumer#stopConsuming()
+     */
+    @Override
+    public void stopConsuming() {
+        MapResultData result = new MapResultData();
+        result.setResult("KoPercent", new ValueResultData((double) errorCount
+                * 100 / count));
+        result.setResult("OkPercent", new ValueResultData(
+                (double) (count - errorCount) * 100 / count));
+        setDataToContext(getName(), result);
+        super.stopProducing();
+    }
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/RequestsSummaryConsumer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultData.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultData.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultData.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultData.java Thu Dec 10 19:10:06 2015
@@ -1,34 +1,34 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * The interface ResultData represents a result from samples processing.
- * 
- * @since 2.14
- */
-public interface ResultData {
-
-    /**
-     * Accepts the specified visitor.
-     *
-     * @param visitor
-     *            the visitor
-     */
-    <TVisit> TVisit accept(ResultDataVisitor<TVisit> visitor);
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * The interface ResultData represents a result from samples processing.
+ * 
+ * @since 2.14
+ */
+public interface ResultData {
+
+    /**
+     * Accepts the specified visitor.
+     *
+     * @param visitor
+     *            the visitor
+     */
+    <TVisit> TVisit accept(ResultDataVisitor<TVisit> visitor);
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultData.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultDataVisitor.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultDataVisitor.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultDataVisitor.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultDataVisitor.java Thu Dec 10 19:10:06 2015
@@ -1,56 +1,56 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * The interface ResultDataVisitor represents a visitor for result data from
- * samples processing.
- *
- * @param <TVisit>
- *            the type returned by visit methods
- * @since 2.14
- */
-public interface ResultDataVisitor<TVisit> {
-
-    /**
-     * Visits the specified list result.
-     *
-     * @param listResult
-     *            the list result
-     * @return the result of the visit
-     */
-    TVisit visitListResult(ListResultData listResult);
-
-    /**
-     * Visits the specified map result.
-     *
-     * @param mapResult
-     *            the map result
-     * @return the result of the visit
-     */
-    TVisit visitMapResult(MapResultData mapResult);
-
-    /**
-     * Visits the specified value result.
-     *
-     * @param valueResult
-     *            the value result
-     * @return the result of the visit
-     */
-    TVisit visitValueResult(ValueResultData valueResult);
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * The interface ResultDataVisitor represents a visitor for result data from
+ * samples processing.
+ *
+ * @param <TVisit>
+ *            the type returned by visit methods
+ * @since 2.14
+ */
+public interface ResultDataVisitor<TVisit> {
+
+    /**
+     * Visits the specified list result.
+     *
+     * @param listResult
+     *            the list result
+     * @return the result of the visit
+     */
+    TVisit visitListResult(ListResultData listResult);
+
+    /**
+     * Visits the specified map result.
+     *
+     * @param mapResult
+     *            the map result
+     * @return the result of the visit
+     */
+    TVisit visitMapResult(MapResultData mapResult);
+
+    /**
+     * Visits the specified value result.
+     *
+     * @param valueResult
+     *            the value result
+     * @return the result of the visit
+     */
+    TVisit visitValueResult(ValueResultData valueResult);
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ResultDataVisitor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleConsumer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleContext.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleIndexer.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleIndexer.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleIndexer.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleIndexer.java Thu Dec 10 19:10:06 2015
@@ -1,46 +1,46 @@
-/*
- * 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.jmeter.report.processor;
-
-import org.apache.jmeter.report.core.Sample;
-
-/**
- * The classes that implement interface SampleIndexer have to calculate an index
- * from a sample.
- *
- * @param <TIndex>
- *            the type of the index
- * 
- * @since 2.14
- */
-public interface SampleIndexer<TIndex> {
-
-    /**
-     * Calculate index from the specified sample.
-     *
-     * @param sample
-     *            the sample
-     * @return the index
-     */
-    TIndex calculateIndex(Sample sample);
-
-    /**
-     * Reset the index calculation logic.
-     */
-    void reset();
-}
+/*
+ * 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.jmeter.report.processor;
+
+import org.apache.jmeter.report.core.Sample;
+
+/**
+ * The classes that implement interface SampleIndexer have to calculate an index
+ * from a sample.
+ *
+ * @param <TIndex>
+ *            the type of the index
+ * 
+ * @since 2.14
+ */
+public interface SampleIndexer<TIndex> {
+
+    /**
+     * Calculate index from the specified sample.
+     *
+     * @param sample
+     *            the sample
+     * @return the index
+     */
+    TIndex calculateIndex(Sample sample);
+
+    /**
+     * Reset the index calculation logic.
+     */
+    void reset();
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleIndexer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleProcessor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleProducer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleSource.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleSource.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleSource.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleSource.java Thu Dec 10 19:10:06 2015
@@ -1,59 +1,59 @@
-/*
- * 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.jmeter.report.processor;
-
-import java.util.List;
-
-/**
- * The interface SampleSource represents a source of samples for sample consumers.
- *
- * @since 2.14
- */
-public interface SampleSource extends Runnable {
-
-    /**
-     * Gets the sample context.
-     *
-     * @return the sampleContext
-     */
-    public SampleContext getSampleContext();
-    
-    /**
-     * Sets the sample context.
-     *
-     * @param sampleContext
-     *            the sampleContext to set
-     */
-    public void setSampleContext(SampleContext sampleContext);
-    
-    /**
-     * Sets the specified sample consumers that will consume samples produced by
-     * this sample source.
-     */
-    public void setSampleConsumers(List<SampleConsumer> consumers);
-    
-    /**
-     * Add a sample consumer to this sample source.
-     */
-    public void addSampleConsumer(SampleConsumer consumer);
-    
-    /**
-     * Remove a sample consumer from this sample source.
-     */
-    public void removeSampleConsumer(SampleConsumer consumer);
-}
+/*
+ * 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.jmeter.report.processor;
+
+import java.util.List;
+
+/**
+ * The interface SampleSource represents a source of samples for sample consumers.
+ *
+ * @since 2.14
+ */
+public interface SampleSource extends Runnable {
+
+    /**
+     * Gets the sample context.
+     *
+     * @return the sampleContext
+     */
+    public SampleContext getSampleContext();
+    
+    /**
+     * Sets the sample context.
+     *
+     * @param sampleContext
+     *            the sampleContext to set
+     */
+    public void setSampleContext(SampleContext sampleContext);
+    
+    /**
+     * Sets the specified sample consumers that will consume samples produced by
+     * this sample source.
+     */
+    public void setSampleConsumers(List<SampleConsumer> consumers);
+    
+    /**
+     * Add a sample consumer to this sample source.
+     */
+    public void addSampleConsumer(SampleConsumer consumer);
+    
+    /**
+     * Remove a sample consumer from this sample source.
+     */
+    public void removeSampleConsumer(SampleConsumer consumer);
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleSource.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleWriterConsumer.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleWriterConsumer.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleWriterConsumer.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleWriterConsumer.java Thu Dec 10 19:10:06 2015
@@ -1,122 +1,122 @@
-/*
- * 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.jmeter.report.processor;
-
-import java.io.File;
-
-import org.apache.jmeter.report.core.ArgumentNullException;
-import org.apache.jmeter.report.core.CsvSampleWriter;
-import org.apache.jmeter.report.core.Sample;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Sample consumed byt this consumer are written to a file<br>
- * <br>
- * 
- * @since 2.14
- */
-public class SampleWriterConsumer extends AbstractSampleConsumer {
-
-    private static final Logger log = LoggerFactory.getLogger(SampleWriterConsumer.class);
-
-    private File outputFile;
-
-    private CsvSampleWriter[] csvWriters;
-
-    private boolean shouldWriteHeader;
-
-    private int channelsCount;
-
-    public void setOutputFile(String outputFile) {
-        setOutputFile(new File(outputFile));
-    }
-
-    public void setOutputFile(File outputFile) {
-        if (outputFile == null) {
-        throw new ArgumentNullException("outputFile");
-        }
-
-        this.outputFile = outputFile;
-    }
-
-    public File getOutputFile() {
-        return outputFile;
-    }
-
-    public File getOutputFile(int channel) {
-        String ext = null;
-        String fName = getOutputFile().getName();
-        int idx = fName.lastIndexOf('.');
-        if (idx >= 0 && idx < fName.length() - 1) {
-            String backedName = fName;
-            fName = fName.substring(0, idx);
-            ext = backedName.substring(idx + 1);
-        } else {
-            ext = "";
-        }
-        if (channel > 0) {
-            fName += "-" + channel + "." + ext;
-        } else {
-            fName += "." + ext;
-        }
-        return new File(getOutputFile().getParentFile(), fName);
-    }
-
-    /**
-     * Enables the CSV header on the output file (defaults to false)
-     */
-    public void setWriteHeader(boolean writeHeader) {
-        this.shouldWriteHeader = writeHeader;
-    }
-
-    @Override
-    public void startConsuming() {
-        if (outputFile == null) {
-            File wd = getWorkingDirectory();
-            wd.mkdir();
-            if (log.isInfoEnabled()) {
-                log.info("startConsuming(): No output file set, writing to work directory :"
-                    + wd.getAbsolutePath());
-            }
-            outputFile = new File(wd, "samples.csv");
-        }
-        outputFile.getParentFile().mkdirs();
-        channelsCount = getConsumedChannelCount();
-        csvWriters = new CsvSampleWriter[channelsCount];
-        for (int i = 0; i < channelsCount; i++) {
-            csvWriters[i] = new CsvSampleWriter(getOutputFile(i),getConsumedMetadata(i));
-            if (shouldWriteHeader) {
-                csvWriters[i].writeHeader();
-            }
-        }
-    }
-
-    @Override
-    public void consume(Sample s, int channel) {
-        csvWriters[channel].write(s);
-    }
-
-    @Override
-    public void stopConsuming() {
-        for (int i = 0; i < channelsCount; i++) {
-            csvWriters[i].close();
-        }
-        getWorkingDirectory().delete();
-    }
-}
+/*
+ * 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.jmeter.report.processor;
+
+import java.io.File;
+
+import org.apache.jmeter.report.core.ArgumentNullException;
+import org.apache.jmeter.report.core.CsvSampleWriter;
+import org.apache.jmeter.report.core.Sample;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Sample consumed byt this consumer are written to a file<br>
+ * <br>
+ * 
+ * @since 2.14
+ */
+public class SampleWriterConsumer extends AbstractSampleConsumer {
+
+    private static final Logger log = LoggerFactory.getLogger(SampleWriterConsumer.class);
+
+    private File outputFile;
+
+    private CsvSampleWriter[] csvWriters;
+
+    private boolean shouldWriteHeader;
+
+    private int channelsCount;
+
+    public void setOutputFile(String outputFile) {
+        setOutputFile(new File(outputFile));
+    }
+
+    public void setOutputFile(File outputFile) {
+        if (outputFile == null) {
+        throw new ArgumentNullException("outputFile");
+        }
+
+        this.outputFile = outputFile;
+    }
+
+    public File getOutputFile() {
+        return outputFile;
+    }
+
+    public File getOutputFile(int channel) {
+        String ext = null;
+        String fName = getOutputFile().getName();
+        int idx = fName.lastIndexOf('.');
+        if (idx >= 0 && idx < fName.length() - 1) {
+            String backedName = fName;
+            fName = fName.substring(0, idx);
+            ext = backedName.substring(idx + 1);
+        } else {
+            ext = "";
+        }
+        if (channel > 0) {
+            fName += "-" + channel + "." + ext;
+        } else {
+            fName += "." + ext;
+        }
+        return new File(getOutputFile().getParentFile(), fName);
+    }
+
+    /**
+     * Enables the CSV header on the output file (defaults to false)
+     */
+    public void setWriteHeader(boolean writeHeader) {
+        this.shouldWriteHeader = writeHeader;
+    }
+
+    @Override
+    public void startConsuming() {
+        if (outputFile == null) {
+            File wd = getWorkingDirectory();
+            wd.mkdir();
+            if (log.isInfoEnabled()) {
+                log.info("startConsuming(): No output file set, writing to work directory :"
+                    + wd.getAbsolutePath());
+            }
+            outputFile = new File(wd, "samples.csv");
+        }
+        outputFile.getParentFile().mkdirs();
+        channelsCount = getConsumedChannelCount();
+        csvWriters = new CsvSampleWriter[channelsCount];
+        for (int i = 0; i < channelsCount; i++) {
+            csvWriters[i] = new CsvSampleWriter(getOutputFile(i),getConsumedMetadata(i));
+            if (shouldWriteHeader) {
+                csvWriters[i].writeHeader();
+            }
+        }
+    }
+
+    @Override
+    public void consume(Sample s, int channel) {
+        csvWriters[channel].write(s);
+    }
+
+    @Override
+    public void stopConsuming() {
+        for (int i = 0; i < channelsCount; i++) {
+            csvWriters[i].close();
+        }
+        getWorkingDirectory().delete();
+    }
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SampleWriterConsumer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/StatisticsSummaryConsumer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/StatisticsSummaryData.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/StatisticsSummaryData.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/StatisticsSummaryData.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/StatisticsSummaryData.java Thu Dec 10 19:10:06 2015
@@ -1,234 +1,234 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * The class ApdexSummaryData provides information for
- * StatisticsSummaryConsumer.
- * 
- * @since 2.14
- *
- */
-public class StatisticsSummaryData {
-
-    private long firstTime = Long.MAX_VALUE;
-    private long endTime = Long.MIN_VALUE;
-    private long bytes = 0L;
-    private long errors = 0L;
-    private long total = 0L;
-    private final PercentileAggregator percentile1;
-    private final PercentileAggregator percentile2;
-    private final PercentileAggregator percentile3;
-    private long min = Long.MAX_VALUE;
-    private long max = Long.MIN_VALUE;
-
-    public long getElapsedTime() {
-        return endTime - firstTime;
-    }
-
-    /**
-     * Gets the first time.
-     *
-     * @return the firstTime
-     */
-    public final long getFirstTime() {
-        return firstTime;
-    }
-
-    /**
-     * Sets the first time.
-     *
-     * @param firstTime
-     *            the firstTime to set
-     */
-    public final void setFirstTime(long firstTime) {
-        this.firstTime = Math.min(this.firstTime, firstTime);
-    }
-
-    /**
-     * Gets the end time.
-     *
-     * @return the endTime
-     */
-    public final long getEndTime() {
-        return endTime;
-    }
-
-    /**
-     * Sets the end time.
-     *
-     * @param endTime
-     *            the endTime to set
-     */
-    public final void setEndTime(long endTime) {
-        this.endTime = Math.max(this.endTime, endTime);
-    }
-
-    /**
-     * Gets the bytes.
-     *
-     * @return the bytes
-     */
-    public final long getBytes() {
-        return bytes;
-    }
-
-    /**
-     * Sets the bytes.
-     *
-     * @param bytes
-     *            the bytes to set
-     */
-    public final void setBytes(long bytes) {
-        this.bytes = bytes;
-    }
-
-    /**
-     * @return the errors
-     */
-    public final long getErrors() {
-        return errors;
-    }
-
-    /**
-     * @param errors
-     *            the errors to set
-     */
-    public final void setErrors(long errors) {
-        this.errors = errors;
-    }
-
-    /**
-     * @return the total
-     */
-    public final long getTotal() {
-        return total;
-    }
-
-    /**
-     * @param total
-     *            the total to set
-     */
-    public final void setTotal(long total) {
-        this.total = total;
-    }
-
-    /**
-     * @return the min
-     */
-    public final long getMin() {
-        return min;
-    }
-
-    /**
-     * @param min
-     *            the min to set
-     */
-    public final void setMin(long min) {
-        this.min = Math.min(this.min, min);
-    }
-
-    /**
-     * @return the max
-     */
-    public final long getMax() {
-        return max;
-    }
-
-    /**
-     * @param max
-     *            the max to set
-     */
-    public final void setMax(long max) {
-        this.max = Math.max(this.max, max);
-    }
-
-    /**
-     * @return the percentile1
-     */
-    public final PercentileAggregator getPercentile1() {
-        return percentile1;
-    }
-
-    /**
-     * Gets the percentile2.
-     *
-     * @return the percentile2
-     */
-    public final PercentileAggregator getPercentile2() {
-        return percentile2;
-    }
-
-    /**
-     * Gets the percentile3.
-     *
-     * @return the percentile3
-     */
-    public final PercentileAggregator getPercentile3() {
-        return percentile3;
-    }
-
-    /**
-     * Instantiates a new statistics info.
-     */
-    public StatisticsSummaryData(long percentileIndex1, long percentileIndex2,
-            long percentileIndex3) {
-        percentile1 = new PercentileAggregator(percentileIndex1);
-        percentile2 = new PercentileAggregator(percentileIndex2);
-        percentile3 = new PercentileAggregator(percentileIndex3);
-    }
-
-    /**
-     * Gets the bytes per second.
-     *
-     * @return the bytes per second
-     */
-    public double getBytesPerSecond() {
-        return bytes / ((double) getElapsedTime() / 1000);
-    }
-
-    /**
-     * Gets the kilo bytes per second.
-     *
-     * @return the kilo bytes per second
-     */
-    public double getKBytesPerSecond() {
-        return getBytesPerSecond() / 1024;
-    }
-
-    /**
-     * Gets the throughput.
-     *
-     * @return the throughput
-     */
-    public double getThroughput() {
-        return (total / (double) getElapsedTime()) * 1000.0;
-    }
-
-    public void IncTotal() {
-        total++;
-    }
-
-    public void IncBytes(long value) {
-        bytes += value;
-    }
-
-    public void IncErrors() {
-        errors++;
-    }
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * The class ApdexSummaryData provides information for
+ * StatisticsSummaryConsumer.
+ * 
+ * @since 2.14
+ *
+ */
+public class StatisticsSummaryData {
+
+    private long firstTime = Long.MAX_VALUE;
+    private long endTime = Long.MIN_VALUE;
+    private long bytes = 0L;
+    private long errors = 0L;
+    private long total = 0L;
+    private final PercentileAggregator percentile1;
+    private final PercentileAggregator percentile2;
+    private final PercentileAggregator percentile3;
+    private long min = Long.MAX_VALUE;
+    private long max = Long.MIN_VALUE;
+
+    public long getElapsedTime() {
+        return endTime - firstTime;
+    }
+
+    /**
+     * Gets the first time.
+     *
+     * @return the firstTime
+     */
+    public final long getFirstTime() {
+        return firstTime;
+    }
+
+    /**
+     * Sets the first time.
+     *
+     * @param firstTime
+     *            the firstTime to set
+     */
+    public final void setFirstTime(long firstTime) {
+        this.firstTime = Math.min(this.firstTime, firstTime);
+    }
+
+    /**
+     * Gets the end time.
+     *
+     * @return the endTime
+     */
+    public final long getEndTime() {
+        return endTime;
+    }
+
+    /**
+     * Sets the end time.
+     *
+     * @param endTime
+     *            the endTime to set
+     */
+    public final void setEndTime(long endTime) {
+        this.endTime = Math.max(this.endTime, endTime);
+    }
+
+    /**
+     * Gets the bytes.
+     *
+     * @return the bytes
+     */
+    public final long getBytes() {
+        return bytes;
+    }
+
+    /**
+     * Sets the bytes.
+     *
+     * @param bytes
+     *            the bytes to set
+     */
+    public final void setBytes(long bytes) {
+        this.bytes = bytes;
+    }
+
+    /**
+     * @return the errors
+     */
+    public final long getErrors() {
+        return errors;
+    }
+
+    /**
+     * @param errors
+     *            the errors to set
+     */
+    public final void setErrors(long errors) {
+        this.errors = errors;
+    }
+
+    /**
+     * @return the total
+     */
+    public final long getTotal() {
+        return total;
+    }
+
+    /**
+     * @param total
+     *            the total to set
+     */
+    public final void setTotal(long total) {
+        this.total = total;
+    }
+
+    /**
+     * @return the min
+     */
+    public final long getMin() {
+        return min;
+    }
+
+    /**
+     * @param min
+     *            the min to set
+     */
+    public final void setMin(long min) {
+        this.min = Math.min(this.min, min);
+    }
+
+    /**
+     * @return the max
+     */
+    public final long getMax() {
+        return max;
+    }
+
+    /**
+     * @param max
+     *            the max to set
+     */
+    public final void setMax(long max) {
+        this.max = Math.max(this.max, max);
+    }
+
+    /**
+     * @return the percentile1
+     */
+    public final PercentileAggregator getPercentile1() {
+        return percentile1;
+    }
+
+    /**
+     * Gets the percentile2.
+     *
+     * @return the percentile2
+     */
+    public final PercentileAggregator getPercentile2() {
+        return percentile2;
+    }
+
+    /**
+     * Gets the percentile3.
+     *
+     * @return the percentile3
+     */
+    public final PercentileAggregator getPercentile3() {
+        return percentile3;
+    }
+
+    /**
+     * Instantiates a new statistics info.
+     */
+    public StatisticsSummaryData(long percentileIndex1, long percentileIndex2,
+            long percentileIndex3) {
+        percentile1 = new PercentileAggregator(percentileIndex1);
+        percentile2 = new PercentileAggregator(percentileIndex2);
+        percentile3 = new PercentileAggregator(percentileIndex3);
+    }
+
+    /**
+     * Gets the bytes per second.
+     *
+     * @return the bytes per second
+     */
+    public double getBytesPerSecond() {
+        return bytes / ((double) getElapsedTime() / 1000);
+    }
+
+    /**
+     * Gets the kilo bytes per second.
+     *
+     * @return the kilo bytes per second
+     */
+    public double getKBytesPerSecond() {
+        return getBytesPerSecond() / 1024;
+    }
+
+    /**
+     * Gets the throughput.
+     *
+     * @return the throughput
+     */
+    public double getThroughput() {
+        return (total / (double) getElapsedTime()) * 1000.0;
+    }
+
+    public void IncTotal() {
+        total++;
+    }
+
+    public void IncBytes(long value) {
+        bytes += value;
+    }
+
+    public void IncErrors() {
+        errors++;
+    }
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/StatisticsSummaryData.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregator.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregator.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregator.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregator.java Thu Dec 10 19:10:06 2015
@@ -1,72 +1,72 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * The class SumAggregator is used to get sum from samples.
- * 
- * @since 2.14
- */
-public class SumAggregator implements Aggregator {
-
-    private long count = 0;
-    private double sum = 0;
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#getCount()
-     */
-    @Override
-    public long getCount() {
-        return count;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#getResult()
-     */
-    @Override
-    public double getResult() {
-        return sum;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#addValue(double)
-     */
-    @Override
-    public void addValue(double value) {
-        count++;
-        sum += value;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#reset()
-     */
-    @Override
-    public void reset() {
-        count = 0;
-        sum = 0;
-    }
-
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * The class SumAggregator is used to get sum from samples.
+ * 
+ * @since 2.14
+ */
+public class SumAggregator implements Aggregator {
+
+    private long count = 0;
+    private double sum = 0;
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#getCount()
+     */
+    @Override
+    public long getCount() {
+        return count;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#getResult()
+     */
+    @Override
+    public double getResult() {
+        return sum;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#addValue(double)
+     */
+    @Override
+    public void addValue(double value) {
+        count++;
+        sum += value;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#reset()
+     */
+    @Override
+    public void reset() {
+        count = 0;
+        sum = 0;
+    }
+
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregatorFactory.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregatorFactory.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregatorFactory.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregatorFactory.java Thu Dec 10 19:10:06 2015
@@ -1,39 +1,39 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * A factory for creating SumAggregator objects.
- *
- * @since 2.14
- */
-public class SumAggregatorFactory extends AbstractAggregatorFactory {
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see
-     * org.apache.jmeter.report.core.AbstractAggregatorFactory#createAggregator
-     * ()
-     */
-    @Override
-    protected Aggregator createAggregator() {
-        return new SumAggregator();
-    }
-
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * A factory for creating SumAggregator objects.
+ *
+ * @since 2.14
+ */
+public class SumAggregatorFactory extends AbstractAggregatorFactory {
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see
+     * org.apache.jmeter.report.core.AbstractAggregatorFactory#createAggregator
+     * ()
+     */
+    @Override
+    protected Aggregator createAggregator() {
+        return new SumAggregator();
+    }
+
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/SumAggregatorFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/TaggerConsumer.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/TaggerConsumer.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/TaggerConsumer.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/TaggerConsumer.java Thu Dec 10 19:10:06 2015
@@ -1,131 +1,131 @@
-/*
- * 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.jmeter.report.processor;
-
-import java.util.ArrayList;
-
-import org.apache.jmeter.report.core.Sample;
-import org.apache.jmeter.report.core.SampleBuilder;
-import org.apache.jmeter.report.core.SampleMetadata;
-import org.apache.jmeter.report.processor.AbstractSampleConsumer;
-
-/**
- * The Class TimeCountConsumer adds a data field to the samples it consumes.
- *
- * The new field is identified by the value of tagLabel in the sample metadata.
- *
- * @param <TIndex>
- *            the generic type
- * 
- * @since 2.14
- */
-public class TaggerConsumer<TIndex> extends AbstractSampleConsumer {
-
-    public static final String DEFAULT_TAG_LABEL = "Tag";
-
-    // Collection of sample builders for channels
-    private ArrayList<SampleBuilder> builders = new ArrayList<>();
-    private SampleIndexer<TIndex> sampleIndexer;
-    private String tagLabel = DEFAULT_TAG_LABEL;
-
-    /**
-     * Gets the label of the tag used by this consumer.
-     *
-     * @return the label of the tag used by this consumer.
-     */
-    public final String getTagLabel() {
-        return tagLabel;
-    }
-
-    public final void setTagLabel(String tagLabel) {
-        // TODO what if tagLabel is null or empty ?
-        this.tagLabel = tagLabel;
-    }
-
-    public final SampleIndexer<TIndex> getSampleIndexer() {
-        return sampleIndexer;
-    }
-
-    public final void setSampleIndexer(SampleIndexer<TIndex> sampleIndexer) {
-        this.sampleIndexer = sampleIndexer;
-    }
-
-    // Adds a new field in the sample metadata for each channel
-    private void initProducedMetadata() {
-        builders.clear();
-        int channelCount = getConsumedChannelCount();
-        for (int i = 0; i < channelCount; i++) {
-            // Get the metadata for the current channel
-            SampleMetadata consumedMetadata = getConsumedMetadata(i);
-
-            // Copy metadata to an array
-            int colCount = consumedMetadata.getColumnCount();
-            String[] names = new String[colCount + 1];
-            for (int j = 0; j < colCount; j++) {
-                names[j] = consumedMetadata.getColumnName(j);
-            }
-
-            // Add the new field
-            names[colCount] = tagLabel;
-
-            // Build the produced metadata from the array
-            SampleMetadata producedMetadata = new SampleMetadata(
-                    consumedMetadata.getSeparator(), names);
-
-            // Add a sample builder for the current channel
-            builders.add(new SampleBuilder(producedMetadata));
-            super.setProducedMetadata(producedMetadata, i);
-        }
-    }
-
-    private Sample createIndexedSample(Sample sample, int channel, TIndex index) {
-        SampleBuilder builder = builders.get(channel);
-        SampleMetadata metadata = builder.getMetadata();
-        int colCount = metadata.getColumnCount();
-        for (int i = 0; i < colCount - 1; i++) {
-            builder.add(sample.getString(i));
-        }
-        builder.add(String.valueOf(index));
-        return builder.build();
-    }
-
-    @Override
-    public void startConsuming() {
-        // TODO what if sampleIndexer is null ?
-        if (sampleIndexer != null) {
-            sampleIndexer.reset();
-        }
-        initProducedMetadata();
-        super.startProducing();
-    }
-
-    @Override
-    public void consume(Sample sample, int channel) {
-        // TODO what if s or sampleIndexer are null ?
-        if (sample != null && sampleIndexer != null) {
-            TIndex index = sampleIndexer.calculateIndex(sample);
-            Sample indexedSample = createIndexedSample(sample, channel, index);
-            super.produce(indexedSample, channel);
-        }
-    }
-
-    @Override
-    public void stopConsuming() {
-        super.stopProducing();
-    }
-}
+/*
+ * 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.jmeter.report.processor;
+
+import java.util.ArrayList;
+
+import org.apache.jmeter.report.core.Sample;
+import org.apache.jmeter.report.core.SampleBuilder;
+import org.apache.jmeter.report.core.SampleMetadata;
+import org.apache.jmeter.report.processor.AbstractSampleConsumer;
+
+/**
+ * The Class TimeCountConsumer adds a data field to the samples it consumes.
+ *
+ * The new field is identified by the value of tagLabel in the sample metadata.
+ *
+ * @param <TIndex>
+ *            the generic type
+ * 
+ * @since 2.14
+ */
+public class TaggerConsumer<TIndex> extends AbstractSampleConsumer {
+
+    public static final String DEFAULT_TAG_LABEL = "Tag";
+
+    // Collection of sample builders for channels
+    private ArrayList<SampleBuilder> builders = new ArrayList<>();
+    private SampleIndexer<TIndex> sampleIndexer;
+    private String tagLabel = DEFAULT_TAG_LABEL;
+
+    /**
+     * Gets the label of the tag used by this consumer.
+     *
+     * @return the label of the tag used by this consumer.
+     */
+    public final String getTagLabel() {
+        return tagLabel;
+    }
+
+    public final void setTagLabel(String tagLabel) {
+        // TODO what if tagLabel is null or empty ?
+        this.tagLabel = tagLabel;
+    }
+
+    public final SampleIndexer<TIndex> getSampleIndexer() {
+        return sampleIndexer;
+    }
+
+    public final void setSampleIndexer(SampleIndexer<TIndex> sampleIndexer) {
+        this.sampleIndexer = sampleIndexer;
+    }
+
+    // Adds a new field in the sample metadata for each channel
+    private void initProducedMetadata() {
+        builders.clear();
+        int channelCount = getConsumedChannelCount();
+        for (int i = 0; i < channelCount; i++) {
+            // Get the metadata for the current channel
+            SampleMetadata consumedMetadata = getConsumedMetadata(i);
+
+            // Copy metadata to an array
+            int colCount = consumedMetadata.getColumnCount();
+            String[] names = new String[colCount + 1];
+            for (int j = 0; j < colCount; j++) {
+                names[j] = consumedMetadata.getColumnName(j);
+            }
+
+            // Add the new field
+            names[colCount] = tagLabel;
+
+            // Build the produced metadata from the array
+            SampleMetadata producedMetadata = new SampleMetadata(
+                    consumedMetadata.getSeparator(), names);
+
+            // Add a sample builder for the current channel
+            builders.add(new SampleBuilder(producedMetadata));
+            super.setProducedMetadata(producedMetadata, i);
+        }
+    }
+
+    private Sample createIndexedSample(Sample sample, int channel, TIndex index) {
+        SampleBuilder builder = builders.get(channel);
+        SampleMetadata metadata = builder.getMetadata();
+        int colCount = metadata.getColumnCount();
+        for (int i = 0; i < colCount - 1; i++) {
+            builder.add(sample.getString(i));
+        }
+        builder.add(String.valueOf(index));
+        return builder.build();
+    }
+
+    @Override
+    public void startConsuming() {
+        // TODO what if sampleIndexer is null ?
+        if (sampleIndexer != null) {
+            sampleIndexer.reset();
+        }
+        initProducedMetadata();
+        super.startProducing();
+    }
+
+    @Override
+    public void consume(Sample sample, int channel) {
+        // TODO what if s or sampleIndexer are null ?
+        if (sample != null && sampleIndexer != null) {
+            TIndex index = sampleIndexer.calculateIndex(sample);
+            Sample indexedSample = createIndexedSample(sample, channel, index);
+            super.produce(indexedSample, channel);
+        }
+    }
+
+    @Override
+    public void stopConsuming() {
+        super.stopProducing();
+    }
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/TaggerConsumer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ThresholdSelector.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/ThresholdSelector.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/ThresholdSelector.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/ThresholdSelector.java Thu Dec 10 19:10:06 2015
@@ -1,37 +1,37 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * The interface ThresholdSelector represents a projection from the samplers
- * with the same name to APDEX threshold information.
- *
- * @since 2.14
- */
-public interface ThresholdSelector {
-
-    /**
-     * Do a projection from the specified samplers name to APDEX threshold
-     * information.
-     *
-     * @param sampleName
-     *            the name of samples, or empty string for overall thresholds
-     * @return the apdex thresholds information
-     */
-    ApdexThresholdsInfo select(String sampleName);
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * The interface ThresholdSelector represents a projection from the samplers
+ * with the same name to APDEX threshold information.
+ *
+ * @since 2.14
+ */
+public interface ThresholdSelector {
+
+    /**
+     * Do a projection from the specified samplers name to APDEX threshold
+     * information.
+     *
+     * @param sampleName
+     *            the name of samples, or empty string for overall thresholds
+     * @return the apdex thresholds information
+     */
+    ApdexThresholdsInfo select(String sampleName);
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ThresholdSelector.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregator.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregator.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregator.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregator.java Thu Dec 10 19:10:06 2015
@@ -1,88 +1,88 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * The class TimeRateAggregator is used to get samples rate by second.
- * 
- * @since 2.14
- */
-public class TimeRateAggregator implements Aggregator {
-
-    private long count = 0;
-    private long granularity = 1;
-    private double value = 0;
-
-    /**
-     * @return the granularity
-     */
-    public final long getGranularity() {
-        return granularity;
-    }
-
-    /**
-     * @param granularity
-     *            the granularity to set
-     */
-    public final void setGranularity(long granularity) {
-        this.granularity = granularity;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#getCount()
-     */
-    @Override
-    public long getCount() {
-        return count;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#getResult()
-     */
-    @Override
-    public double getResult() {
-        return value * 1000 / granularity;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#addValue(double)
-     */
-    @Override
-    public void addValue(final double value) {
-        this.count++;
-        this.value += value;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.apache.jmeter.report.core.GraphAggregator#reset()
-     */
-    @Override
-    public void reset() {
-        count = 0;
-        value = 0;
-    }
-
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * The class TimeRateAggregator is used to get samples rate by second.
+ * 
+ * @since 2.14
+ */
+public class TimeRateAggregator implements Aggregator {
+
+    private long count = 0;
+    private long granularity = 1;
+    private double value = 0;
+
+    /**
+     * @return the granularity
+     */
+    public final long getGranularity() {
+        return granularity;
+    }
+
+    /**
+     * @param granularity
+     *            the granularity to set
+     */
+    public final void setGranularity(long granularity) {
+        this.granularity = granularity;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#getCount()
+     */
+    @Override
+    public long getCount() {
+        return count;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#getResult()
+     */
+    @Override
+    public double getResult() {
+        return value * 1000 / granularity;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#addValue(double)
+     */
+    @Override
+    public void addValue(final double value) {
+        this.count++;
+        this.value += value;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.apache.jmeter.report.core.GraphAggregator#reset()
+     */
+    @Override
+    public void reset() {
+        count = 0;
+        value = 0;
+    }
+
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregatorFactory.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregatorFactory.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregatorFactory.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregatorFactory.java Thu Dec 10 19:10:06 2015
@@ -1,62 +1,62 @@
-/*
- * 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.jmeter.report.processor;
-
-/**
- * A factory for creating TimeRateAggregator objects.
- *
- * @since 2.14
- */
-public class TimeRateAggregatorFactory extends AbstractAggregatorFactory {
-
-    private long granularity = 1L;
-
-    /**
-     * Gets the granularity used by created aggregators.
-     *
-     * @return the granularity
-     */
-    public final long getGranularity() {
-        return granularity;
-    }
-
-    /**
-     * Sets the granularity used by created aggregators.
-     *
-     * @param granularity
-     *            the granularity to set
-     */
-    public final void setGranularity(long granularity) {
-        this.granularity = granularity;
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see
-     * org.apache.jmeter.report.core.AbstractAggregatorFactory#createAggregator
-     * ()
-     */
-    @Override
-    protected Aggregator createAggregator() {
-        TimeRateAggregator aggregator = new TimeRateAggregator();
-        aggregator.setGranularity(granularity);
-        return aggregator;
-    }
-
-}
+/*
+ * 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.jmeter.report.processor;
+
+/**
+ * A factory for creating TimeRateAggregator objects.
+ *
+ * @since 2.14
+ */
+public class TimeRateAggregatorFactory extends AbstractAggregatorFactory {
+
+    private long granularity = 1L;
+
+    /**
+     * Gets the granularity used by created aggregators.
+     *
+     * @return the granularity
+     */
+    public final long getGranularity() {
+        return granularity;
+    }
+
+    /**
+     * Sets the granularity used by created aggregators.
+     *
+     * @param granularity
+     *            the granularity to set
+     */
+    public final void setGranularity(long granularity) {
+        this.granularity = granularity;
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see
+     * org.apache.jmeter.report.core.AbstractAggregatorFactory#createAggregator
+     * ()
+     */
+    @Override
+    protected Aggregator createAggregator() {
+        TimeRateAggregator aggregator = new TimeRateAggregator();
+        aggregator.setGranularity(granularity);
+        return aggregator;
+    }
+
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/TimeRateAggregatorFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ValueResultData.java
URL: http://svn.apache.org/viewvc/jmeter/trunk/src/core/org/apache/jmeter/report/processor/ValueResultData.java?rev=1719185&r1=1719184&r2=1719185&view=diff
==============================================================================
--- jmeter/trunk/src/core/org/apache/jmeter/report/processor/ValueResultData.java (original)
+++ jmeter/trunk/src/core/org/apache/jmeter/report/processor/ValueResultData.java Thu Dec 10 19:10:06 2015
@@ -1,81 +1,81 @@
-/*
- * 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.jmeter.report.processor;
-
-import org.apache.jmeter.report.core.ArgumentNullException;
-
-/**
- * The class ValueResultData provides a value result from samples processing.
- * 
- * @since 2.14
- */
-public class ValueResultData implements ResultData {
-
-    private Object value;
-
-    /**
-     * Gets the value of the result.
-     *
-     * @return the value of the result
-     */
-    public final Object getValue() {
-        return value;
-    }
-
-    /**
-     * Sets the value of the result.
-     *
-     * @param value
-     *            the new value of the result
-     */
-    public final void setValue(Object value) {
-        this.value = value;
-    }
-
-    /**
-     * Instantiates a new value result data.
-     */
-    public ValueResultData() {
-    }
-
-    /**
-     * Instantiates a new value result data.
-     *
-     * @param value
-     *            the value of the result
-     */
-    public ValueResultData(Object value) {
-        setValue(value);
-    }
-
-    /*
-     * (non-Javadoc)
-     * 
-     * @see
-     * org.apache.jmeter.report.processor.ResultData#accept(org.apache.jmeter
-     * .report.processor.ResultDataVisitor)
-     */
-    @Override
-    public <TVisit> TVisit accept(ResultDataVisitor<TVisit> visitor) {
-        if (visitor == null) {
-            throw new ArgumentNullException("visitor");
-        }
-        return visitor.visitValueResult(this);
-    }
-
-}
+/*
+ * 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.jmeter.report.processor;
+
+import org.apache.jmeter.report.core.ArgumentNullException;
+
+/**
+ * The class ValueResultData provides a value result from samples processing.
+ * 
+ * @since 2.14
+ */
+public class ValueResultData implements ResultData {
+
+    private Object value;
+
+    /**
+     * Gets the value of the result.
+     *
+     * @return the value of the result
+     */
+    public final Object getValue() {
+        return value;
+    }
+
+    /**
+     * Sets the value of the result.
+     *
+     * @param value
+     *            the new value of the result
+     */
+    public final void setValue(Object value) {
+        this.value = value;
+    }
+
+    /**
+     * Instantiates a new value result data.
+     */
+    public ValueResultData() {
+    }
+
+    /**
+     * Instantiates a new value result data.
+     *
+     * @param value
+     *            the value of the result
+     */
+    public ValueResultData(Object value) {
+        setValue(value);
+    }
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see
+     * org.apache.jmeter.report.processor.ResultData#accept(org.apache.jmeter
+     * .report.processor.ResultDataVisitor)
+     */
+    @Override
+    public <TVisit> TVisit accept(ResultDataVisitor<TVisit> visitor) {
+        if (visitor == null) {
+            throw new ArgumentNullException("visitor");
+        }
+        return visitor.visitValueResult(this);
+    }
+
+}

Propchange: jmeter/trunk/src/core/org/apache/jmeter/report/processor/ValueResultData.java
------------------------------------------------------------------------------
    svn:eol-style = native