T - type of the elements in the collectionpublic class MultiOutputCoder<T> extends CustomCoder<scala.Tuple2<TupleTag<T>,org.apache.beam.sdk.util.WindowedValue<T>>>
DoFn.Coder.Context, Coder.NonDeterministicException| Modifier and Type | Method and Description | 
|---|---|
| scala.Tuple2<TupleTag<T>,org.apache.beam.sdk.util.WindowedValue<T>> | decode(java.io.InputStream inStream)Decodes a value of type  Tfrom the given input stream in the given context. | 
| void | encode(scala.Tuple2<TupleTag<T>,org.apache.beam.sdk.util.WindowedValue<T>> tuple2,
      java.io.OutputStream outStream)Encodes the given value of type  Tonto the given output stream. | 
| static MultiOutputCoder | of(Coder<TupleTag> tupleTagCoder,
  java.util.Map<TupleTag<?>,Coder<?>> coderMap,
  Coder<? extends BoundedWindow> windowCoder) | 
getCoderArguments, verifyDeterministicconsistentWithEquals, decode, encode, getEncodedElementByteSize, getEncodedTypeDescriptor, isRegisterByteSizeObserverCheap, registerByteSizeObserver, structuralValue, verifyDeterministic, verifyDeterministicpublic static MultiOutputCoder of(Coder<TupleTag> tupleTagCoder, java.util.Map<TupleTag<?>,Coder<?>> coderMap, Coder<? extends BoundedWindow> windowCoder)
public void encode(scala.Tuple2<TupleTag<T>,org.apache.beam.sdk.util.WindowedValue<T>> tuple2, java.io.OutputStream outStream) throws java.io.IOException
CoderT onto the given output stream.public scala.Tuple2<TupleTag<T>,org.apache.beam.sdk.util.WindowedValue<T>> decode(java.io.InputStream inStream) throws CoderException, java.io.IOException
CoderT from the given input stream in the given context. Returns the
 decoded value.