Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.crunch Classes and Interfaces - 256 results found.
NameDescriptionTypePackageFramework
AbstractCompositeExtractorBase class for Extractor instances that delegates the parsing of fields to other Extractor instances, primarily used for constructing composite records that implementClassorg.apache.crunch.contrib.textApache Crunch
AbstractSimpleExtractorBase 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 handlingClassorg.apache.crunch.contrib.textApache Crunch
AggregateMethods for performing various types of aggregations over PCollection instances.Classorg.apache.crunch.libApache Crunch
Aggregate .PairValueComparatorConstructor SummaryAggregate.Classorg.apache.crunch.lib.AggregateApache Crunch
Aggregate .TopKCombineFnSee Also:Serialized FormConstructor SummaryAggregate.Classorg.apache.crunch.lib.AggregateApache Crunch
Aggregate .TopKFnSee Also:Serialized FormConstructor SummaryAggregate.Classorg.apache.crunch.lib.AggregateApache Crunch
AggregatorAggregate a sequence of values into a possibly smaller sequence of the same type.Interfaceorg.apache.crunchApache Crunch
AggregatorsA collection of pre-defined Aggregators.Classorg.apache.crunch.fnApache Crunch
Aggregators .SimpleAggregatorBase class for aggregators that do not require any initialization.Classorg.apache.crunch.fn.AggregatorsApache Crunch
AtStatic 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 forClassorg.apache.crunch.ioApache Crunch
AverageBytesByIPSee Also:Serialized FormConstructor SummaryAverageBytesByIP()Classorg.apache.crunch.examplesApache Crunch
AvroDerivedValueDeepCopierA DeepCopier specific to Avro derived types.Classorg.apache.crunch.types.avroApache Crunch
AvroInputFormatAn InputFormat for Avro data files.Classorg.apache.crunch.types.avroApache Crunch
AvroModeAvroMode is an immutable object used for configuring the reading and writing of Avro types.Classorg.apache.crunch.types.avroApache Crunch
AvroMode .ModeTypeInternal enum which represents the various Avro data types.Classorg.apache.crunch.types.avro.AvroModeApache Crunch
AvroOutputFormatAn OutputFormat for Avro data files.Classorg.apache.crunch.types.avroApache Crunch
AvroPathPerKeyOutputFormatA 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.Classorg.apache.crunch.types.avroApache Crunch
AvrosDefines static methods that are analogous to the methods defined in AvroTypeFamily for convenient static importing.Classorg.apache.crunch.types.avroApache Crunch
AvroSerDeClassorg.apache.crunch.impl.spark.serdeApache Crunch
AvroTextOutputFormatNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.types.avroApache Crunch
AvroTypeThe implementation of the PType interface for Avro-based serialization.Classorg.apache.crunch.types.avroApache Crunch
AvroType .AvroRecordTypeClassorg.apache.crunch.types.avro.AvroTypeApache Crunch
AvroTypeFamilyClassorg.apache.crunch.types.avroApache Crunch
AvroUtf8InputFormatAn InputFormat for text files.Classorg.apache.crunch.types.avroApache Crunch
BaseDoCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BaseDoTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BaseGroupedTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BaseInputCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BaseInputTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BaseUnionCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BaseUnionTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
BloomFilterFactoryFactory Class for creating BloomFilters.Classorg.apache.crunch.contrib.bloomfilterApache Crunch
BloomFilterFnThe class is responsible for generating keys that are used in a BloomFilterSee Also:Serialized FormClassorg.apache.crunch.contrib.bloomfilterApache Crunch
BloomFilterJoinStrategyJoin 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-sideClassorg.apache.crunch.lib.joinApache Crunch
ByteArrayClassorg.apache.crunch.impl.sparkApache Crunch
CachingOptionsOptions for controlling how a PCollection is cached for subsequent processing.Classorg.apache.crunchApache Crunch
CachingOptions .BuilderA Builder class to use for setting the CachingOptions for a PCollection.Classorg.apache.crunch.CachingOptionsApache Crunch
CartesianUtilities for Cartesian products of two PTable or PCollectionConstructor SummaryCartesian()Classorg.apache.crunch.libApache Crunch
ChannelsUtilities for splitting Pair instances emitted by DoFn into separate PCollection instances.Classorg.apache.crunch.libApache Crunch
CogroupConstructor SummaryCogroup() PTableClassorg.apache.crunch.libApache Crunch
CollectionDeepCopierPerforms deep copies (based on underlying PType deep copying) of Collections.Classorg.apache.crunch.typesApache Crunch
CombineFnA special DoFn implementation that converts an Iterable of values into a single value.Classorg.apache.crunchApache Crunch
CombineMapsideFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
CompositeMapFnClassorg.apache.crunch.fnApache Crunch
CompositePathIterablecreate(org.Classorg.apache.crunch.ioApache Crunch
CompressHelper functions for compressing output data.Classorg.apache.crunch.ioApache Crunch
ConverterConverts 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 theInterfaceorg.apache.crunch.typesApache Crunch
CounterAccumulatorParamSee Also:Serialized FormConstructor SummaryCounterAccumulatorParam()Classorg.apache.crunch.impl.sparkApache Crunch
CrunchInputsHelper functions for configuring multiple InputFormat instances within a single Crunch MapReduce job.Classorg.apache.crunch.ioApache Crunch
CrunchIterableClassorg.apache.crunch.impl.spark.fnApache Crunch
CrunchOutputsAn analogue of CrunchInputs for handling multiple OutputFormat instances writing to multiple files within a single MapReduce job.Classorg.apache.crunch.ioApache Crunch
CrunchPairTuple2See Also:Serialized FormConstructor SummaryCrunchPairTuple2()Classorg.apache.crunch.impl.spark.fnApache Crunch
CrunchRuntimeExceptionA RuntimeException implementation that includes some additional options for the Crunch execution engine to track reporting status.Classorg.apache.crunchApache Crunch
CrunchTestSupportA temporary workaround for Scala tests to use when working with Rule annotations until it gets fixed in JUnit 4.Classorg.apache.crunch.testApache Crunch
CrunchToolAn extension of the Tool interface that creates a Pipeline instance and provides methods for working with the Pipeline from inside ofClassorg.apache.crunch.utilApache Crunch
DataBaseSourceSource from reading from a database via a JDBC connection.Classorg.apache.crunch.contrib.io.jdbcApache Crunch
DataBaseSource .BuilderConstructor SummaryDataBaseSource.Classorg.apache.crunch.contrib.io.jdbc.DataBaseSourceApache Crunch
DebugLoggingAllows direct manipulation of the Hadoop log4j settings to aid in unit testing.Classorg.apache.crunch.testApache Crunch
DeepCopierPerforms deep copies of values.Interfaceorg.apache.crunch.typesApache Crunch
DefaultJoinStrategyDefault join strategy that simply sends all data through the map, shuffle, and reduce phase.Classorg.apache.crunch.lib.joinApache Crunch
DelegatingReadableData and passing its contents through a DoFn.Classorg.apache.crunch.utilApache Crunch
DistCacheProvides functions for working with Hadoop's distributed cache.Classorg.apache.crunch.utilApache Crunch
DistinctFunctions for computing the distinct elements of a PCollection.Classorg.apache.crunch.libApache Crunch
DistributedPipelineClassorg.apache.crunch.impl.distApache Crunch
DoCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
DoFnBase class for all data processing functions in Crunch.Classorg.apache.crunchApache Crunch
DoFnIteratorAn Iterator that combines a delegate Iterator and a DoFn, generating data by passing the contents of the iterator through the function.Classorg.apache.crunch.utilApache Crunch
DoTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
EmitterInterface for writing outputs from a DoFn.Interfaceorg.apache.crunchApache Crunch
EmptyPCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
EmptyPCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
EmptyPTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
EmptyPTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
ExtractKeyFnWrapper function for converting a MapFn into a key-value pair that is used to convert from a PCollection to a PTable.Classorg.apache.crunch.fnApache Crunch
ExtractorAn interface for extracting a specific data type from a text string that is being processed by a Scanner object.Interfaceorg.apache.crunch.contrib.textApache Crunch
ExtractorsFactory methods for constructing common Extractor types.Classorg.apache.crunch.contrib.textApache Crunch
ExtractorStatsClassorg.apache.crunch.contrib.textApache Crunch
FileNamingSchemeEncapsulates rules for naming output files.Interfaceorg.apache.crunch.ioApache Crunch
FileReaderFactoryInterfaceorg.apache.crunch.ioApache Crunch
FilterFnA DoFn for the common case of filtering the members of a PCollection based on a boolean condition.Classorg.apache.crunchApache Crunch
FilterFnsA collection of pre-defined FilterFn implementations.Classorg.apache.crunch.fnApache Crunch
FlatMapIndexFnClassorg.apache.crunch.impl.spark.fnApache Crunch
FlatMapPairDoFnClassorg.apache.crunch.impl.spark.fnApache Crunch
FormatBundleA combination of an InputFormat or OutputFormat and any extra configuration information that format class needs to run.Classorg.apache.crunch.ioApache Crunch
FromStatic factory methods for creating common Source types.Classorg.apache.crunch.ioApache Crunch
FullOuterJoinFnUsed to perform the last step of an full outer join.Classorg.apache.crunch.lib.joinApache Crunch
GroupingOptionsOptions that can be passed to a groupByKey operation in order to exercise finer control over how the partitioning, grouping, and sorting ofClassorg.apache.crunchApache Crunch
GroupingOptions .BuilderBuilder class for creating GroupingOptions instances.Classorg.apache.crunch.GroupingOptionsApache Crunch
GuavaUtilsConstructor SummaryGuavaUtils() com.Classorg.apache.crunch.impl.sparkApache Crunch
IdentifiableNameClassorg.apache.crunch.contrib.io.jdbcApache Crunch
IdentityFnClassorg.apache.crunch.fnApache Crunch
InnerJoinFnUsed to perform the last step of an inner join.Classorg.apache.crunch.lib.joinApache Crunch
InputCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
InputConverterFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
InputTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
IntByteArraySee Also:Serialized FormFields inherited from class org.Classorg.apache.crunch.impl.sparkApache Crunch
JoinUtilities for joining multiple PTable instances based on a commonConstructor SummaryJoin()Classorg.apache.crunch.libApache Crunch
JoinFnRepresents a DoFn for performing joins.Classorg.apache.crunch.lib.joinApache Crunch
JoinStrategyDefines a strategy for joining two PTables together on a common key.Interfaceorg.apache.crunch.lib.joinApache Crunch
JoinTypeenum JoinTypeextends EnumSpecifies the specific behavior of how a join should be performed in terms of requiring matching keys Classorg.apache.crunch.lib.joinApache Crunch
JoinUtilsUtilities that are useful in joining multiple data sets via a MapReduce.Classorg.apache.crunch.lib.joinApache Crunch
JoinUtils .AvroIndexedRecordPartitionerConstructor SummaryJoinUtils.Classorg.apache.crunch.lib.join.JoinUtilsApache Crunch
JoinUtils .AvroPairGroupingComparatorConstructor SummaryJoinUtils.Classorg.apache.crunch.lib.join.JoinUtilsApache Crunch
JoinUtils .TupleWritableComparatorConstructor SummaryJoinUtils.Classorg.apache.crunch.lib.join.JoinUtilsApache Crunch
JoinUtils .TupleWritablePartitionerConstructor SummaryJoinUtils.Classorg.apache.crunch.lib.join.JoinUtilsApache Crunch
LeftOuterJoinFnUsed to perform the last step of an left outer join.Classorg.apache.crunch.lib.joinApache Crunch
MapDeepCopierClassorg.apache.crunch.typesApache Crunch
MapFnA DoFn for the common case of emitting exactly one value for eachSee Also:Serialized FormClassorg.apache.crunchApache Crunch
MapFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
MapOutputFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
MapredStatic functions for working with legacy Mappers and Reducers that live under the org.Classorg.apache.crunch.libApache Crunch
MapreduceStatic functions for working with legacy Mappers and Reducers that live under the org.Classorg.apache.crunch.libApache Crunch
MapReduceTargetNested Class SummaryNested classes/interfaces inherited from interface org.Interfaceorg.apache.crunch.ioApache Crunch
MapsideJoinStrategyUtility for doing map side joins on a common key between two PTables.Classorg.apache.crunch.lib.joinApache Crunch
MemPipelineClassorg.apache.crunch.impl.memApache Crunch
MRCollectionInterfaceorg.apache.crunch.impl.dist.collectApache Crunch
MRJobA Hadoop MapReduce job managed by Crunch.Interfaceorg.apache.crunch.impl.mrApache Crunch
MRJob .StateA job will be in one of the following states.Classorg.apache.crunch.impl.mr.MRJobApache Crunch
MRPipelinePipeline implementation that is executed within Hadoop MapReduce.Classorg.apache.crunch.impl.mrApache Crunch
MRPipelineExecutionNested Class SummaryNested classes/interfaces inherited from interface org.Interfaceorg.apache.crunch.impl.mrApache Crunch
NoOpDeepCopierA DeepCopier that does nothing, and just returns the input value without copying anything.Classorg.apache.crunch.typesApache Crunch
OneToManyJoinOptimized join for situations where exactly one value is being joined with any other number of values based on a common key.Classorg.apache.crunch.lib.joinApache Crunch
OrcsUtilities to create PTypes for ORC serialization / deserializationConstructor SummaryOrcs()Classorg.apache.crunch.types.orcApache Crunch
OrcUtilsClassorg.apache.crunch.types.orcApache Crunch
OutputConverterFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
OutputHandlerInterfaceorg.apache.crunch.ioApache Crunch
PairA convenience class for two-element Tuples.Classorg.apache.crunchApache Crunch
PairFlatMapDoFnClassorg.apache.crunch.impl.spark.fnApache Crunch
PairMapFnClassorg.apache.crunch.fnApache Crunch
PairMapFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
PairMapIterableFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
ParallelDoOptionsContainer class that includes optional information about a parallelDo operation applied to a PCollection.Classorg.apache.crunchApache Crunch
ParallelDoOptions .BuilderConstructor SummaryParallelDoOptions.Classorg.apache.crunch.ParallelDoOptionsApache Crunch
ParseClassorg.apache.crunch.contrib.textApache Crunch
PartitionedMapOutputFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
PartitionUtilsHelper functions and settings for determining the number of reducers to use in a pipeline job created by the Crunch planner.Classorg.apache.crunch.utilApache Crunch
PathTargetA target whose output goes to a given path on a file system.Interfaceorg.apache.crunch.ioApache Crunch
PCollectionA representation of an immutable, distributed collection of elements that is the fundamental target of computations in Crunch.Interfaceorg.apache.crunchApache Crunch
PCollectionFactoryInterfaceorg.apache.crunch.impl.dist.collectApache Crunch
PCollectionImplClassorg.apache.crunch.impl.dist.collectApache Crunch
PCollectionImpl .VisitorInterfaceorg.apache.crunch.impl.dist.collect.PCollectionImplApache Crunch
PGroupedTableThe Crunch representation of a grouped PTable, which corresponds to the output of the shuffle phase of a MapReduce job.Interfaceorg.apache.crunchApache Crunch
PGroupedTableImplNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
PGroupedTableTypeThe PType instance for PGroupedTable instances.Classorg.apache.crunch.typesApache Crunch
PGroupedTableType .PairIterableMapFnSee Also:Serialized FormConstructor SummaryPGroupedTableType.Classorg.apache.crunch.types.PGroupedTableTypeApache Crunch
PipelineManages the state of a pipeline execution.Interfaceorg.apache.crunchApache Crunch
PipelineCallableA 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 ofClassorg.apache.crunchApache Crunch
PipelineCallable .StatusClassorg.apache.crunch.PipelineCallableApache Crunch
PipelineExecutionA handle to allow clients to control a Crunch pipeline as it runs.Interfaceorg.apache.crunchApache Crunch
PipelineExecution .StatusClassorg.apache.crunch.PipelineExecutionApache Crunch
PipelineResultContainer for the results of a call to run or done on the Pipeline interface that includes details and statistics about the componentClassorg.apache.crunchApache Crunch
PipelineResult .StageResultConstructor SummaryPipelineResult.Classorg.apache.crunch.PipelineResultApache Crunch
PObjectA PObject represents a singleton object value that results from a distributed computation.Interfaceorg.apache.crunchApache Crunch
ProtosUtility functions for working with protocol buffers in Crunch.Classorg.apache.crunch.typesApache Crunch
PTableA sub-interface of PCollection that represents an immutable, distributed multi-map of keys and values.Interfaceorg.apache.crunchApache Crunch
PTableBaseNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.dist.collectApache Crunch
PTablesMethods for performing common operations on PTables.Classorg.apache.crunch.libApache Crunch
PTableTypeAn extension of PType specifically for PTable objects.Interfaceorg.apache.crunch.typesApache Crunch
PTypeA 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.Interfaceorg.apache.crunch.typesApache Crunch
PTypeFamilyAn abstract factory for creating PType instances that have the same serialization/storage backing format.Interfaceorg.apache.crunch.typesApache Crunch
PTypesUtility functions for creating common types of derived PTypes, e.Classorg.apache.crunch.typesApache Crunch
PTypeUtilsUtilities for converting between PTypes from different PTypeFamily implementations.Classorg.apache.crunch.typesApache Crunch
ReadableDataRepresents 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.Interfaceorg.apache.crunchApache Crunch
ReadableSourceAn extension of the Source interface that indicates that a Source instance may be read as a series of records by the clientInterfaceorg.apache.crunch.ioApache Crunch
ReadableSourceTargetAn interface that indicates that a SourceTarget instance can be read into the local client.Interfaceorg.apache.crunch.ioApache Crunch
ReaderWriterFactoryInterface for accessing DatumReader, DatumWriter, and Data classes.Interfaceorg.apache.crunch.types.avroApache Crunch
ReduceGroupingFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
ReduceInputFunctionClassorg.apache.crunch.impl.spark.fnApache Crunch
ReflectDataFactoryA Factory class for constructing Avro reflection-related objects.Classorg.apache.crunch.types.avroApache Crunch
ReverseAvroComparatorClassorg.apache.crunch.lib.sortApache Crunch
ReverseWritableComparatorClassorg.apache.crunch.lib.sortApache Crunch
RightOuterJoinFnUsed to perform the last step of an right outer join.Classorg.apache.crunch.lib.joinApache Crunch
SampleMethods for performing random sampling in a distributed fashion, either by accepting each record in a PCollection with an independent probability in order to sample someClassorg.apache.crunch.libApache Crunch
SDoubleFlatMapFunctionA Crunch-compatible abstract base class for Spark's DoubleFlatMapFunction.Classorg.apache.crunch.fnApache Crunch
SDoubleFunctionA Crunch-compatible abstract base class for Spark's DoubleFunction.Classorg.apache.crunch.fnApache Crunch
SecondarySortUtilities for performing a secondary sort on a PTable> collection.Classorg.apache.crunch.libApache Crunch
SecondarySortExampleSee Also:Serialized FormConstructor SummarySecondarySortExample()Classorg.apache.crunch.examplesApache Crunch
SequentialFileNamingSchemeDefault FileNamingScheme that uses an incrementing sequence number in order to generate unique file names.Classorg.apache.crunch.ioApache Crunch
SerDeInterfaceorg.apache.crunch.impl.spark.serdeApache Crunch
SerializableSupplierAn extension of Guava's Supplier interface that indicates that an instance will also implement Serializable, which makes this object suitable for useInterfaceorg.apache.crunch.utilApache Crunch
SetUtilities for performing set operations (difference, intersection, etc) on PCollection instances.Classorg.apache.crunch.libApache Crunch
SFlatMapFunctionA Crunch-compatible abstract base class for Spark's FlatMapFunction.Classorg.apache.crunch.fnApache Crunch
SFlatMapFunction2A Crunch-compatible abstract base class for Spark's FlatMapFunction2.Classorg.apache.crunch.fnApache Crunch
SFunctionA Crunch-compatible abstract base class for Spark's Function.Classorg.apache.crunch.fnApache Crunch
SFunction2A Crunch-compatible abstract base class for Spark's Function2.Classorg.apache.crunch.fnApache Crunch
SFunctionsUtility methods for wrapping existing Spark Java API Functions for Crunch compatibility.Classorg.apache.crunch.fnApache Crunch
ShardUtilities for controlling how the data in a PCollection is balanced across reducersConstructor SummaryShard()Classorg.apache.crunch.libApache Crunch
ShardedJoinStrategyJoinStrategy that splits the key space up into shards.Classorg.apache.crunch.lib.joinApache Crunch
ShardedJoinStrategy .ShardingStrategyDetermines over how many shards a key will be split in a sharded join.Interfaceorg.apache.crunch.lib.join.ShardedJoinStrategyApache Crunch
SingleUseIterableWrapper around a Reducer's input Iterable.Classorg.apache.crunch.implApache Crunch
SortUtilities for sorting PCollection instances.Classorg.apache.crunch.libApache Crunch
Sort .ColumnOrderTo sort by column 2 ascending then column 1 descending, you would use: sortPairs(coll, by(2, ASCENDING), by(1, DESCENDING))Classorg.apache.crunch.lib.SortApache Crunch
Sort .OrderFor signaling the order in which a sort should be done.Classorg.apache.crunch.lib.SortApache Crunch
SortExampleSimple Crunch tool for running sorting examples from the command line.Classorg.apache.crunch.examplesApache Crunch
SortFnsA set of DoFns that are used by Crunch's Sort library.Classorg.apache.crunch.lib.sortApache Crunch
SortFns .AvroGenericFnPulls a composite set of keys from an Avro GenericRecord instance.Classorg.apache.crunch.lib.sort.SortFnsApache Crunch
SortFns .KeyExtractionUtility class for encapsulating key extraction logic and serialization information aboutConstructor SummarySortFns.Classorg.apache.crunch.lib.sort.SortFnsApache Crunch
SortFns .SingleKeyFnExtracts a single indexed key from a Tuple instance.Classorg.apache.crunch.lib.sort.SortFnsApache Crunch
SortFns .TupleKeyFnExtracts a composite key from a Tuple instance.Classorg.apache.crunch.lib.sort.SortFnsApache Crunch
SourceInterfaceorg.apache.crunchApache Crunch
SourceTargetInterfaceorg.apache.crunchApache Crunch
SourceTargetHelperFunctions for configuring the inputs/outputs of MapReduce jobs.Classorg.apache.crunch.ioApache Crunch
SPairFlatMapFunctionA Crunch-compatible abstract base class for Spark's PairFlatMapFunction.Classorg.apache.crunch.fnApache Crunch
SPairFunctionA Crunch-compatible abstract base class for Spark's PairFunction.Classorg.apache.crunch.fnApache Crunch
SparkCollectFactoryConstructor SummarySparkCollectFactory() BaseDoCollectionClassorg.apache.crunch.impl.spark.collectApache Crunch
SparkCollectionInterfaceorg.apache.crunch.impl.sparkApache Crunch
SparkComparatorClassorg.apache.crunch.impl.sparkApache Crunch
SparkPartitionerClassorg.apache.crunch.impl.sparkApache Crunch
SparkPipelineConstructor SummarySparkPipeline(org.Classorg.apache.crunch.impl.sparkApache Crunch
SparkRuntimeNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.crunch.impl.sparkApache Crunch
SparkRuntimeContextClassorg.apache.crunch.impl.sparkApache Crunch
SwapFnSwap the elements of a Pair type.Classorg.apache.crunch.fnApache Crunch
TableSourceThe interface Source implementations that return a PTable.Interfaceorg.apache.crunchApache Crunch
TableSourceTargetInterfaceorg.apache.crunchApache Crunch
TargetA Target represents the output destination of a Crunch PCollection in the context of a Crunch job.Interfaceorg.apache.crunchApache Crunch
Target .WriteModeAn enum to represent different options the client may specify for handling the case where the output path, table, etc.Classorg.apache.crunch.TargetApache Crunch
TemporaryPathCreates a temporary directory for a test case and destroys it afterwards.Classorg.apache.crunch.testApache Crunch
TestCountersA utility class used during unit testing to update and read counters.Classorg.apache.crunch.testApache Crunch
ToStatic factory methods for creating common Target types.Classorg.apache.crunch.ioApache Crunch
ToByteArrayFunctionSee Also:Serialized FormConstructor SummaryToByteArrayFunction()Classorg.apache.crunch.impl.spark.collectApache Crunch
TokenizerManages a Scanner instance and provides support for returning only a subset of the fields returned by the underlying Scanner.Classorg.apache.crunch.contrib.textApache Crunch
TokenizerFactoryFactory 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.Classorg.apache.crunch.contrib.textApache Crunch
TokenizerFactory .BuilderA class for constructing new TokenizerFactory instances using the Builder pattern.Classorg.apache.crunch.contrib.text.TokenizerFactoryApache Crunch
TotalBytesByIPSee Also:Serialized FormConstructor SummaryTotalBytesByIP()Classorg.apache.crunch.examplesApache Crunch
TotalOrderPartitionerClassorg.apache.crunch.lib.sortApache Crunch
TotalWordCountSee Also:Serialized FormConstructor SummaryTotalWordCount()Classorg.apache.crunch.examplesApache Crunch
TupleA fixed-size collection of Objects, used in Crunch for representing joins between PCollections.Interfaceorg.apache.crunchApache Crunch
Tuple3A convenience class for three-element Tuples.Classorg.apache.crunchApache Crunch
Tuple3 .CollectNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.Tuple3Apache Crunch
Tuple4A convenience class for four-element Tuples.Classorg.apache.crunchApache Crunch
Tuple4 .CollectNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.Tuple4Apache Crunch
TupleDeepCopierPerforms deep copies (based on underlying PType deep copying) of Tuple-based objects.Classorg.apache.crunch.typesApache Crunch
TupleFactoryClassorg.apache.crunch.typesApache Crunch
TupleNA Tuple instance for an arbitrary number of values.Classorg.apache.crunchApache Crunch
TupleObjectInspectorClassorg.apache.crunch.types.orcApache Crunch
TuplesUtilities for working with subclasses of the Tuple interface.Classorg.apache.crunch.utilApache Crunch
Tuples .PairIterableConstructor SummaryTuples.Classorg.apache.crunch.util.TuplesApache Crunch
Tuples .QuadIterableConstructor SummaryTuples.Classorg.apache.crunch.util.TuplesApache Crunch
Tuples .TripIterableConstructor SummaryTuples.Classorg.apache.crunch.util.TuplesApache Crunch
Tuples .TupleNIterableConstructor SummaryTuples.Classorg.apache.crunch.util.TuplesApache Crunch
TupleWritableA serialization format for Tuple.Classorg.apache.crunch.types.writableApache Crunch
TupleWritable .ComparatorClassorg.apache.crunch.types.writable.TupleWritableApache Crunch
TupleWritableComparatorClassorg.apache.crunch.lib.sortApache Crunch
UnionAllows 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.Classorg.apache.crunchApache Crunch
UnionCollectionNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
UnionDeepCopierSee Also:Serialized FormConstructor SummaryUnionDeepCopier(PType.Classorg.apache.crunch.typesApache Crunch
UnionReadableDataClassorg.apache.crunch.utilApache Crunch
UnionTableNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.crunch.impl.spark.collectApache Crunch
UnionWritableClassorg.apache.crunch.types.writableApache Crunch
WordAggregationHBaseYou need to have a HBase instance running.Classorg.apache.crunch.examplesApache Crunch
WordCountSee Also:Serialized FormConstructor SummaryWordCount()Classorg.apache.crunch.examplesApache Crunch
WritableDeepCopierPerforms deep copies of Writable values.Classorg.apache.crunch.types.writableApache Crunch
WritablesDefines static methods that are analogous to the methods defined in WritableTypeFamily for convenient static importing.Classorg.apache.crunch.types.writableApache Crunch
WritableSerDeSee Also:Serialized FormConstructor SummaryWritableSerDe(ClassClassorg.apache.crunch.impl.spark.serdeApache Crunch
WritableTypeClassorg.apache.crunch.types.writableApache Crunch
WritableTypeFamilyThe Writable-based implementation of the PTypeFamily interface.Classorg.apache.crunch.types.writableApache Crunch