Skip to content

Commit

Permalink
Closes #880
Browse files Browse the repository at this point in the history
  • Loading branch information
dhalperi committed Aug 24, 2016
2 parents 2f4321e + ddda21b commit f7384e1
Show file tree
Hide file tree
Showing 8 changed files with 11 additions and 12 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -37,7 +37,7 @@


/**
* An example that verifies word counts in Shakespeare and includes Dataflow best practices.
* An example that verifies word counts in Shakespeare and includes Beam best practices.
*
* <p>This class, {@link DebuggingWordCount}, is the third in a series of four successively more
* detailed 'word count' examples. You may first want to take a look at {@link MinimalWordCount}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -183,8 +183,7 @@ public static interface Options extends WordCount.WordCountOptions,
public static void main(String[] args) throws IOException {
Options options = PipelineOptionsFactory.fromArgs(args).withValidation().as(Options.class);
options.setBigQuerySchema(getSchema());
// DataflowExampleUtils creates the necessary input sources to simplify execution of this
// Pipeline.
// ExampleUtils creates the necessary input sources to simplify execution of this Pipeline.
ExampleUtils exampleUtils = new ExampleUtils(options);
exampleUtils.setup();

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@
* Options that can be used to configure the Beam examples.
*/
public interface ExampleOptions extends PipelineOptions {
@Description("Whether to keep jobs running on the Dataflow service after local process exit")
@Description("Whether to keep jobs running after local process exit")
@Default.Boolean(false)
boolean getKeepJobsRunning();
void setKeepJobsRunning(boolean keepJobsRunning);
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -43,14 +43,14 @@ This directory contains end-to-end example pipelines that perform complex data p
<code>Windowing</code> to perform time-based aggregations of data.
</li>
<li><a href="https://github.com/GoogleCloudPlatform/DataflowJavaSDK/blob/master/examples/src/main/java/com/google/cloud/dataflow/examples/complete/TrafficMaxLaneFlow.java">TrafficMaxLaneFlow</a>
&mdash; A streaming Cloud Dataflow example using BigQuery output in the
&mdash; A streaming Beam Example using BigQuery output in the
<code>traffic sensor</code> domain. Demonstrates the Cloud Dataflow streaming
runner, sliding windows, Cloud Pub/Sub topic ingestion, the use of the
<code>AvroCoder</code> to encode a custom class, and custom
<code>Combine</code> transforms.
</li>
<li><a href="https://github.com/GoogleCloudPlatform/DataflowJavaSDK/blob/master/examples/src/main/java/com/google/cloud/dataflow/examples/complete/TrafficRoutes.java">TrafficRoutes</a>
&mdash; A streaming Cloud Dataflow example using BigQuery output in the
&mdash; A streaming Beam Example using BigQuery output in the
<code>traffic sensor</code> domain. Demonstrates the Cloud Dataflow streaming
runner, <code>GroupByKey</code>, keyed state, sliding windows, and Cloud
Pub/Sub topic ingestion.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -37,7 +37,7 @@
import org.apache.beam.sdk.transforms.ParDo;

/**
* A streaming Dataflow Example using BigQuery output.
* A streaming Beam Example using BigQuery output.
*
* <p>This pipeline example reads lines of the input text file, splits each line
* into individual words, capitalizes those words, and writes the output to
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -181,7 +181,7 @@ public void processElement(ProcessContext c) {
/**
* Options supported by this class.
*
* <p>Inherits standard Dataflow configuration options.
* <p>Inherits standard Beam configuration options.
*/
private static interface Options extends PipelineOptions {
@Description(
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -53,7 +53,7 @@
import org.joda.time.format.DateTimeFormatter;

/**
* A Dataflow Example that runs in both batch and streaming modes with traffic sensor data.
* A Beam Example that runs in both batch and streaming modes with traffic sensor data.
* You can configure the running mode by setting {@literal --streaming} to true or false.
*
* <p>Concepts: The batch and streaming runners, sliding windows,
Expand Down Expand Up @@ -329,7 +329,7 @@ public static void main(String[] args) throws IOException {
.withValidation()
.as(TrafficMaxLaneFlowOptions.class);
options.setBigQuerySchema(FormatMaxesFn.getSchema());
// Using DataflowExampleUtils to set up required resources.
// Using ExampleUtils to set up required resources.
ExampleUtils exampleUtils = new ExampleUtils(options);
exampleUtils.setup();

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -57,7 +57,7 @@
import org.joda.time.format.DateTimeFormatter;

/**
* A Dataflow Example that runs in both batch and streaming modes with traffic sensor data.
* A Beam Example that runs in both batch and streaming modes with traffic sensor data.
* You can configure the running mode by setting {@literal --streaming} to true or false.
*
* <p>Concepts: The batch and streaming runners, GroupByKey, sliding windows.
Expand Down Expand Up @@ -340,7 +340,7 @@ public static void main(String[] args) throws IOException {
.as(TrafficRoutesOptions.class);

options.setBigQuerySchema(FormatStatsFn.getSchema());
// Using DataflowExampleUtils to set up required resources.
// Using ExampleUtils to set up required resources.
ExampleUtils exampleUtils = new ExampleUtils(options);
exampleUtils.setup();

Expand Down

0 comments on commit f7384e1

Please sign in to comment.