public class OffsetByteRangeCoder extends AtomicCoder<org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange>
Coder.Context, Coder.NonDeterministicException| Constructor and Description | 
|---|
| OffsetByteRangeCoder() | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange | decode(java.io.InputStream inStream)Decodes a value of type  Tfrom the given input stream in the given context. | 
| void | encode(org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange value,
      java.io.OutputStream outStream)Encodes the given value of type  Tonto the given output stream. | 
| static CoderProvider | getCoderProvider() | 
equals, getCoderArguments, getComponents, hashCode, verifyDeterministictoStringconsistentWithEquals, decode, encode, getEncodedElementByteSize, getEncodedTypeDescriptor, isRegisterByteSizeObserverCheap, registerByteSizeObserver, structuralValue, verifyDeterministic, verifyDeterministicpublic void encode(org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange value,
                   java.io.OutputStream outStream)
            throws java.io.IOException
CoderT onto the given output stream.encode in class Coder<org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange>java.io.IOException - if writing to the OutputStream fails for some reasonCoderException - if the value could not be encoded for some reasonpublic org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange decode(java.io.InputStream inStream)
                                                                      throws java.io.IOException
CoderT from the given input stream in the given context. Returns the
 decoded value.decode in class Coder<org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange>java.io.IOException - if reading from the InputStream fails for some reasonCoderException - if the value could not be decoded for some reasonpublic static CoderProvider getCoderProvider()