See: Description
| Interface | Description | 
|---|---|
| CompressedSource.DecompressingChannelFactory | Factory interface for creating channels that decompress the content of an underlying channel. | 
| FileBasedSink.OutputFileHints | Provides hints about how to generate output files, such as a suggested filename suffix (e.g. | 
| FileBasedSink.WritableByteChannelFactory | Implementations create instances of  WritableByteChannelused byFileBasedSinkand related classes to allow decorating, or otherwise transforming, the raw data that
 would normally be written directly to theWritableByteChannelpassed intoFileBasedSink.WritableByteChannelFactory.create(WritableByteChannel). | 
| FileSystemRegistrar | A registrar that creates  FileSysteminstances fromPipelineOptions. | 
| UnboundedSource.CheckpointMark | A marker representing the progress and state of an
  UnboundedSource.UnboundedReader. | 
| Class | Description | 
|---|---|
| AvroIO | PTransforms for reading and writing Avro files. | 
| AvroIO.Parse<T> | |
| AvroIO.ParseAll<T> | |
| AvroIO.Read<T> | Implementation of  AvroIO.read(java.lang.Class<T>)andAvroIO.readGenericRecords(org.apache.avro.Schema). | 
| AvroIO.ReadAll<T> | Implementation of  AvroIO.readAll(java.lang.Class<T>). | 
| AvroIO.TypedWrite<UserT,DestinationT,OutputT> | Implementation of  AvroIO.write(java.lang.Class<T>). | 
| AvroIO.Write<T> | This class is used as the default return value of  AvroIO.write(java.lang.Class<T>) | 
| AvroSource<T> | Do not use in pipelines directly: most users should use  AvroIO.Read. | 
| AvroSource.AvroReader<T> | A  BlockBasedSource.BlockBasedReaderfor reading blocks from Avro files. | 
| BlockBasedSource<T> | A  BlockBasedSourceis aFileBasedSourcewhere a file consists of blocks of
 records. | 
| BlockBasedSource.Block<T> | A  Blockrepresents a block of records that can be read. | 
| BlockBasedSource.BlockBasedReader<T> | A  Readerthat reads records from aBlockBasedSource. | 
| BoundedReadFromUnboundedSource<T> | PTransformthat reads a bounded amount of data from anUnboundedSource,
 specified as one or both of a maximum number of elements or a maximum period of time to read. | 
| BoundedSource<T> | A  Sourcethat reads a finite amount of input and, because of that, supports
 some additional operations. | 
| BoundedSource.BoundedReader<T> | A  Readerthat reads a bounded amount of input and supports some additional
 operations, such as progress estimation and dynamic work rebalancing. | 
| CompressedSource<T> | A Source that reads from compressed files. | 
| CompressedSource.CompressedReader<T> | Reader for a  CompressedSource. | 
| CountingSource | Most users should use  GenerateSequenceinstead. | 
| CountingSource.CounterMark | The checkpoint for an unbounded  CountingSourceis simply the last value produced. | 
| DefaultFilenamePolicy | A default  FileBasedSink.FilenamePolicyfor windowed and unwindowed files. | 
| DefaultFilenamePolicy.Params | Encapsulates constructor parameters to  DefaultFilenamePolicy. | 
| DefaultFilenamePolicy.ParamsCoder | A Coder for  DefaultFilenamePolicy.Params. | 
| DynamicAvroDestinations<UserT,DestinationT,OutputT> | A specialization of  FileBasedSink.DynamicDestinationsforAvroIO. | 
| DynamicFileDestinations | Some helper classes that derive from  FileBasedSink.DynamicDestinations. | 
| FileBasedSink<UserT,DestinationT,OutputT> | Abstract class for file-based output. | 
| FileBasedSink.DynamicDestinations<UserT,DestinationT,OutputT> | A class that allows value-dependent writes in  FileBasedSink. | 
| FileBasedSink.FilenamePolicy | A naming policy for output files. | 
| FileBasedSink.FileResult<DestinationT> | Result of a single bundle write. | 
| FileBasedSink.FileResultCoder<DestinationT> | A coder for  FileBasedSink.FileResultobjects. | 
| FileBasedSink.WriteOperation<DestinationT,OutputT> | Abstract operation that manages the process of writing to  FileBasedSink. | 
| FileBasedSink.Writer<DestinationT,OutputT> | Abstract writer that writes a bundle to a  FileBasedSink. | 
| FileBasedSource<T> | A common base class for all file-based  Sources. | 
| FileBasedSource.FileBasedReader<T> | A  readerthat implements code common to readers ofFileBasedSources. | 
| FileIO | Transforms for working with files. | 
| FileIO.Match | Implementation of  FileIO.match(). | 
| FileIO.MatchAll | Implementation of  FileIO.matchAll(). | 
| FileIO.MatchConfiguration | Describes configuration for matching filepatterns, such as  EmptyMatchTreatmentand
 continuous watching for matching files. | 
| FileIO.ReadableFile | A utility class for accessing a potentially compressed file. | 
| FileIO.ReadMatches | Implementation of  FileIO.readMatches(). | 
| FileSystem<ResourceIdT extends ResourceId> | File system interface in Beam. | 
| FileSystems | Clients facing  FileSystemutility. | 
| GenerateSequence | A  PTransformthat produces longs starting from the given value, and either up to the
 given limit or untilLong.MAX_VALUE/ until the given time elapses. | 
| LocalFileSystemRegistrar | AutoServiceregistrar for theLocalFileSystem. | 
| LocalResources | Helper functions for producing a  ResourceIdthat references a local file or directory. | 
| OffsetBasedSource<T> | A  BoundedSourcethat uses offsets to define starting and ending positions. | 
| OffsetBasedSource.OffsetBasedReader<T> | A  Source.Readerthat implements code common to readers of allOffsetBasedSources. | 
| Read | A  PTransformfor reading from aSource. | 
| Read.Bounded<T> | PTransformthat reads from aBoundedSource. | 
| Read.Builder | Helper class for building  Readtransforms. | 
| Read.Unbounded<T> | PTransformthat reads from aUnboundedSource. | 
| ReadableFileCoder | A  CoderforFileIO.ReadableFile. | 
| ReadAllViaFileBasedSource<T> | Reads each file in the input  PCollectionofFileIO.ReadableFileusing given parameters
 for splitting files into offset ranges and for creating aFileBasedSourcefor a file. | 
| ShardNameTemplate | Standard shard naming templates. | 
| Source<T> | Base class for defining input formats and creating a  Sourcefor reading the input. | 
| Source.Reader<T> | The interface that readers of custom input sources must implement. | 
| TextIO | PTransforms for reading and writing text files. | 
| TextIO.Read | Implementation of  TextIO.read(). | 
| TextIO.ReadAll | Implementation of  TextIO.readAll(). | 
| TextIO.ReadFiles | Implementation of  TextIO.readFiles(). | 
| TextIO.TypedWrite<UserT,DestinationT> | Implementation of  TextIO.write(). | 
| TextIO.Write | This class is used as the default return value of  TextIO.write(). | 
| TFRecordIO | PTransforms for reading and writing TensorFlow TFRecord files. | 
| TFRecordIO.Read | Implementation of  TFRecordIO.read(). | 
| TFRecordIO.Write | Implementation of  TFRecordIO.write(). | 
| UnboundedSource<OutputT,CheckpointMarkT extends UnboundedSource.CheckpointMark> | A  Sourcethat reads an unbounded amount of input and, because of that, supports
 some additional operations such as checkpointing, watermarks, and record ids. | 
| UnboundedSource.UnboundedReader<OutputT> | A  Readerthat reads an unbounded amount of input. | 
| WriteFiles<UserT,DestinationT,OutputT> | A  PTransformthat writes to aFileBasedSink. | 
| WriteFilesResult<DestinationT> | The result of a  WriteFilestransform. | 
| Enum | Description | 
|---|---|
| CompressedSource.CompressionMode | Deprecated Use  Compressioninstead | 
| Compression | Various compression types for reading/writing files. | 
| FileBasedSink.CompressionType | Deprecated use  Compression. | 
| FileBasedSource.Mode | A given  FileBasedSourcerepresents a file resource of one of these types. | 
| TextIO.CompressionType | Deprecated Use  Compression. | 
| TFRecordIO.CompressionType | Deprecated Use  Compression. | 
AvroIO, and
 TextIO.
 The classes in this package provide Read transforms that create PCollections
 from existing storage:
 
 PCollection<TableRow> inputData = pipeline.apply(
     BigQueryIO.readTableRows().from("clouddataflow-readonly:samples.weather_stations"));
 Write transforms that persist PCollections to external storage:
  
 PCollection<Integer> numbers = ...;
 numbers.apply(TextIO.write().to("gs://my_bucket/path/to/numbers"));