| Name | Description | Type | Package | Framework |
| AbstractCompositeExtractor | Base class for Extractor instances that delegates the parsing of fields to other Extractor instances, primarily used for constructing composite records that implement | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| AbstractSimpleExtractor | Base class for the common case Extractor instances that construct a single object from a block of text stored in a String, with support for error handling | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| Aggregate | Methods for performing various types of aggregations over PCollection instances. | Class | org.apache.crunch.lib | Apache Crunch |
|
| Aggregator | Aggregate a sequence of values into a possibly smaller sequence of the same type. | Interface | org.apache.crunch | Apache Crunch |
|
| Aggregators | A collection of pre-defined Aggregators. | Class | org.apache.crunch.fn | Apache Crunch |
|
| At | Static factory methods for creating common SourceTarget types, which may be treated as both a Source The At methods is analogous to the From and To factory methods, but is used for | Class | org.apache.crunch.io | Apache Crunch |
|
| AverageBytesByIP | See Also:Serialized FormConstructor SummaryAverageBytesByIP() | Class | org.apache.crunch.examples | Apache Crunch |
|
| AvroDerivedValueDeepCopier | A DeepCopier specific to Avro derived types. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroInputFormat | An InputFormat for Avro data files. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroMode | AvroMode is an immutable object used for configuring the reading and writing of Avro types. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroOutputFormat | An OutputFormat for Avro data files. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroPathPerKeyOutputFormat | A FileOutputFormat that takes in a Utf8 and an Avro record and writes the Avro records to a sub-directory of the output path whose name is equal to the string-form of the Utf8. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| Avros | Defines static methods that are analogous to the methods defined in AvroTypeFamily for convenient static importing. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroSerDe | | Class | org.apache.crunch.impl.spark.serde | Apache Crunch |
|
| AvroTextOutputFormat | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroType | The implementation of the PType interface for Avro-based serialization. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroTypeFamily | | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| AvroUtf8InputFormat | An InputFormat for text files. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| BaseDoCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BaseDoTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BaseGroupedTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BaseInputCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BaseInputTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BaseUnionCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BaseUnionTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| BloomFilterFactory | Factory Class for creating BloomFilters. | Class | org.apache.crunch.contrib.bloomfilter | Apache Crunch |
|
| BloomFilterFn | The class is responsible for generating keys that are used in a BloomFilterSee Also:Serialized Form | Class | org.apache.crunch.contrib.bloomfilter | Apache Crunch |
|
| BloomFilterJoinStrategy | Join strategy that uses a Bloom filter that is trained on the keys of the left-side table to filter the key/value pairs of the right-side | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| ByteArray | | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| CachingOptions | Options for controlling how a PCollection is cached for subsequent processing. | Class | org.apache.crunch | Apache Crunch |
|
| Cartesian | Utilities for Cartesian products of two PTable or PCollectionConstructor SummaryCartesian() | Class | org.apache.crunch.lib | Apache Crunch |
|
| Channels | Utilities for splitting Pair instances emitted by DoFn into separate PCollection instances. | Class | org.apache.crunch.lib | Apache Crunch |
|
| Cogroup | Constructor SummaryCogroup() PTable | Class | org.apache.crunch.lib | Apache Crunch |
|
| CollectionDeepCopier | Performs deep copies (based on underlying PType deep copying) of Collections. | Class | org.apache.crunch.types | Apache Crunch |
|
| CombineFn | A special DoFn implementation that converts an Iterable of values into a single value. | Class | org.apache.crunch | Apache Crunch |
|
| CombineMapsideFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| CompositeMapFn | | Class | org.apache.crunch.fn | Apache Crunch |
|
| CompositePathIterable | create(org. | Class | org.apache.crunch.io | Apache Crunch |
|
| Compress | Helper functions for compressing output data. | Class | org.apache.crunch.io | Apache Crunch |
|
| Converter | Converts the input key/value from a MapReduce task into the input to a DoFn, or takes the output of a DoFn and write it to the | Interface | org.apache.crunch.types | Apache Crunch |
|
| CounterAccumulatorParam | See Also:Serialized FormConstructor SummaryCounterAccumulatorParam() | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| CrunchInputs | Helper functions for configuring multiple InputFormat instances within a single Crunch MapReduce job. | Class | org.apache.crunch.io | Apache Crunch |
|
| CrunchIterable | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| CrunchOutputs | An analogue of CrunchInputs for handling multiple OutputFormat instances writing to multiple files within a single MapReduce job. | Class | org.apache.crunch.io | Apache Crunch |
|
| CrunchPairTuple2 | See Also:Serialized FormConstructor SummaryCrunchPairTuple2() | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| CrunchRuntimeException | A RuntimeException implementation that includes some additional options for the Crunch execution engine to track reporting status. | Class | org.apache.crunch | Apache Crunch |
|
| CrunchTestSupport | A temporary workaround for Scala tests to use when working with Rule annotations until it gets fixed in JUnit 4. | Class | org.apache.crunch.test | Apache Crunch |
|
| CrunchTool | An extension of the Tool interface that creates a Pipeline instance and provides methods for working with the Pipeline from inside of | Class | org.apache.crunch.util | Apache Crunch |
|
| DataBaseSource | Source from reading from a database via a JDBC connection. | Class | org.apache.crunch.contrib.io.jdbc | Apache Crunch |
|
| DebugLogging | Allows direct manipulation of the Hadoop log4j settings to aid in unit testing. | Class | org.apache.crunch.test | Apache Crunch |
|
| DeepCopier | Performs deep copies of values. | Interface | org.apache.crunch.types | Apache Crunch |
|
| DefaultJoinStrategy | Default join strategy that simply sends all data through the map, shuffle, and reduce phase. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| DelegatingReadableData | and passing its contents through a DoFn. | Class | org.apache.crunch.util | Apache Crunch |
|
| DistCache | Provides functions for working with Hadoop's distributed cache. | Class | org.apache.crunch.util | Apache Crunch |
|
| Distinct | Functions for computing the distinct elements of a PCollection. | Class | org.apache.crunch.lib | Apache Crunch |
|
| DistributedPipeline | | Class | org.apache.crunch.impl.dist | Apache Crunch |
|
| DoCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| DoFn | Base class for all data processing functions in Crunch. | Class | org.apache.crunch | Apache Crunch |
|
| DoFnIterator | An Iterator that combines a delegate Iterator and a DoFn, generating data by passing the contents of the iterator through the function. | Class | org.apache.crunch.util | Apache Crunch |
|
| DoTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| Emitter | Interface for writing outputs from a DoFn. | Interface | org.apache.crunch | Apache Crunch |
|
| EmptyPCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| EmptyPCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| EmptyPTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| EmptyPTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| ExtractKeyFn | Wrapper function for converting a MapFn into a key-value pair that is used to convert from a PCollection to a PTable. | Class | org.apache.crunch.fn | Apache Crunch |
|
| Extractor | An interface for extracting a specific data type from a text string that is being processed by a Scanner object. | Interface | org.apache.crunch.contrib.text | Apache Crunch |
|
| Extractors | Factory methods for constructing common Extractor types. | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| ExtractorStats | | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| FileNamingScheme | Encapsulates rules for naming output files. | Interface | org.apache.crunch.io | Apache Crunch |
|
| FileReaderFactory | | Interface | org.apache.crunch.io | Apache Crunch |
|
| FilterFn | A DoFn for the common case of filtering the members of a PCollection based on a boolean condition. | Class | org.apache.crunch | Apache Crunch |
|
| FilterFns | A collection of pre-defined FilterFn implementations. | Class | org.apache.crunch.fn | Apache Crunch |
|
| FlatMapIndexFn | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| FlatMapPairDoFn | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| FormatBundle | A combination of an InputFormat or OutputFormat and any extra configuration information that format class needs to run. | Class | org.apache.crunch.io | Apache Crunch |
|
| From | Static factory methods for creating common Source types. | Class | org.apache.crunch.io | Apache Crunch |
|
| FullOuterJoinFn | Used to perform the last step of an full outer join. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| GroupingOptions | Options that can be passed to a groupByKey operation in order to exercise finer control over how the partitioning, grouping, and sorting of | Class | org.apache.crunch | Apache Crunch |
|
| GuavaUtils | Constructor SummaryGuavaUtils() com. | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| IdentifiableName | | Class | org.apache.crunch.contrib.io.jdbc | Apache Crunch |
|
| IdentityFn | | Class | org.apache.crunch.fn | Apache Crunch |
|
| InnerJoinFn | Used to perform the last step of an inner join. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| InputCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| InputConverterFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| InputTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| IntByteArray | See Also:Serialized FormFields inherited from class org. | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| Join | Utilities for joining multiple PTable instances based on a commonConstructor SummaryJoin() | Class | org.apache.crunch.lib | Apache Crunch |
|
| JoinFn | Represents a DoFn for performing joins. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| JoinStrategy | Defines a strategy for joining two PTables together on a common key. | Interface | org.apache.crunch.lib.join | Apache Crunch |
|
| JoinType | enum JoinTypeextends EnumSpecifies the specific behavior of how a join should be performed in terms of requiring matching keys | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| JoinUtils | Utilities that are useful in joining multiple data sets via a MapReduce. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| LeftOuterJoinFn | Used to perform the last step of an left outer join. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| MapDeepCopier | | Class | org.apache.crunch.types | Apache Crunch |
|
| MapFn | A DoFn for the common case of emitting exactly one value for eachSee Also:Serialized Form | Class | org.apache.crunch | Apache Crunch |
|
| MapFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| MapOutputFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| Mapred | Static functions for working with legacy Mappers and Reducers that live under the org. | Class | org.apache.crunch.lib | Apache Crunch |
|
| Mapreduce | Static functions for working with legacy Mappers and Reducers that live under the org. | Class | org.apache.crunch.lib | Apache Crunch |
|
| MapReduceTarget | Nested Class SummaryNested classes/interfaces inherited from interface org. | Interface | org.apache.crunch.io | Apache Crunch |
|
| MapsideJoinStrategy | Utility for doing map side joins on a common key between two PTables. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| MemPipeline | | Class | org.apache.crunch.impl.mem | Apache Crunch |
|
| MRCollection | | Interface | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| MRJob | A Hadoop MapReduce job managed by Crunch. | Interface | org.apache.crunch.impl.mr | Apache Crunch |
|
| MRPipeline | Pipeline implementation that is executed within Hadoop MapReduce. | Class | org.apache.crunch.impl.mr | Apache Crunch |
|
| MRPipelineExecution | Nested Class SummaryNested classes/interfaces inherited from interface org. | Interface | org.apache.crunch.impl.mr | Apache Crunch |
|
| NoOpDeepCopier | A DeepCopier that does nothing, and just returns the input value without copying anything. | Class | org.apache.crunch.types | Apache Crunch |
|
| OneToManyJoin | Optimized join for situations where exactly one value is being joined with any other number of values based on a common key. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| Orcs | Utilities to create PTypes for ORC serialization / deserializationConstructor SummaryOrcs() | Class | org.apache.crunch.types.orc | Apache Crunch |
|
| OrcUtils | | Class | org.apache.crunch.types.orc | Apache Crunch |
|
| OutputConverterFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| OutputHandler | | Interface | org.apache.crunch.io | Apache Crunch |
|
| Pair | A convenience class for two-element Tuples. | Class | org.apache.crunch | Apache Crunch |
|
| PairFlatMapDoFn | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| PairMapFn | | Class | org.apache.crunch.fn | Apache Crunch |
|
| PairMapFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| PairMapIterableFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| ParallelDoOptions | Container class that includes optional information about a parallelDo operation applied to a PCollection. | Class | org.apache.crunch | Apache Crunch |
|
| Parse | | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| PartitionedMapOutputFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| PartitionUtils | Helper functions and settings for determining the number of reducers to use in a pipeline job created by the Crunch planner. | Class | org.apache.crunch.util | Apache Crunch |
|
| PathTarget | A target whose output goes to a given path on a file system. | Interface | org.apache.crunch.io | Apache Crunch |
|
| PCollection | A representation of an immutable, distributed collection of elements that is the fundamental target of computations in Crunch. | Interface | org.apache.crunch | Apache Crunch |
|
| PCollectionFactory | | Interface | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| PCollectionImpl | | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| PGroupedTable | The Crunch representation of a grouped PTable, which corresponds to the output of the shuffle phase of a MapReduce job. | Interface | org.apache.crunch | Apache Crunch |
|
| PGroupedTableImpl | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| PGroupedTableType | The PType instance for PGroupedTable instances. | Class | org.apache.crunch.types | Apache Crunch |
|
| Pipeline | Manages the state of a pipeline execution. | Interface | org.apache.crunch | Apache Crunch |
|
| PipelineCallable | A specialization of Callable that executes some sequential logic on the client machine as part of an overall Crunch pipeline in order to generate zero or more outputs, some of | Class | org.apache.crunch | Apache Crunch |
|
| PipelineExecution | A handle to allow clients to control a Crunch pipeline as it runs. | Interface | org.apache.crunch | Apache Crunch |
|
| PipelineResult | Container for the results of a call to run or done on the Pipeline interface that includes details and statistics about the component | Class | org.apache.crunch | Apache Crunch |
|
| PObject | A PObject represents a singleton object value that results from a distributed computation. | Interface | org.apache.crunch | Apache Crunch |
|
| Protos | Utility functions for working with protocol buffers in Crunch. | Class | org.apache.crunch.types | Apache Crunch |
|
| PTable | A sub-interface of PCollection that represents an immutable, distributed multi-map of keys and values. | Interface | org.apache.crunch | Apache Crunch |
|
| PTableBase | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.dist.collect | Apache Crunch |
|
| PTables | Methods for performing common operations on PTables. | Class | org.apache.crunch.lib | Apache Crunch |
|
| PTableType | An extension of PType specifically for PTable objects. | Interface | org.apache.crunch.types | Apache Crunch |
|
| PType | A PType defines a mapping between a data type that is used in a Crunch pipeline and a serialization and storage format that is used to read/write data from/to HDFS. | Interface | org.apache.crunch.types | Apache Crunch |
|
| PTypeFamily | An abstract factory for creating PType instances that have the same serialization/storage backing format. | Interface | org.apache.crunch.types | Apache Crunch |
|
| PTypes | Utility functions for creating common types of derived PTypes, e. | Class | org.apache.crunch.types | Apache Crunch |
|
| PTypeUtils | Utilities for converting between PTypes from different PTypeFamily implementations. | Class | org.apache.crunch.types | Apache Crunch |
|
| ReadableData | Represents the contents of a data source that can be read on the cluster from within one of the tasks running as part of a Crunch pipeline. | Interface | org.apache.crunch | Apache Crunch |
|
| ReadableSource | An extension of the Source interface that indicates that a Source instance may be read as a series of records by the client | Interface | org.apache.crunch.io | Apache Crunch |
|
| ReadableSourceTarget | An interface that indicates that a SourceTarget instance can be read into the local client. | Interface | org.apache.crunch.io | Apache Crunch |
|
| ReaderWriterFactory | Interface for accessing DatumReader, DatumWriter, and Data classes. | Interface | org.apache.crunch.types.avro | Apache Crunch |
|
| ReduceGroupingFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| ReduceInputFunction | | Class | org.apache.crunch.impl.spark.fn | Apache Crunch |
|
| ReflectDataFactory | A Factory class for constructing Avro reflection-related objects. | Class | org.apache.crunch.types.avro | Apache Crunch |
|
| ReverseAvroComparator | | Class | org.apache.crunch.lib.sort | Apache Crunch |
|
| ReverseWritableComparator | | Class | org.apache.crunch.lib.sort | Apache Crunch |
|
| RightOuterJoinFn | Used to perform the last step of an right outer join. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| Sample | Methods for performing random sampling in a distributed fashion, either by accepting each record in a PCollection with an independent probability in order to sample some | Class | org.apache.crunch.lib | Apache Crunch |
|
| SDoubleFlatMapFunction | A Crunch-compatible abstract base class for Spark's DoubleFlatMapFunction. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SDoubleFunction | A Crunch-compatible abstract base class for Spark's DoubleFunction. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SecondarySort | Utilities for performing a secondary sort on a PTable> collection. | Class | org.apache.crunch.lib | Apache Crunch |
|
| SecondarySortExample | See Also:Serialized FormConstructor SummarySecondarySortExample() | Class | org.apache.crunch.examples | Apache Crunch |
|
| SequentialFileNamingScheme | Default FileNamingScheme that uses an incrementing sequence number in order to generate unique file names. | Class | org.apache.crunch.io | Apache Crunch |
|
| SerDe | | Interface | org.apache.crunch.impl.spark.serde | Apache Crunch |
|
| SerializableSupplier | An extension of Guava's Supplier interface that indicates that an instance will also implement Serializable, which makes this object suitable for use | Interface | org.apache.crunch.util | Apache Crunch |
|
| Set | Utilities for performing set operations (difference, intersection, etc) on PCollection instances. | Class | org.apache.crunch.lib | Apache Crunch |
|
| SFlatMapFunction | A Crunch-compatible abstract base class for Spark's FlatMapFunction. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SFlatMapFunction2 | A Crunch-compatible abstract base class for Spark's FlatMapFunction2. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SFunction | A Crunch-compatible abstract base class for Spark's Function. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SFunction2 | A Crunch-compatible abstract base class for Spark's Function2. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SFunctions | Utility methods for wrapping existing Spark Java API Functions for Crunch compatibility. | Class | org.apache.crunch.fn | Apache Crunch |
|
| Shard | Utilities for controlling how the data in a PCollection is balanced across reducersConstructor SummaryShard() | Class | org.apache.crunch.lib | Apache Crunch |
|
| ShardedJoinStrategy | JoinStrategy that splits the key space up into shards. | Class | org.apache.crunch.lib.join | Apache Crunch |
|
| SingleUseIterable | Wrapper around a Reducer's input Iterable. | Class | org.apache.crunch.impl | Apache Crunch |
|
| Sort | Utilities for sorting PCollection instances. | Class | org.apache.crunch.lib | Apache Crunch |
|
| SortExample | Simple Crunch tool for running sorting examples from the command line. | Class | org.apache.crunch.examples | Apache Crunch |
|
| SortFns | A set of DoFns that are used by Crunch's Sort library. | Class | org.apache.crunch.lib.sort | Apache Crunch |
|
| Source | | Interface | org.apache.crunch | Apache Crunch |
|
| SourceTarget | | Interface | org.apache.crunch | Apache Crunch |
|
| SourceTargetHelper | Functions for configuring the inputs/outputs of MapReduce jobs. | Class | org.apache.crunch.io | Apache Crunch |
|
| SPairFlatMapFunction | A Crunch-compatible abstract base class for Spark's PairFlatMapFunction. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SPairFunction | A Crunch-compatible abstract base class for Spark's PairFunction. | Class | org.apache.crunch.fn | Apache Crunch |
|
| SparkCollectFactory | Constructor SummarySparkCollectFactory() BaseDoCollection | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| SparkCollection | | Interface | org.apache.crunch.impl.spark | Apache Crunch |
|
| SparkComparator | | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| SparkCounter | | Class | org.apache.hadoop.mapred | Apache Crunch |
|
| SparkPartitioner | | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| SparkPipeline | Constructor SummarySparkPipeline(org. | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| SparkRuntime | Nested Class SummaryNested classes/interfaces inherited from interface org. | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| SparkRuntimeContext | | Class | org.apache.crunch.impl.spark | Apache Crunch |
|
| SwapFn | Swap the elements of a Pair type. | Class | org.apache.crunch.fn | Apache Crunch |
|
| TableSource | The interface Source implementations that return a PTable. | Interface | org.apache.crunch | Apache Crunch |
|
| TableSourceTarget | | Interface | org.apache.crunch | Apache Crunch |
|
| Target | A Target represents the output destination of a Crunch PCollection in the context of a Crunch job. | Interface | org.apache.crunch | Apache Crunch |
|
| TemporaryPath | Creates a temporary directory for a test case and destroys it afterwards. | Class | org.apache.crunch.test | Apache Crunch |
|
| TestCounters | A utility class used during unit testing to update and read counters. | Class | org.apache.crunch.test | Apache Crunch |
|
| To | Static factory methods for creating common Target types. | Class | org.apache.crunch.io | Apache Crunch |
|
| ToByteArrayFunction | See Also:Serialized FormConstructor SummaryToByteArrayFunction() | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| Tokenizer | Manages a Scanner instance and provides support for returning only a subset of the fields returned by the underlying Scanner. | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| TokenizerFactory | Factory class that constructs Tokenizer instances for input strings that use a fixed set of delimiters, skip patterns, locales, and sets of indices to keep or drop. | Class | org.apache.crunch.contrib.text | Apache Crunch |
|
| TotalBytesByIP | See Also:Serialized FormConstructor SummaryTotalBytesByIP() | Class | org.apache.crunch.examples | Apache Crunch |
|
| TotalOrderPartitioner | | Class | org.apache.crunch.lib.sort | Apache Crunch |
|
| TotalWordCount | See Also:Serialized FormConstructor SummaryTotalWordCount() | Class | org.apache.crunch.examples | Apache Crunch |
|
| Tuple | A fixed-size collection of Objects, used in Crunch for representing joins between PCollections. | Interface | org.apache.crunch | Apache Crunch |
|
| Tuple3 | A convenience class for three-element Tuples. | Class | org.apache.crunch | Apache Crunch |
|
| Tuple4 | A convenience class for four-element Tuples. | Class | org.apache.crunch | Apache Crunch |
|
| TupleDeepCopier | Performs deep copies (based on underlying PType deep copying) of Tuple-based objects. | Class | org.apache.crunch.types | Apache Crunch |
|
| TupleFactory | | Class | org.apache.crunch.types | Apache Crunch |
|
| TupleN | A Tuple instance for an arbitrary number of values. | Class | org.apache.crunch | Apache Crunch |
|
| TupleObjectInspector | | Class | org.apache.crunch.types.orc | Apache Crunch |
|
| Tuples | Utilities for working with subclasses of the Tuple interface. | Class | org.apache.crunch.util | Apache Crunch |
|
| TupleWritable | A serialization format for Tuple. | Class | org.apache.crunch.types.writable | Apache Crunch |
|
| TupleWritableComparator | | Class | org.apache.crunch.lib.sort | Apache Crunch |
|
| Union | Allows us to represent the combination of multiple data sources that may contain different types of data as a single type with an index to indicate which of the original sources the current record was from. | Class | org.apache.crunch | Apache Crunch |
|
| UnionCollection | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| UnionDeepCopier | See Also:Serialized FormConstructor SummaryUnionDeepCopier(PType. | Class | org.apache.crunch.types | Apache Crunch |
|
| UnionReadableData | | Class | org.apache.crunch.util | Apache Crunch |
|
| UnionTable | Nested Class SummaryNested classes/interfaces inherited from class org. | Class | org.apache.crunch.impl.spark.collect | Apache Crunch |
|
| UnionWritable | | Class | org.apache.crunch.types.writable | Apache Crunch |
|
| WordAggregationHBase | You need to have a HBase instance running. | Class | org.apache.crunch.examples | Apache Crunch |
|
| WordCount | See Also:Serialized FormConstructor SummaryWordCount() | Class | org.apache.crunch.examples | Apache Crunch |
|
| WritableDeepCopier | Performs deep copies of Writable values. | Class | org.apache.crunch.types.writable | Apache Crunch |
|
| Writables | Defines static methods that are analogous to the methods defined in WritableTypeFamily for convenient static importing. | Class | org.apache.crunch.types.writable | Apache Crunch |
|
| WritableSerDe | See Also:Serialized FormConstructor SummaryWritableSerDe(Class extends org. | Class | org.apache.crunch.impl.spark.serde | Apache Crunch |
|
| WritableType | | Class | org.apache.crunch.types.writable | Apache Crunch |
|
| WritableTypeFamily | The Writable-based implementation of the PTypeFamily interface. | Class | org.apache.crunch.types.writable | Apache Crunch |