public static class BatchStatefulParDoOverrides.BatchStatefulDoFn<K,V,OutputT> extends DoFn<KV<K,java.lang.Iterable<KV<Instant,org.apache.beam.sdk.util.WindowedValue<KV<K,V>>>>>,OutputT>
DoFn that explodes an iterable that has been grouped by key and
 window.DoFn.AlwaysFetched, DoFn.BoundedPerElement, DoFn.BundleFinalizer, DoFn.Element, DoFn.FieldAccess, DoFn.FinishBundle, DoFn.FinishBundleContext, DoFn.GetInitialRestriction, DoFn.GetInitialWatermarkEstimatorState, DoFn.GetRestrictionCoder, DoFn.GetSize, DoFn.GetWatermarkEstimatorStateCoder, DoFn.Key, DoFn.MultiOutputReceiver, DoFn.NewTracker, DoFn.NewWatermarkEstimator, DoFn.OnTimer, DoFn.OnTimerContext, DoFn.OnTimerFamily, DoFn.OnWindowExpiration, DoFn.OnWindowExpirationContext, DoFn.OutputReceiver<T>, DoFn.ProcessContext, DoFn.ProcessContinuation, DoFn.ProcessElement, DoFn.RequiresStableInput, DoFn.RequiresTimeSortedInput, DoFn.Restriction, DoFn.Setup, DoFn.SideInput, DoFn.SplitRestriction, DoFn.StartBundle, DoFn.StartBundleContext, DoFn.StateId, DoFn.Teardown, DoFn.TimerFamily, DoFn.TimerId, DoFn.Timestamp, DoFn.TruncateRestriction, DoFn.UnboundedPerElement, DoFn.WatermarkEstimatorState, DoFn.WindowedContext| Modifier and Type | Method and Description | 
|---|---|
| TypeDescriptor<OutputT> | getOutputTypeDescriptor()Returns a  TypeDescriptorcapturing what is known statically about the output type of
 thisDoFninstance's most-derived class. | 
| DoFn<KV<K,V>,OutputT> | getUnderlyingDoFn() | 
| void | processElement(DoFn.ProcessContext c,
              BoundedWindow window) | 
| void | setup(PipelineOptions options) | 
| void | teardown() | 
getAllowedTimestampSkew, getInputTypeDescriptor, populateDisplayData, prepareForProcessing@DoFn.Setup public void setup(PipelineOptions options)
@DoFn.ProcessElement public void processElement(DoFn.ProcessContext c, BoundedWindow window)
@DoFn.Teardown public void teardown()
public TypeDescriptor<OutputT> getOutputTypeDescriptor()
DoFnTypeDescriptor capturing what is known statically about the output type of
 this DoFn instance's most-derived class.
 In the normal case of a concrete DoFn subclass with no generic type parameters of
 its own (including anonymous inner classes), this will be a complete non-generic type, which is
 good for choosing a default output Coder<O> for the output PCollection<O>.