public class PubsubMessageWithAttributesCoder extends CustomCoder<PubsubMessage>
Coder.Context, Coder.NonDeterministicException
Constructor and Description |
---|
PubsubMessageWithAttributesCoder() |
Modifier and Type | Method and Description |
---|---|
PubsubMessage |
decode(java.io.InputStream inStream)
Decodes a value of type
T from the given input stream in the given context. |
PubsubMessage |
decode(java.io.InputStream inStream,
Coder.Context context)
Decodes a value of type
T from the given input stream in the given context. |
void |
encode(PubsubMessage value,
java.io.OutputStream outStream)
Encodes the given value of type
T onto the given output stream. |
void |
encode(PubsubMessage value,
java.io.OutputStream outStream,
Coder.Context context)
Encodes the given value of type
T onto the given output stream in the given context. |
static PubsubMessageWithAttributesCoder |
of() |
static Coder<PubsubMessage> |
of(TypeDescriptor<PubsubMessage> ignored) |
getCoderArguments, verifyDeterministic
consistentWithEquals, getEncodedElementByteSize, getEncodedTypeDescriptor, isRegisterByteSizeObserverCheap, registerByteSizeObserver, structuralValue, verifyDeterministic, verifyDeterministic
public static Coder<PubsubMessage> of(TypeDescriptor<PubsubMessage> ignored)
public static PubsubMessageWithAttributesCoder of()
public void encode(PubsubMessage value, java.io.OutputStream outStream) throws java.io.IOException
Coder
T
onto the given output stream.encode
in class Coder<PubsubMessage>
java.io.IOException
- if writing to the OutputStream
fails for some reasonCoderException
- if the value could not be encoded for some reasonpublic void encode(PubsubMessage value, java.io.OutputStream outStream, Coder.Context context) throws java.io.IOException
Coder
T
onto the given output stream in the given context.encode
in class Coder<PubsubMessage>
java.io.IOException
- if writing to the OutputStream
fails for some reasonCoderException
- if the value could not be encoded for some reasonpublic PubsubMessage decode(java.io.InputStream inStream) throws java.io.IOException
Coder
T
from the given input stream in the given context. Returns the
decoded value.decode
in class Coder<PubsubMessage>
java.io.IOException
- if reading from the InputStream
fails for some reasonCoderException
- if the value could not be decoded for some reasonpublic PubsubMessage decode(java.io.InputStream inStream, Coder.Context context) throws java.io.IOException
Coder
T
from the given input stream in the given context. Returns the
decoded value.decode
in class Coder<PubsubMessage>
java.io.IOException
- if reading from the InputStream
fails for some reasonCoderException
- if the value could not be decoded for some reason