http://git-wip-us.apache.org/repos/asf/incubator-beam-site/blob/cc22c462/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InMemoryWatermarkManager.html ---------------------------------------------------------------------- diff --git a/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InMemoryWatermarkManager.html b/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InMemoryWatermarkManager.html deleted file mode 100644 index 86a3c63..0000000 --- a/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InMemoryWatermarkManager.html +++ /dev/null @@ -1,442 +0,0 @@ - - - -
- - -public class InMemoryWatermarkManager -extends Object-
PCollections
and input and output watermarks of
- AppliedPTransforms
to provide event-time and completion tracking for
- in-memory execution. InMemoryWatermarkManager
is designed to update and return a
- consistent view of watermarks in the presence of concurrent updates.
-
- An InMemoryWatermarkManager
is provided with the collection of root
- AppliedPTransforms
and a map of PCollections
to
- all the AppliedPTransforms
that consume them at construction time.
-
-
Whenever a root transform
produces elements, the
- InMemoryWatermarkManager
is provided with the produced elements and the output watermark
- of the producing transform
. The
- watermark manager
is responsible for computing the watermarks
- of all transforms
that consume one or more
- PCollections
.
-
-
Whenever a non-root AppliedPTransform
finishes processing one or more in-flight
- elements (referred to as the input bundle
), the following occurs
- atomically:
-
AppliedPTransform
.AppliedPTransform
are added to the collection
- of pending elements for each AppliedPTransform
that consumes them.AppliedPTransform
becomes the maximum value of
- PCollection
watermarksAppliedPTransform
becomes the maximum of
- PCollection
can be advanced to the output watermark of
- the AppliedPTransform
AppliedPTransforms
can be
- advanced.The watermark of a PCollection
is equal to the output watermark of the
- AppliedPTransform
that produces it.
-
-
The watermarks for a PTransform
are updated as follows when output is committed:
- Watermark_In' = MAX(Watermark_In, MIN(U(TS_Pending), U(Watermark_InputPCollection))) - Watermark_Out' = MAX(Watermark_Out, MIN(Watermark_In', U(StateHold))) - Watermark_PCollection = Watermark_Out_ProducingPTransform -
Modifier and Type | -Class and Description | -
---|---|
static class |
-InMemoryWatermarkManager.FiredTimers
-A pair of
-TimerInternals.TimerData and key which can be delivered to the appropriate
- AppliedPTransform . |
-
static class |
-InMemoryWatermarkManager.TimerUpdate
-A collection of newly set, deleted, and completed timers.
- |
-
class |
-InMemoryWatermarkManager.TransformWatermarks
-A reference to the input and output watermarks of an
-AppliedPTransform . |
-
Modifier and Type | -Method and Description | -
---|---|
static InMemoryWatermarkManager |
-create(Clock clock,
- Collection<AppliedPTransform<?,?,?>> rootTransforms,
- Map<PValue,Collection<AppliedPTransform<?,?,?>>> consumers)
-Creates a new
-InMemoryWatermarkManager . |
-
Map<AppliedPTransform<?,?,?>,Map<org.apache.beam.runners.direct.StructuralKey<?>,InMemoryWatermarkManager.FiredTimers>> |
-extractFiredTimers()
-Returns a map of each
-PTransform that has pending timers to those timers. |
-
Set<AppliedPTransform<?,?,?>> |
-getCompletedTransforms() |
-
InMemoryWatermarkManager.TransformWatermarks |
-getWatermarks(AppliedPTransform<?,?,?> transform)
-Gets the input and output watermarks for an
-AppliedPTransform . |
-
void |
-updateWatermarks(InProcessPipelineRunner.CommittedBundle<?> completed,
- InMemoryWatermarkManager.TimerUpdate timerUpdate,
- org.apache.beam.runners.direct.CommittedResult result,
- org.joda.time.Instant earliestHold)
-Updates the watermarks of a transform with one or more inputs.
- |
-
public static InMemoryWatermarkManager create(Clock clock, - Collection<AppliedPTransform<?,?,?>> rootTransforms, - Map<PValue,Collection<AppliedPTransform<?,?,?>>> consumers)-
InMemoryWatermarkManager
. All watermarks within the newly created
- InMemoryWatermarkManager
start at BoundedWindow.TIMESTAMP_MIN_VALUE
, the
- minimum watermark, with no watermark holds or pending elements.rootTransforms
- the root-level transforms of the Pipeline
consumers
- a mapping between each PCollection
in the Pipeline
to the
- transforms that consume it as a part of their inputpublic InMemoryWatermarkManager.TransformWatermarks getWatermarks(AppliedPTransform<?,?,?> transform)-
AppliedPTransform
. If the
- PTransform
has not processed any elements, return a watermark of
- BoundedWindow.TIMESTAMP_MIN_VALUE
.public void updateWatermarks(@Nullable - InProcessPipelineRunner.CommittedBundle<?> completed, - InMemoryWatermarkManager.TimerUpdate timerUpdate, - org.apache.beam.runners.direct.CommittedResult result, - org.joda.time.Instant earliestHold)-
Each transform has two monotonically increasing watermarks: the input watermark, which can, - at any time, be updated to equal: -
- MAX(CurrentInputWatermark, MIN(PendingElements, InputPCollectionWatermarks)) -- and the output watermark, which can, at any time, be updated to equal: -
- MAX(CurrentOutputWatermark, MIN(InputWatermark, WatermarkHolds)) -.
completed
- the input that has completedtimerUpdate
- the timers that were added, removed, and completed as part of producing
- this updateresult
- the result that was produced by processing the inputearliestHold
- the earliest watermark hold in the transform's state. null
if there
- is no holdpublic Map<AppliedPTransform<?,?,?>,Map<org.apache.beam.runners.direct.StructuralKey<?>,InMemoryWatermarkManager.FiredTimers>> extractFiredTimers()-
PTransform
that has pending timers to those timers. All of the
- pending timers will be removed from this InMemoryWatermarkManager
.public Set<AppliedPTransform<?,?,?>> getCompletedTransforms()-
Copyright © 2016 The Apache Software Foundation. All rights reserved.
- - http://git-wip-us.apache.org/repos/asf/incubator-beam-site/blob/cc22c462/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessBundleOutputManager.html ---------------------------------------------------------------------- diff --git a/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessBundleOutputManager.html b/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessBundleOutputManager.html deleted file mode 100644 index da149dc..0000000 --- a/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessBundleOutputManager.html +++ /dev/null @@ -1,303 +0,0 @@ - - - - - - -public class InProcessBundleOutputManager -extends Object -implements DoFnRunners.OutputManager- -
Constructor and Description | -
---|
InProcessBundleOutputManager(Map<TupleTag<?>,InProcessPipelineRunner.UncommittedBundle<?>> bundles) |
-
Modifier and Type | -Method and Description | -
---|---|
static InProcessBundleOutputManager |
-create(Map<TupleTag<?>,InProcessPipelineRunner.UncommittedBundle<?>> outputBundles) |
-
<T> void |
-output(TupleTag<T> tag,
- WindowedValue<T> output)
-Outputs a single element to the receiver indicated by the given
-TupleTag . |
-
public InProcessBundleOutputManager(Map<TupleTag<?>,InProcessPipelineRunner.UncommittedBundle<?>> bundles)-
public static InProcessBundleOutputManager create(Map<TupleTag<?>,InProcessPipelineRunner.UncommittedBundle<?>> outputBundles)-
public <T> void output(TupleTag<T> tag, - WindowedValue<T> output)-
DoFnRunners.OutputManager
TupleTag
.output
in interface DoFnRunners.OutputManager
Copyright © 2016 The Apache Software Foundation. All rights reserved.
- - http://git-wip-us.apache.org/repos/asf/incubator-beam-site/blob/cc22c462/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessPipelineOptions.html ---------------------------------------------------------------------- diff --git a/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessPipelineOptions.html b/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessPipelineOptions.html deleted file mode 100644 index 1fab964..0000000 --- a/documentation/sdks/javadoc/0.1.0-incubating/org/apache/beam/runners/direct/InProcessPipelineOptions.html +++ /dev/null @@ -1,407 +0,0 @@ - - - - - - -public interface InProcessPipelineOptions -extends PipelineOptions, ApplicationNameOptions-
InProcessPipelineRunner
.PipelineOptions.CheckEnabled
Modifier and Type | -Method and Description | -
---|---|
Clock |
-getClock()
-Gets the
-Clock used by this pipeline. |
-
ExecutorServiceFactory |
-getExecutorServiceFactory()
-Gets the
-ExecutorServiceFactory to use to create instances of ExecutorService
- to execute PTransforms . |
-
boolean |
-isBlockOnRun() |
-
boolean |
-isShutdownUnboundedProducersWithMaxWatermark() |
-
boolean |
-isTestImmutability() |
-
void |
-setBlockOnRun(boolean b) |
-
void |
-setClock(Clock clock) |
-
void |
-setExecutorServiceFactory(ExecutorServiceFactory executorService) |
-
void |
-setShutdownUnboundedProducersWithMaxWatermark(boolean shutdown) |
-
void |
-setTestImmutability(boolean test) |
-
getAppName, setAppName
as, cloneAs, getRunner, getStableUniqueNames, getTempLocation, setRunner, setStableUniqueNames, setTempLocation
populateDisplayData
@Validation.Required - @Hidden - @Default.InstanceFactory(value=org.apache.beam.runners.direct.FixedThreadPoolExecutorServiceFactory.class) -ExecutorServiceFactory getExecutorServiceFactory()-
ExecutorServiceFactory
to use to create instances of ExecutorService
- to execute PTransforms
.
-
- Note that ExecutorServices
returned by the factory must ensure that
- it cannot enter a state in which it will not schedule additional pending work unless currently
- scheduled work completes, as this may cause the Pipeline
to cease processing.
-
-
Defaults to a FixedThreadPoolExecutorServiceFactory
, which produces instances of
- Executors.newCachedThreadPool()
.
void setExecutorServiceFactory(ExecutorServiceFactory executorService)-
@Default.InstanceFactory(value=NanosOffsetClock.Factory.class) - @Validation.Required - @Hidden -Clock getClock()-
Clock
used by this pipeline. The clock is used in place of accessing the
- system time when time values are required by the evaluator.void setClock(Clock clock)-
@Default.Boolean(value=false) -boolean isShutdownUnboundedProducersWithMaxWatermark()-
void setShutdownUnboundedProducersWithMaxWatermark(boolean shutdown)-
@Default.Boolean(value=true) -boolean isBlockOnRun()-
void setBlockOnRun(boolean b)-
@Default.Boolean(value=true) -boolean isTestImmutability()-
void setTestImmutability(boolean test)-
Copyright © 2016 The Apache Software Foundation. All rights reserved.
- -