T
- type of the elements in the collectionpublic class MultiOuputCoder<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
T from 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
T onto the given output stream. |
static MultiOuputCoder |
of(Coder<TupleTag> tupleTagCoder,
java.util.Map<TupleTag<?>,Coder<?>> coderMap,
Coder<? extends BoundedWindow> windowCoder) |
getCoderArguments, verifyDeterministic
consistentWithEquals, decode, encode, getEncodedElementByteSize, getEncodedTypeDescriptor, isRegisterByteSizeObserverCheap, registerByteSizeObserver, structuralValue, verifyDeterministic, verifyDeterministic
public static MultiOuputCoder 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
Coder
T
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
Coder
T
from the given input stream in the given context. Returns the
decoded value.