This project has retired. For details please refer to its Attic page.
Index (Apache Crunch 0.3.0-incubating API)
A B C D E F G H I J K L M N O P Q R S T U V W

A

accept(T) - Method in class org.apache.crunch.FilterFn
If true, emit the given record.
accept(S) - Method in class org.apache.crunch.FilterFn.AndFn
 
accept(S) - Method in class org.apache.crunch.FilterFn.NotFn
 
accept(S) - Method in class org.apache.crunch.FilterFn.OrFn
 
accept(PCollectionImpl.Visitor) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
accept(OutputHandler, PType<?>) - Method in class org.apache.crunch.io.avro.AvroFileTarget
 
accept(OutputHandler, PType<?>) - Method in class org.apache.crunch.io.hbase.HBaseTarget
 
accept(OutputHandler, PType<?>) - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
accept(OutputHandler, PType<?>) - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
accept(OutputHandler, PType<?>) - Method in interface org.apache.crunch.Target
 
accept(Class<?>) - Method in class org.apache.crunch.types.avro.SafeAvroSerialization
 
addChild(DoNode) - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
addDependency(JobPrototype) - Method in class org.apache.crunch.impl.mr.plan.JobPrototype
 
addDependingJob(CrunchControlledJob) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Add a job to this jobs' dependency list.
addInputPath(Job, Path, InputBundle, int) - Static method in class org.apache.crunch.impl.mr.run.CrunchInputs
 
addJarDirToDistributedCache(Configuration, File) - Static method in class org.apache.crunch.util.DistCache
Adds all jars under the specified directory to the distributed cache of jobs using the provided configuration.
addJarDirToDistributedCache(Configuration, String) - Static method in class org.apache.crunch.util.DistCache
Adds all jars under the directory at the specified path to the distributed cache of jobs using the provided configuration.
addJarToDistributedCache(Configuration, File) - Static method in class org.apache.crunch.util.DistCache
Adds the specified jar to the distributed cache of jobs using the provided configuration.
addJarToDistributedCache(Configuration, String) - Static method in class org.apache.crunch.util.DistCache
Adds the jar at the specified path to the distributed cache of jobs using the provided configuration.
addJob(CrunchControlledJob) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
Add a new job.
addJob(CrunchJob) - Method in class org.apache.crunch.impl.mr.exec.MRExecutor
 
addJobCollection(Collection<CrunchControlledJob>) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
Add a collection of jobs
addNamedOutput(Job, String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Static method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Adds a named output for the job.
addReducePaths(HashMultimap<Target, NodePath>) - Method in class org.apache.crunch.impl.mr.plan.JobPrototype
 
Aggregate - Class in org.apache.crunch.lib
Methods for performing various types of aggregations over PCollection instances.
Aggregate() - Constructor for class org.apache.crunch.lib.Aggregate
 
Aggregate.PairValueComparator<K,V> - Class in org.apache.crunch.lib
 
Aggregate.PairValueComparator(boolean) - Constructor for class org.apache.crunch.lib.Aggregate.PairValueComparator
 
Aggregate.TopKCombineFn<K,V> - Class in org.apache.crunch.lib
 
Aggregate.TopKCombineFn(int, boolean) - Constructor for class org.apache.crunch.lib.Aggregate.TopKCombineFn
 
Aggregate.TopKFn<K,V> - Class in org.apache.crunch.lib
 
Aggregate.TopKFn(int, boolean) - Constructor for class org.apache.crunch.lib.Aggregate.TopKFn
 
aggregator(CombineFn.Aggregator<V>) - Static method in class org.apache.crunch.CombineFn
 
AGGREGATOR_BUCKETS - Static variable in class org.apache.crunch.impl.mr.run.RuntimeParameters
 
aggregatorFactory(CombineFn.AggregatorFactory<V>) - Static method in class org.apache.crunch.CombineFn
 
allFinished() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
and(FilterFn<S>...) - Static method in class org.apache.crunch.FilterFn
 
apply(Statement, Description) - Method in class org.apache.crunch.test.TemporaryPath
 
as(PType<T>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
as(PType<T>) - Method in interface org.apache.crunch.types.PTypeFamily
Returns the equivalent of the given ptype for this family, if it exists.
as(PType<T>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
asSourceTarget(PType<T>) - Method in class org.apache.crunch.io.avro.AvroFileTarget
 
asSourceTarget(PType<T>) - Method in class org.apache.crunch.io.hbase.HBaseTarget
 
asSourceTarget(PType<T>) - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
asSourceTarget(PType<S>) - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
asSourceTarget(PType<T>) - Method in class org.apache.crunch.io.seq.SeqFileTarget
 
asSourceTarget(PType<T>) - Method in class org.apache.crunch.io.text.TextFileTarget
 
asSourceTarget(PType<T>) - Method in interface org.apache.crunch.Target
 
At - Class in org.apache.crunch.io
Static factory methods for creating various SourceTarget types.
At() - Constructor for class org.apache.crunch.io.At
 
AtHBase - Class in org.apache.crunch.io.hbase
Static factory methods for creating HBase SourceTarget types.
AtHBase() - Constructor for class org.apache.crunch.io.hbase.AtHBase
 
AutoClosingIterator<T> - Class in org.apache.crunch.io.impl
Closes the wrapped Closeable when AutoClosingIterator.hasNext() returns false.
AutoClosingIterator(Closeable, Iterator<T>) - Constructor for class org.apache.crunch.io.impl.AutoClosingIterator
 
AverageBytesByIP - Class in org.apache.crunch.examples
 
AverageBytesByIP() - Constructor for class org.apache.crunch.examples.AverageBytesByIP
 
AvroDeepCopier<T> - Class in org.apache.crunch.types.avro
Performs deep copies of Avro-serializable objects.
AvroDeepCopier(Schema) - Constructor for class org.apache.crunch.types.avro.AvroDeepCopier
 
AvroDeepCopier.AvroGenericDeepCopier - Class in org.apache.crunch.types.avro
Deep copier for Avro generic data objects.
AvroDeepCopier.AvroGenericDeepCopier(Schema) - Constructor for class org.apache.crunch.types.avro.AvroDeepCopier.AvroGenericDeepCopier
 
AvroDeepCopier.AvroReflectDeepCopier<T> - Class in org.apache.crunch.types.avro
Deep copier for Avro reflect data objects.
AvroDeepCopier.AvroReflectDeepCopier(Class<T>, Schema) - Constructor for class org.apache.crunch.types.avro.AvroDeepCopier.AvroReflectDeepCopier
 
AvroDeepCopier.AvroSpecificDeepCopier<T> - Class in org.apache.crunch.types.avro
Deep copier for Avro specific data objects.
AvroDeepCopier.AvroSpecificDeepCopier(Class<T>, Schema) - Constructor for class org.apache.crunch.types.avro.AvroDeepCopier.AvroSpecificDeepCopier
 
AvroDeepCopier.AvroTupleDeepCopier - Class in org.apache.crunch.types.avro
 
AvroDeepCopier.AvroTupleDeepCopier() - Constructor for class org.apache.crunch.types.avro.AvroDeepCopier.AvroTupleDeepCopier
 
avroFile(String, AvroType<T>) - Static method in class org.apache.crunch.io.At
 
avroFile(Path, AvroType<T>) - Static method in class org.apache.crunch.io.At
 
avroFile(String, AvroType<T>) - Static method in class org.apache.crunch.io.From
 
avroFile(Path, AvroType<T>) - Static method in class org.apache.crunch.io.From
 
avroFile(String) - Static method in class org.apache.crunch.io.To
 
avroFile(Path) - Static method in class org.apache.crunch.io.To
 
AvroFileReaderFactory<T> - Class in org.apache.crunch.io.avro
 
AvroFileReaderFactory(AvroType<T>, Configuration) - Constructor for class org.apache.crunch.io.avro.AvroFileReaderFactory
 
AvroFileSource<T> - Class in org.apache.crunch.io.avro
 
AvroFileSource(Path, AvroType<T>) - Constructor for class org.apache.crunch.io.avro.AvroFileSource
 
AvroFileSourceTarget<T> - Class in org.apache.crunch.io.avro
 
AvroFileSourceTarget(Path, AvroType<T>) - Constructor for class org.apache.crunch.io.avro.AvroFileSourceTarget
 
AvroFileTarget - Class in org.apache.crunch.io.avro
 
AvroFileTarget(String) - Constructor for class org.apache.crunch.io.avro.AvroFileTarget
 
AvroFileTarget(Path) - Constructor for class org.apache.crunch.io.avro.AvroFileTarget
 
AvroGroupedTableType<K,V> - Class in org.apache.crunch.types.avro
 
AvroGroupedTableType(AvroTableType<K, V>) - Constructor for class org.apache.crunch.types.avro.AvroGroupedTableType
 
AvroInputFormat<T> - Class in org.apache.crunch.types.avro
An InputFormat for Avro data files.
AvroInputFormat() - Constructor for class org.apache.crunch.types.avro.AvroInputFormat
 
AvroKeyConverter<K> - Class in org.apache.crunch.types.avro
 
AvroKeyConverter() - Constructor for class org.apache.crunch.types.avro.AvroKeyConverter
 
AvroOutputFormat<T> - Class in org.apache.crunch.types.avro
An OutputFormat for Avro data files.
AvroOutputFormat() - Constructor for class org.apache.crunch.types.avro.AvroOutputFormat
 
AvroPairConverter<K,V> - Class in org.apache.crunch.types.avro
 
AvroPairConverter() - Constructor for class org.apache.crunch.types.avro.AvroPairConverter
 
AvroRecordReader<T> - Class in org.apache.crunch.types.avro
An RecordReader for Avro data files.
AvroRecordReader(Schema) - Constructor for class org.apache.crunch.types.avro.AvroRecordReader
 
Avros - Class in org.apache.crunch.types.avro
Defines static methods that are analogous to the methods defined in AvroTypeFamily for convenient static importing.
AvroTableType<K,V> - Class in org.apache.crunch.types.avro
The implementation of the PTableType interface for Avro-based serialization.
AvroTableType(AvroType<K>, AvroType<V>, Class<Pair<K, V>>) - Constructor for class org.apache.crunch.types.avro.AvroTableType
 
AvroType<T> - Class in org.apache.crunch.types.avro
The implementation of the PType interface for Avro-based serialization.
AvroType(Class<T>, Schema, DeepCopier<T>, PType...) - Constructor for class org.apache.crunch.types.avro.AvroType
 
AvroType(Class<T>, Schema, MapFn, MapFn, DeepCopier<T>, PType...) - Constructor for class org.apache.crunch.types.avro.AvroType
 
AvroTypeFamily - Class in org.apache.crunch.types.avro
 
AvroUtf8InputFormat - Class in org.apache.crunch.types.avro
An InputFormat for text files.
AvroUtf8InputFormat() - Constructor for class org.apache.crunch.types.avro.AvroUtf8InputFormat
 

B

bigInt(PTypeFamily) - Static method in class org.apache.crunch.util.PTypes
 
BIGINT_TO_BYTE - Static variable in class org.apache.crunch.util.PTypes
 
booleans() - Static method in class org.apache.crunch.types.avro.Avros
 
booleans() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
booleans() - Method in interface org.apache.crunch.types.PTypeFamily
 
booleans() - Static method in class org.apache.crunch.types.writable.Writables
 
booleans() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
bottom(int) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
bottom(int) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
bottom(int) - Method in interface org.apache.crunch.PTable
Returns a PTable made up of the pairs in this PTable with the smallest value field.
build() - Method in class org.apache.crunch.GroupingOptions.Builder
 
build() - Method in class org.apache.crunch.impl.mr.plan.JobNameBuilder
 
builder() - Static method in class org.apache.crunch.GroupingOptions
 
by(MapFn<S, K>, PType<K>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
by(String, MapFn<S, K>, PType<K>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
by(MapFn<S, K>, PType<K>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
by(String, MapFn<S, K>, PType<K>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
by(int, Sort.Order) - Static method in class org.apache.crunch.lib.Sort.ColumnOrder
 
by(MapFn<S, K>, PType<K>) - Method in interface org.apache.crunch.PCollection
Apply the given map function to each element of this instance in order to create a PTable.
by(String, MapFn<S, K>, PType<K>) - Method in interface org.apache.crunch.PCollection
Apply the given map function to each element of this instance in order to create a PTable.
BYTE_TO_BIGINT - Static variable in class org.apache.crunch.util.PTypes
 
bytes() - Static method in class org.apache.crunch.types.avro.Avros
 
bytes() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
bytes() - Method in interface org.apache.crunch.types.PTypeFamily
 
bytes() - Static method in class org.apache.crunch.types.writable.Writables
 
bytes() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
BYTES_IN - Static variable in class org.apache.crunch.types.avro.Avros
 
BZip2TextInputFormat - Class in org.apache.crunch.io.text
 
BZip2TextInputFormat() - Constructor for class org.apache.crunch.io.text.BZip2TextInputFormat
 

C

CAN_COMBINE_SPECIFIC_AND_REFLECT_SCHEMAS - Static variable in class org.apache.crunch.types.avro.Avros
Older versions of Avro (i.e., before 1.7.0) do not support schemas that are composed of a mix of specific and reflection-based schemas.
Cartesian - Class in org.apache.crunch.lib
Utilities for Cartesian products of two PTable or PCollection instances.
Cartesian() - Constructor for class org.apache.crunch.lib.Cartesian
 
CBZip2InputStream - Class in org.apache.crunch.io.text
An input stream that decompresses from the BZip2 format (without the file header chars) to be read as any other stream.
CBZip2InputStream(FSDataInputStream, int, long) - Constructor for class org.apache.crunch.io.text.CBZip2InputStream
 
checkCombiningSpecificAndReflectionSchemas() - Static method in class org.apache.crunch.types.avro.Avros
 
cleanup(Emitter<T>) - Method in class org.apache.crunch.DoFn
Called during the cleanup of the MapReduce job this DoFn is associated with.
cleanup(Emitter<T>) - Method in class org.apache.crunch.fn.CompositeMapFn
 
cleanup(Emitter<Pair<S, T>>) - Method in class org.apache.crunch.fn.PairMapFn
 
cleanup() - Method in class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
cleanup() - Method in class org.apache.crunch.impl.mr.run.RTNode
 
cleanup(Emitter<Pair<Integer, Pair<K, V>>>) - Method in class org.apache.crunch.lib.Aggregate.TopKFn
 
cleanup(Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.FullOuterJoinFn
Called during the cleanup of the MapReduce job this DoFn is associated with.
cleanup(Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.LeftOuterJoinFn
Called during the cleanup of the MapReduce job this DoFn is associated with.
clearCounters() - Static method in class org.apache.crunch.test.TestCounters
 
clearWritten(int) - Method in class org.apache.crunch.types.writable.TupleWritable
Record that the tuple does not contain an element at the position provided.
clearWritten() - Method in class org.apache.crunch.types.writable.TupleWritable
Clear any record of which writables have been written to, without releasing storage.
close() - Method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Closes all the opened outputs.
close() - Method in class org.apache.crunch.io.impl.AutoClosingIterator
 
close() - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
cogroup(PTable<K, U>) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
cogroup(PTable<K, U>) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
Cogroup - Class in org.apache.crunch.lib
 
Cogroup() - Constructor for class org.apache.crunch.lib.Cogroup
 
cogroup(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Cogroup
Co-groups the two PTable arguments.
cogroup(PTable<K, U>) - Method in interface org.apache.crunch.PTable
Co-group operation with the given table on common keys.
CollectionDeepCopier<T> - Class in org.apache.crunch.types
Performs deep copies (based on underlying PType deep copying) of Collections.
CollectionDeepCopier(PType<T>) - Constructor for class org.apache.crunch.types.CollectionDeepCopier
 
collectionOf(T...) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
collectionOf(Iterable<T>) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
collections(PType<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
collections(PType<T>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
collections(PType<T>) - Method in interface org.apache.crunch.types.PTypeFamily
 
collections(PType<T>) - Static method in class org.apache.crunch.types.writable.Writables
 
collections(PType<T>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
Collects - Class in org.apache.crunch.util
Utility functions for returning Collection objects backed by different types of implementations.
collectValues() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
collectValues() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
collectValues(PTable<K, V>) - Static method in class org.apache.crunch.lib.Aggregate
 
collectValues() - Method in interface org.apache.crunch.PTable
Aggregate all of the values with the same key into a single key-value pair in the returned PTable.
CombineFn<S,T> - Class in org.apache.crunch
A special DoFn implementation that converts an Iterable of values into a single value.
CombineFn() - Constructor for class org.apache.crunch.CombineFn
 
CombineFn.Aggregator<T> - Interface in org.apache.crunch
 
CombineFn.AggregatorCombineFn<K,V> - Class in org.apache.crunch
A CombineFn that delegates all of the actual work to an Aggregator instance.
CombineFn.AggregatorCombineFn(CombineFn.Aggregator<V>) - Constructor for class org.apache.crunch.CombineFn.AggregatorCombineFn
 
CombineFn.AggregatorFactory<T> - Interface in org.apache.crunch
Interface for constructing new aggregator instances.
CombineFn.FirstNAggregator<V> - Class in org.apache.crunch
 
CombineFn.FirstNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.FirstNAggregator
 
CombineFn.LastNAggregator<V> - Class in org.apache.crunch
 
CombineFn.LastNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.LastNAggregator
 
CombineFn.MaxBigInts - Class in org.apache.crunch
 
CombineFn.MaxBigInts() - Constructor for class org.apache.crunch.CombineFn.MaxBigInts
 
CombineFn.MaxDoubles - Class in org.apache.crunch
 
CombineFn.MaxDoubles() - Constructor for class org.apache.crunch.CombineFn.MaxDoubles
 
CombineFn.MaxFloats - Class in org.apache.crunch
 
CombineFn.MaxFloats() - Constructor for class org.apache.crunch.CombineFn.MaxFloats
 
CombineFn.MaxInts - Class in org.apache.crunch
 
CombineFn.MaxInts() - Constructor for class org.apache.crunch.CombineFn.MaxInts
 
CombineFn.MaxLongs - Class in org.apache.crunch
 
CombineFn.MaxLongs() - Constructor for class org.apache.crunch.CombineFn.MaxLongs
 
CombineFn.MaxNAggregator<V extends Comparable<V>> - Class in org.apache.crunch
 
CombineFn.MaxNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.MaxNAggregator
 
CombineFn.MinBigInts - Class in org.apache.crunch
 
CombineFn.MinBigInts() - Constructor for class org.apache.crunch.CombineFn.MinBigInts
 
CombineFn.MinDoubles - Class in org.apache.crunch
 
CombineFn.MinDoubles() - Constructor for class org.apache.crunch.CombineFn.MinDoubles
 
CombineFn.MinFloats - Class in org.apache.crunch
 
CombineFn.MinFloats() - Constructor for class org.apache.crunch.CombineFn.MinFloats
 
CombineFn.MinInts - Class in org.apache.crunch
 
CombineFn.MinInts() - Constructor for class org.apache.crunch.CombineFn.MinInts
 
CombineFn.MinLongs - Class in org.apache.crunch
 
CombineFn.MinLongs() - Constructor for class org.apache.crunch.CombineFn.MinLongs
 
CombineFn.MinNAggregator<V extends Comparable<V>> - Class in org.apache.crunch
 
CombineFn.MinNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.MinNAggregator
 
CombineFn.PairAggregator<V1,V2> - Class in org.apache.crunch
 
CombineFn.PairAggregator(CombineFn.Aggregator<V1>, CombineFn.Aggregator<V2>) - Constructor for class org.apache.crunch.CombineFn.PairAggregator
 
CombineFn.QuadAggregator<A,B,C,D> - Class in org.apache.crunch
 
CombineFn.QuadAggregator(CombineFn.Aggregator<A>, CombineFn.Aggregator<B>, CombineFn.Aggregator<C>, CombineFn.Aggregator<D>) - Constructor for class org.apache.crunch.CombineFn.QuadAggregator
 
CombineFn.StringConcatAggregator - Class in org.apache.crunch
 
CombineFn.StringConcatAggregator(String, boolean) - Constructor for class org.apache.crunch.CombineFn.StringConcatAggregator
 
CombineFn.StringConcatAggregator(String, boolean, long, long) - Constructor for class org.apache.crunch.CombineFn.StringConcatAggregator
 
CombineFn.SumBigInts - Class in org.apache.crunch
 
CombineFn.SumBigInts() - Constructor for class org.apache.crunch.CombineFn.SumBigInts
 
CombineFn.SumDoubles - Class in org.apache.crunch
 
CombineFn.SumDoubles() - Constructor for class org.apache.crunch.CombineFn.SumDoubles
 
CombineFn.SumFloats - Class in org.apache.crunch
 
CombineFn.SumFloats() - Constructor for class org.apache.crunch.CombineFn.SumFloats
 
CombineFn.SumInts - Class in org.apache.crunch
 
CombineFn.SumInts() - Constructor for class org.apache.crunch.CombineFn.SumInts
 
CombineFn.SumLongs - Class in org.apache.crunch
 
CombineFn.SumLongs() - Constructor for class org.apache.crunch.CombineFn.SumLongs
 
CombineFn.TripAggregator<A,B,C> - Class in org.apache.crunch
 
CombineFn.TripAggregator(CombineFn.Aggregator<A>, CombineFn.Aggregator<B>, CombineFn.Aggregator<C>) - Constructor for class org.apache.crunch.CombineFn.TripAggregator
 
CombineFn.TupleNAggregator - Class in org.apache.crunch
 
CombineFn.TupleNAggregator(CombineFn.Aggregator<?>...) - Constructor for class org.apache.crunch.CombineFn.TupleNAggregator
 
combineValues(CombineFn<K, V>) - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
combineValues(CombineFn<K, V>) - Method in interface org.apache.crunch.PGroupedTable
Combines the values of this grouping using the given CombineFn.
comm(PCollection<T>, PCollection<T>) - Static method in class org.apache.crunch.lib.Set
Find the elements that are common to two sets, like the Unix comm utility.
compare(Pair<K, V>, Pair<K, V>) - Method in class org.apache.crunch.lib.Aggregate.PairValueComparator
 
compare(AvroWrapper<T>, AvroWrapper<T>) - Method in class org.apache.crunch.lib.join.JoinUtils.AvroPairGroupingComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.crunch.lib.join.JoinUtils.AvroPairGroupingComparator
 
compare(TupleWritable, TupleWritable) - Method in class org.apache.crunch.lib.join.JoinUtils.TupleWritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.crunch.lib.join.JoinUtils.TupleWritableComparator
 
compareTo(Pair<K, V>) - Method in class org.apache.crunch.Pair
 
compareTo(TupleWritable) - Method in class org.apache.crunch.types.writable.TupleWritable
 
CompositeMapFn<R,S,T> - Class in org.apache.crunch.fn
 
CompositeMapFn(MapFn<R, S>, MapFn<S, T>) - Constructor for class org.apache.crunch.fn.CompositeMapFn
 
CompositePathIterable<T> - Class in org.apache.crunch.io
 
configure(Configuration) - Method in class org.apache.crunch.DoFn
Called during the job planning phase.
configure(Configuration) - Method in class org.apache.crunch.fn.CompositeMapFn
 
configure(Configuration) - Method in class org.apache.crunch.fn.PairMapFn
 
configure(Job) - Method in class org.apache.crunch.GroupingOptions
 
configure(Target, PType<?>) - Method in class org.apache.crunch.impl.mr.plan.MSCROutputHandler
 
configure(Configuration) - Method in class org.apache.crunch.io.impl.InputBundle
 
configure(Target, PType<?>) - Method in interface org.apache.crunch.io.OutputHandler
 
configure(Configuration) - Method in class org.apache.crunch.types.avro.AvroUtf8InputFormat
 
configureForMapReduce(Job, PType<?>, Path, String) - Method in class org.apache.crunch.io.avro.AvroFileTarget
 
configureForMapReduce(Job, PType<?>, Path, String) - Method in class org.apache.crunch.io.hbase.HBaseTarget
 
configureForMapReduce(Job, PType<?>, Path, String) - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
configureForMapReduce(Job, PType<?>, Path, String) - Method in class org.apache.crunch.io.impl.SourcePathTargetImpl
 
configureForMapReduce(Job, PType<?>, Path, String) - Method in interface org.apache.crunch.io.MapReduceTarget
 
configureForMapReduce(Job, PType<?>, Path, String) - Method in class org.apache.crunch.io.PathTargetImpl
 
configureNode(DoNode, Target) - Method in class org.apache.crunch.impl.mr.plan.MSCROutputHandler
 
configureReflectDataFactory(Configuration) - Static method in class org.apache.crunch.types.avro.Avros
 
configureShuffle(Job) - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
configureShuffle(Job, GroupingOptions) - Method in class org.apache.crunch.types.avro.AvroGroupedTableType
 
configureShuffle(Job, GroupingOptions) - Method in class org.apache.crunch.types.PGroupedTableType
 
configureShuffle(Job, GroupingOptions) - Method in class org.apache.crunch.types.writable.WritableGroupedTableType
 
configureSource(Job, int) - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
configureSource(Job, int) - Method in class org.apache.crunch.io.impl.FileSourceImpl
 
configureSource(Job, int) - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
configureSource(Job, int) - Method in interface org.apache.crunch.Source
Configure the given job to use this source as an input.
containers(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
containers(Class<T>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
convert(PType<T>, PTypeFamily) - Static method in class org.apache.crunch.types.PTypeUtils
 
Converter<K,V,S,T> - Interface in org.apache.crunch.types
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 output key/values.
convertInput(AvroWrapper<K>, NullWritable) - Method in class org.apache.crunch.types.avro.AvroKeyConverter
 
convertInput(AvroKey<K>, AvroValue<V>) - Method in class org.apache.crunch.types.avro.AvroPairConverter
 
convertInput(K, V) - Method in interface org.apache.crunch.types.Converter
 
convertInput(K, V) - Method in class org.apache.crunch.types.writable.WritablePairConverter
 
convertIterableInput(AvroWrapper<K>, Iterable<NullWritable>) - Method in class org.apache.crunch.types.avro.AvroKeyConverter
 
convertIterableInput(AvroKey<K>, Iterable<AvroValue<V>>) - Method in class org.apache.crunch.types.avro.AvroPairConverter
 
convertIterableInput(K, Iterable<V>) - Method in interface org.apache.crunch.types.Converter
 
convertIterableInput(K, Iterable<V>) - Method in class org.apache.crunch.types.writable.WritablePairConverter
 
copyResourceFile(String) - Method in class org.apache.crunch.test.TemporaryPath
Copy a classpath resource to File.
copyResourceFileName(String) - Method in class org.apache.crunch.test.TemporaryPath
Copy a classpath resource returning its absolute file name.
copyResourcePath(String) - Method in class org.apache.crunch.test.TemporaryPath
Copy a classpath resource to a Path.
count() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
count() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
count(PCollection<S>) - Static method in class org.apache.crunch.lib.Aggregate
Returns a PTable that contains the unique elements of this collection mapped to a count of their occurrences.
count() - Method in interface org.apache.crunch.PCollection
Returns a PTable instance that contains the counts of each unique element of this PCollection.
create() - Method in interface org.apache.crunch.CombineFn.AggregatorFactory
 
create(Configuration, TaskAttemptID) - Static method in class org.apache.crunch.impl.mr.run.TaskAttemptContextFactory
 
create(FileSystem, Path, FileReaderFactory<S>) - Static method in class org.apache.crunch.io.CompositePathIterable
 
create(Class<T>, Class...) - Static method in class org.apache.crunch.types.TupleFactory
 
CREATE_DIR - Static variable in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.DoCollectionImpl
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.DoTableImpl
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.InputCollection
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.InputTable
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.UnionCollection
 
createDoNode() - Method in class org.apache.crunch.impl.mr.collect.UnionTable
 
createFnNode(String, DoFn<?, ?>, PType<?>) - Static method in class org.apache.crunch.impl.mr.plan.DoNode
 
createGroupingNode(String, PGroupedTableType<K, V>) - Static method in class org.apache.crunch.impl.mr.plan.DoNode
 
createInputNode(Source<S>) - Static method in class org.apache.crunch.impl.mr.plan.DoNode
 
createIntermediateOutput(PType<T>) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
createMapOnlyJob(HashMultimap<Target, NodePath>, Path) - Static method in class org.apache.crunch.impl.mr.plan.JobPrototype
 
createMapReduceJob(PGroupedTableImpl<?, ?>, Set<NodePath>, Path) - Static method in class org.apache.crunch.impl.mr.plan.JobPrototype
 
createOutputNode(String, PType<S>) - Static method in class org.apache.crunch.impl.mr.plan.DoNode
 
createPut(PTable<String, String>) - Method in class org.apache.crunch.examples.WordAggregationHBase
Create puts in order to insert them in hbase.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.crunch.impl.mr.run.CrunchInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.crunch.io.text.BZip2TextInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.crunch.types.avro.AvroInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.crunch.types.avro.AvroUtf8InputFormat
 
createTempPath() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
cross(PTable<K1, U>, PTable<K2, V>) - Static method in class org.apache.crunch.lib.Cartesian
Performs a full cross join on the specified PTables (using the same strategy as Pig's CROSS operator).
cross(PTable<K1, U>, PTable<K2, V>, int) - Static method in class org.apache.crunch.lib.Cartesian
Performs a full cross join on the specified PTables (using the same strategy as Pig's CROSS operator).
cross(PCollection<U>, PCollection<V>) - Static method in class org.apache.crunch.lib.Cartesian
Performs a full cross join on the specified PCollections (using the same strategy as Pig's CROSS operator).
cross(PCollection<U>, PCollection<V>, int) - Static method in class org.apache.crunch.lib.Cartesian
Performs a full cross join on the specified PCollections (using the same strategy as Pig's CROSS operator).
CRUNCH_WORKING_DIRECTORY - Static variable in class org.apache.crunch.impl.mr.plan.PlanningParameters
 
CrunchCombiner - Class in org.apache.crunch.impl.mr.run
 
CrunchCombiner() - Constructor for class org.apache.crunch.impl.mr.run.CrunchCombiner
 
CrunchControlledJob - Class in org.apache.crunch.hadoop.mapreduce.lib.jobcontrol
This class encapsulates a MapReduce job and its dependency.
CrunchControlledJob(Job, List<CrunchControlledJob>) - Constructor for class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Construct a job.
CrunchControlledJob(Configuration) - Constructor for class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Construct a job.
CrunchControlledJob.State - Enum in org.apache.crunch.hadoop.mapreduce.lib.jobcontrol
 
CrunchInputFormat<K,V> - Class in org.apache.crunch.impl.mr.run
 
CrunchInputFormat() - Constructor for class org.apache.crunch.impl.mr.run.CrunchInputFormat
 
CrunchInputs - Class in org.apache.crunch.impl.mr.run
 
CrunchInputs() - Constructor for class org.apache.crunch.impl.mr.run.CrunchInputs
 
CrunchInputSplit - Class in org.apache.crunch.impl.mr.run
 
CrunchInputSplit() - Constructor for class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
CrunchInputSplit(InputSplit, Class<? extends InputFormat>, Map<String, String>, int, Configuration) - Constructor for class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
CrunchJob - Class in org.apache.crunch.impl.mr.exec
 
CrunchJob(Job, Path, MSCROutputHandler) - Constructor for class org.apache.crunch.impl.mr.exec.CrunchJob
 
CrunchJobControl - Class in org.apache.crunch.hadoop.mapreduce.lib.jobcontrol
This class encapsulates a set of MapReduce jobs and its dependency.
CrunchJobControl(String) - Constructor for class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
Construct a job control for a group of jobs.
CrunchJobControl.ThreadState - Enum in org.apache.crunch.hadoop.mapreduce.lib.jobcontrol
 
CrunchMapper - Class in org.apache.crunch.impl.mr.run
 
CrunchMapper() - Constructor for class org.apache.crunch.impl.mr.run.CrunchMapper
 
CrunchMultipleOutputs<KEYOUT,VALUEOUT> - Class in org.apache.crunch.hadoop.mapreduce.lib.output
The MultipleOutputs class simplifies writing output data to multiple outputs
CrunchMultipleOutputs(TaskInputOutputContext<?, ?, KEYOUT, VALUEOUT>) - Constructor for class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Creates and initializes multiple outputs support, it should be instantiated in the Mapper/Reducer setup method.
CrunchReducer - Class in org.apache.crunch.impl.mr.run
 
CrunchReducer() - Constructor for class org.apache.crunch.impl.mr.run.CrunchReducer
 
CrunchRuntimeException - Exception in org.apache.crunch.impl.mr.run
 
CrunchRuntimeException(String) - Constructor for exception org.apache.crunch.impl.mr.run.CrunchRuntimeException
 
CrunchRuntimeException(Exception) - Constructor for exception org.apache.crunch.impl.mr.run.CrunchRuntimeException
 
CrunchRuntimeException(String, Exception) - Constructor for exception org.apache.crunch.impl.mr.run.CrunchRuntimeException
 
CrunchTaskContext - Class in org.apache.crunch.impl.mr.run
 
CrunchTaskContext(TaskInputOutputContext<Object, Object, Object, Object>, NodeContext) - Constructor for class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
CrunchTestSupport - Class in org.apache.crunch.test
A temporary workaround for Scala tests to use when working with Rule annotations until it gets fixed in JUnit 4.11.
CrunchTestSupport() - Constructor for class org.apache.crunch.test.CrunchTestSupport
 
CrunchTool - Class in org.apache.crunch.tool
An extension of the Tool interface that creates a Pipeline instance and provides methods for working with the Pipeline from inside of the Tool's run method.
CrunchTool() - Constructor for class org.apache.crunch.tool.CrunchTool
 
CrunchTool(boolean) - Constructor for class org.apache.crunch.tool.CrunchTool
 

D

DEBUG - Static variable in class org.apache.crunch.impl.mr.run.RuntimeParameters
 
DeepCopier<T> - Interface in org.apache.crunch.types
Performs deep copies of values.
DeepCopier.NoOpDeepCopier<V> - Class in org.apache.crunch.types
 
DeepCopier.NoOpDeepCopier() - Constructor for class org.apache.crunch.types.DeepCopier.NoOpDeepCopier
 
deepCopy(T) - Method in class org.apache.crunch.types.avro.AvroDeepCopier
Create a deep copy of an Avro value.
deepCopy(Collection<T>) - Method in class org.apache.crunch.types.CollectionDeepCopier
 
deepCopy(T) - Method in interface org.apache.crunch.types.DeepCopier
Create a deep copy of a value.
deepCopy(V) - Method in class org.apache.crunch.types.DeepCopier.NoOpDeepCopier
 
deepCopy(Map<String, T>) - Method in class org.apache.crunch.types.MapDeepCopier
 
deepCopy(T) - Method in class org.apache.crunch.types.TupleDeepCopier
 
deepCopy(T) - Method in class org.apache.crunch.types.writable.WritableDeepCopier
 
derived(Class<T>, MapFn<S, T>, MapFn<T, S>, PType<S>) - Static method in class org.apache.crunch.types.avro.Avros
 
derived(Class<T>, MapFn<S, T>, MapFn<T, S>, PType<S>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
derived(Class<T>, MapFn<S, T>, MapFn<T, S>, PType<S>) - Method in interface org.apache.crunch.types.PTypeFamily
 
derived(Class<T>, MapFn<S, T>, MapFn<T, S>, PType<S>) - Static method in class org.apache.crunch.types.writable.Writables
 
derived(Class<T>, MapFn<S, T>, MapFn<T, S>, PType<S>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
difference(PCollection<T>, PCollection<T>) - Static method in class org.apache.crunch.lib.Set
Compute the set difference between two sets of elements.
DistCache - Class in org.apache.crunch.util
Provides functions for working with Hadoop's distributed cache.
DistCache() - Constructor for class org.apache.crunch.util.DistCache
 
DoCollectionImpl<S> - Class in org.apache.crunch.impl.mr.collect
 
DoFn<S,T> - Class in org.apache.crunch
Base class for all data processing functions in Crunch.
DoFn() - Constructor for class org.apache.crunch.DoFn
 
done() - Method in class org.apache.crunch.impl.mem.MemPipeline
 
done() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
done() - Method in interface org.apache.crunch.Pipeline
Run any remaining jobs required to generate outputs and then clean up any intermediate data files that were created in this run or previous calls to run.
done() - Method in class org.apache.crunch.tool.CrunchTool
 
DoNode - Class in org.apache.crunch.impl.mr.plan
 
DoTableImpl<K,V> - Class in org.apache.crunch.impl.mr.collect
 
doubles() - Static method in class org.apache.crunch.types.avro.Avros
 
doubles() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
doubles() - Method in interface org.apache.crunch.types.PTypeFamily
 
doubles() - Static method in class org.apache.crunch.types.writable.Writables
 
doubles() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 

E

emit(T) - Method in interface org.apache.crunch.Emitter
Write the emitted value to the next stage of the pipeline.
emit(Object) - Method in class org.apache.crunch.impl.mr.emit.IntermediateEmitter
 
emit(T) - Method in class org.apache.crunch.impl.mr.emit.MultipleOutputEmitter
 
emit(T) - Method in class org.apache.crunch.impl.mr.emit.OutputEmitter
 
emit(T) - Method in class org.apache.crunch.test.InMemoryEmitter
 
Emitter<T> - Interface in org.apache.crunch
Interface for writing outputs from a DoFn.
EMPTY - Static variable in class org.apache.crunch.PipelineResult
 
enableDebug() - Method in class org.apache.crunch.impl.mem.MemPipeline
 
enableDebug() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
enableDebug() - Method in interface org.apache.crunch.Pipeline
Turn on debug logging for jobs that are run from this pipeline.
enableDebug() - Method in class org.apache.crunch.tool.CrunchTool
 
entrySet() - Method in class org.apache.crunch.materialize.MaterializableMap
 
entrySet() - Method in class org.apache.crunch.types.writable.TextMapWritable
 
equals(Object) - Method in class org.apache.crunch.impl.mr.collect.InputCollection
 
equals(Object) - Method in class org.apache.crunch.impl.mr.collect.InputTable
 
equals(Object) - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
equals(Object) - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
equals(Object) - Method in class org.apache.crunch.io.hbase.HBaseTarget
 
equals(Object) - Method in class org.apache.crunch.io.impl.FileSourceImpl
 
equals(Object) - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
equals(Object) - Method in class org.apache.crunch.io.impl.InputBundle
 
equals(Object) - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
equals(Object) - Method in class org.apache.crunch.Pair
 
equals(Object) - Method in class org.apache.crunch.Tuple3
 
equals(Object) - Method in class org.apache.crunch.Tuple4
 
equals(Object) - Method in class org.apache.crunch.TupleN
 
equals(Object) - Method in class org.apache.crunch.types.avro.AvroType
 
equals(Object) - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
equals(Object) - Method in class org.apache.crunch.types.writable.TupleWritable
equals(Object) - Method in class org.apache.crunch.types.writable.WritableType
 
execute() - Method in class org.apache.crunch.impl.mr.exec.MRExecutor
 
extractKey(String) - Static method in class org.apache.crunch.util.Protos
 
ExtractKeyFn<K,V> - Class in org.apache.crunch.fn
Wrapper function for converting a MapFn into a key-value pair that is used to convert from a PCollection<V> to a PTable<K, V>.
ExtractKeyFn(MapFn<V, K>) - Constructor for class org.apache.crunch.fn.ExtractKeyFn
 
extractText(PTable<ImmutableBytesWritable, Result>) - Method in class org.apache.crunch.examples.WordAggregationHBase
Extract information from hbase

F

FileReaderFactory<T> - Interface in org.apache.crunch.io
 
FileSourceImpl<T> - Class in org.apache.crunch.io.impl
 
FileSourceImpl(Path, PType<T>, Class<? extends InputFormat>) - Constructor for class org.apache.crunch.io.impl.FileSourceImpl
 
FileSourceImpl(Path, PType<T>, InputBundle) - Constructor for class org.apache.crunch.io.impl.FileSourceImpl
 
FileTableSourceImpl<K,V> - Class in org.apache.crunch.io.impl
 
FileTableSourceImpl(Path, PTableType<K, V>, Class<? extends FileInputFormat>) - Constructor for class org.apache.crunch.io.impl.FileTableSourceImpl
 
FileTargetImpl - Class in org.apache.crunch.io.impl
 
FileTargetImpl(Path, Class<? extends FileOutputFormat>) - Constructor for class org.apache.crunch.io.impl.FileTargetImpl
 
filter(FilterFn<S>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
filter(String, FilterFn<S>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
filter(FilterFn<S>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
filter(String, FilterFn<S>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
filter(FilterFn<S>) - Method in interface org.apache.crunch.PCollection
Apply the given filter function to this instance and return the resulting PCollection.
filter(String, FilterFn<S>) - Method in interface org.apache.crunch.PCollection
Apply the given filter function to this instance and return the resulting PCollection.
FilterFn<T> - Class in org.apache.crunch
A DoFn for the common case of filtering the members of a PCollection based on a boolean condition.
FilterFn() - Constructor for class org.apache.crunch.FilterFn
 
FilterFn.AndFn<S> - Class in org.apache.crunch
 
FilterFn.AndFn(FilterFn<S>...) - Constructor for class org.apache.crunch.FilterFn.AndFn
 
FilterFn.NotFn<S> - Class in org.apache.crunch
 
FilterFn.NotFn(FilterFn<S>) - Constructor for class org.apache.crunch.FilterFn.NotFn
 
FilterFn.OrFn<S> - Class in org.apache.crunch
 
FilterFn.OrFn(FilterFn<S>...) - Constructor for class org.apache.crunch.FilterFn.OrFn
 
findContainingJar(Class) - Static method in class org.apache.crunch.util.DistCache
Finds the path to a jar that contains the class provided, if any.
findCounter(Enum<?>) - Method in class org.apache.crunch.PipelineResult.StageResult
 
first() - Method in class org.apache.crunch.Pair
 
first() - Method in class org.apache.crunch.Tuple3
 
first() - Method in class org.apache.crunch.Tuple4
 
FIRST_N(int) - Static method in class org.apache.crunch.CombineFn
 
floats() - Static method in class org.apache.crunch.types.avro.Avros
 
floats() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
floats() - Method in interface org.apache.crunch.types.PTypeFamily
 
floats() - Static method in class org.apache.crunch.types.writable.Writables
 
floats() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
flush() - Method in interface org.apache.crunch.Emitter
Flushes any values cached by this emitter.
flush() - Method in class org.apache.crunch.impl.mr.emit.IntermediateEmitter
 
flush() - Method in class org.apache.crunch.impl.mr.emit.MultipleOutputEmitter
 
flush() - Method in class org.apache.crunch.impl.mr.emit.OutputEmitter
 
flush() - Method in class org.apache.crunch.test.InMemoryEmitter
 
formattedFile(String, Class<? extends FileInputFormat>, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
 
formattedFile(Path, Class<? extends FileInputFormat>, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
 
formattedFile(String, Class<? extends FileOutputFormat>) - Static method in class org.apache.crunch.io.To
 
formattedFile(Path, Class<? extends FileOutputFormat>) - Static method in class org.apache.crunch.io.To
 
fourth() - Method in class org.apache.crunch.Tuple4
 
From - Class in org.apache.crunch.io
Static factory methods for creating various Source types.
From() - Constructor for class org.apache.crunch.io.From
 
FromHBase - Class in org.apache.crunch.io.hbase
Static factory methods for creating HBase Source types.
FromHBase() - Constructor for class org.apache.crunch.io.hbase.FromHBase
 
fromSerialized(String) - Static method in class org.apache.crunch.io.impl.InputBundle
 
fullJoin(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
Performs a full outer join on the specified PTables.
FullOuterJoinFn<K,U,V> - Class in org.apache.crunch.lib.join
Used to perform the last step of an full outer join.
FullOuterJoinFn(PType<K>, PType<U>) - Constructor for class org.apache.crunch.lib.join.FullOuterJoinFn
 

G

GenericArrayWritable<T> - Class in org.apache.crunch.types.writable
 
GenericArrayWritable(Class<? extends Writable>) - Constructor for class org.apache.crunch.types.writable.GenericArrayWritable
 
GenericArrayWritable() - Constructor for class org.apache.crunch.types.writable.GenericArrayWritable
 
generics(Schema) - Static method in class org.apache.crunch.types.avro.Avros
 
generics(Schema) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
get(int) - Method in class org.apache.crunch.Pair
 
get() - Static method in class org.apache.crunch.scrunch.ScalaSafeReflectData
 
get(int) - Method in interface org.apache.crunch.Tuple
Returns the Object at the given index.
get(int) - Method in class org.apache.crunch.Tuple3
 
get(int) - Method in class org.apache.crunch.Tuple4
 
get(int) - Method in class org.apache.crunch.TupleN
 
get() - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
get(int) - Method in class org.apache.crunch.types.writable.TupleWritable
Get ith Writable from Tuple.
getChildren() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
getCollection() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
getConf() - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
getConf() - Method in class org.apache.crunch.tool.CrunchTool
 
getConfiguration() - Method in class org.apache.crunch.impl.mem.MemPipeline
 
getConfiguration() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
getConfiguration() - Method in interface org.apache.crunch.Pipeline
Returns the Configuration instance associated with this pipeline.
getConfigurationKey() - Method in enum org.apache.crunch.impl.mr.run.NodeContext
 
getContext() - Method in class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
getConverter() - Method in class org.apache.crunch.types.avro.AvroType
 
getConverter() - Method in class org.apache.crunch.types.PGroupedTableType
 
getConverter() - Method in interface org.apache.crunch.types.PType
 
getConverter() - Method in class org.apache.crunch.types.writable.WritableType
 
getCounter(Enum<?>) - Static method in class org.apache.crunch.test.TestCounters
 
getCounter(String, String) - Static method in class org.apache.crunch.test.TestCounters
 
getCounters() - Method in class org.apache.crunch.PipelineResult.StageResult
 
getCountersEnabled(JobContext) - Static method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Returns if the counters for the named outputs are enabled or not.
getCounterValue(Enum<?>) - Method in class org.apache.crunch.PipelineResult.StageResult
 
getCrunchJob(Class<?>, Configuration, Pipeline) - Method in class org.apache.crunch.impl.mr.plan.JobPrototype
 
getCurrentKey() - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
getCurrentValue() - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
getDefaultConfiguration() - Method in class org.apache.crunch.test.TemporaryPath
 
getDefaultFileSource(Path) - Method in class org.apache.crunch.types.avro.AvroType
 
getDefaultFileSource(Path) - Method in class org.apache.crunch.types.PGroupedTableType
 
getDefaultFileSource(Path) - Method in interface org.apache.crunch.types.PType
Returns a SourceTarget that is able to read/write data using the serialization format specified by this PType.
getDefaultFileSource(Path) - Method in class org.apache.crunch.types.writable.WritableType
 
getDependentJobs() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getDepth() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getDeserializer(Class<AvroWrapper<T>>) - Method in class org.apache.crunch.types.avro.SafeAvroSerialization
Returns the specified map output deserializer.
getDetachedValue(PTableType<K, V>, Pair<K, V>) - Static method in class org.apache.crunch.lib.PTables
Create a detached value for a table Pair.
getDetachedValue(Pair<K, Iterable<V>>) - Method in class org.apache.crunch.types.avro.AvroGroupedTableType
 
getDetachedValue(Pair<K, V>) - Method in class org.apache.crunch.types.avro.AvroTableType
 
getDetachedValue(T) - Method in class org.apache.crunch.types.avro.AvroType
 
getDetachedValue(T) - Method in interface org.apache.crunch.types.PType
Returns a copy of a value (or the value itself) that can safely be retained.
getDetachedValue(Pair<K, Iterable<V>>) - Method in class org.apache.crunch.types.writable.WritableGroupedTableType
 
getDetachedValue(T) - Method in class org.apache.crunch.types.writable.WritableType
 
getExtraConfiguration() - Method in class org.apache.crunch.io.impl.InputBundle
 
getFailedJobList() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
getFamily() - Method in class org.apache.crunch.types.avro.AvroType
 
getFamily() - Method in class org.apache.crunch.types.PGroupedTableType
 
getFamily() - Method in interface org.apache.crunch.types.PType
Returns the PTypeFamily that this PType belongs to.
getFamily() - Method in class org.apache.crunch.types.writable.WritableType
 
getField(Object, String, int) - Method in class org.apache.crunch.scrunch.ScalaSafeReflectData
 
getFile(String) - Method in class org.apache.crunch.test.TemporaryPath
Get a File below the temporary directory.
getFileName(String) - Method in class org.apache.crunch.test.TemporaryPath
Get an absolute file name below the temporary directory.
getFirst() - Method in class org.apache.crunch.fn.CompositeMapFn
 
getFormatNodeMap(JobContext) - Static method in class org.apache.crunch.impl.mr.run.CrunchInputs
 
getGroupedDetachedValue(PGroupedTableType<K, V>, Pair<K, Iterable<V>>) - Static method in class org.apache.crunch.lib.PTables
Created a detached value for a PGroupedTable value.
getGroupedTableType() - Method in class org.apache.crunch.types.avro.AvroTableType
 
getGroupedTableType() - Method in interface org.apache.crunch.types.PTableType
Returns the grouped table version of this type.
getGroupingComparator(PTypeFamily) - Static method in class org.apache.crunch.lib.join.JoinUtils
 
getGroupingConverter() - Method in class org.apache.crunch.types.avro.AvroGroupedTableType
 
getGroupingConverter() - Method in class org.apache.crunch.types.PGroupedTableType
 
getGroupingConverter() - Method in class org.apache.crunch.types.writable.WritableGroupedTableType
 
getGroupingNode() - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
getInputFormatClass() - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
getInputFormatClass() - Method in class org.apache.crunch.io.impl.InputBundle
 
getInputMapFn() - Method in class org.apache.crunch.types.avro.AvroGroupedTableType
 
getInputMapFn() - Method in class org.apache.crunch.types.avro.AvroType
 
getInputMapFn() - Method in interface org.apache.crunch.types.PType
 
getInputMapFn() - Method in class org.apache.crunch.types.writable.WritableGroupedTableType
 
getInputMapFn() - Method in class org.apache.crunch.types.writable.WritableType
 
getInputSplit() - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
getInstance() - Static method in class org.apache.crunch.fn.IdentityFn
 
getInstance() - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
getInstance() - Static method in class org.apache.crunch.types.avro.AvroTypeFamily
 
getInstance() - Static method in class org.apache.crunch.types.writable.WritableTypeFamily
 
getJob() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getJobID() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getJobName() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getJobState() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getJoinType() - Method in class org.apache.crunch.lib.join.FullOuterJoinFn
getJoinType() - Method in class org.apache.crunch.lib.join.InnerJoinFn
getJoinType() - Method in class org.apache.crunch.lib.join.JoinFn
 
getJoinType() - Method in class org.apache.crunch.lib.join.LeftOuterJoinFn
getJoinType() - Method in class org.apache.crunch.lib.join.RightOuterJoinFn
getKeyClass() - Method in class org.apache.crunch.types.avro.AvroKeyConverter
 
getKeyClass() - Method in class org.apache.crunch.types.avro.AvroPairConverter
 
getKeyClass() - Method in interface org.apache.crunch.types.Converter
 
getKeyClass() - Method in class org.apache.crunch.types.writable.WritablePairConverter
 
getKeyType() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
getKeyType() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
getKeyType() - Method in interface org.apache.crunch.PTable
Returns the PType of the key.
getKeyType() - Method in class org.apache.crunch.types.avro.AvroTableType
 
getKeyType() - Method in interface org.apache.crunch.types.PTableType
Returns the key type for the table.
getLength() - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
getLocations() - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
getMapredJobID() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getMaterializedAt() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getMaterializeSourceTarget(PCollection<T>) - Method in class org.apache.crunch.impl.mr.MRPipeline
Retrieve a ReadableSourceTarget that provides access to the contents of a PCollection.
getMessage() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
getMultiPaths() - Method in class org.apache.crunch.impl.mr.plan.MSCROutputHandler
 
getMultipleOutputs() - Method in class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
getName() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
getName() - Method in class org.apache.crunch.impl.mem.MemPipeline
 
getName() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getName() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
getName() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
getName() - Method in class org.apache.crunch.io.impl.InputBundle
 
getName() - Method in interface org.apache.crunch.PCollection
Returns a shorthand name for this PCollection.
getName() - Method in interface org.apache.crunch.Pipeline
Returns the name of this pipeline.
getNextAnonymousStageId() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
getNodeContext() - Method in class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
getNodeIndex() - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
getNodes() - Method in class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
getNumReducers() - Method in class org.apache.crunch.GroupingOptions
 
getOnlyParent() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getOutput() - Method in class org.apache.crunch.test.InMemoryEmitter
 
getOutputMapFn() - Method in class org.apache.crunch.types.avro.AvroGroupedTableType
 
getOutputMapFn() - Method in class org.apache.crunch.types.avro.AvroType
 
getOutputMapFn() - Method in interface org.apache.crunch.types.PType
 
getOutputMapFn() - Method in class org.apache.crunch.types.writable.WritableGroupedTableType
 
getOutputMapFn() - Method in class org.apache.crunch.types.writable.WritableType
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.DoCollectionImpl
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.DoTableImpl
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.InputCollection
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.InputTable
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.UnionCollection
 
getParents() - Method in class org.apache.crunch.impl.mr.collect.UnionTable
 
getPartition(AvroKey<K>, AvroValue<V>, int) - Method in class org.apache.crunch.lib.join.JoinUtils.AvroIndexedRecordPartitioner
 
getPartition(TupleWritable, Writable, int) - Method in class org.apache.crunch.lib.join.JoinUtils.TupleWritablePartitioner
 
getPartitionerClass(PTypeFamily) - Static method in class org.apache.crunch.lib.join.JoinUtils
 
getPath() - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
getPath() - Method in class org.apache.crunch.io.impl.SourcePathTargetImpl
 
getPath() - Method in interface org.apache.crunch.io.PathTarget
 
getPath() - Method in class org.apache.crunch.io.PathTargetImpl
 
getPath() - Method in class org.apache.crunch.io.text.TextFileTarget
 
getPath(String) - Method in class org.apache.crunch.test.TemporaryPath
Get a Path below the temporary directory.
getPathSize(Configuration, Path) - Static method in class org.apache.crunch.io.SourceTargetHelper
 
getPathSize(FileSystem, Path) - Static method in class org.apache.crunch.io.SourceTargetHelper
 
getPipeline() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
getPipeline() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getPipeline() - Method in interface org.apache.crunch.PCollection
Returns the Pipeline associated with this PCollection.
getPos() - Method in class org.apache.crunch.io.text.CBZip2InputStream
getPos is used by the caller to know when the processing of the current InputSplit is complete.
getPos() - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
getPrimitiveType(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
getPrimitiveType(Class<T>) - Static method in class org.apache.crunch.types.writable.Writables
 
getProgress() - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
getPTableType() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
getPTableType() - Method in class org.apache.crunch.impl.mr.collect.DoTableImpl
 
getPTableType() - Method in class org.apache.crunch.impl.mr.collect.InputTable
 
getPTableType() - Method in class org.apache.crunch.impl.mr.collect.UnionTable
 
getPTableType() - Method in interface org.apache.crunch.PTable
Returns the PTableType of this PTable.
getPType() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.DoCollectionImpl
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.DoTableImpl
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.InputCollection
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.InputTable
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.UnionCollection
 
getPType() - Method in class org.apache.crunch.impl.mr.collect.UnionTable
 
getPType() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
getPType() - Method in interface org.apache.crunch.PCollection
Returns the PType of this PCollection.
getReadCount() - Method in class org.apache.crunch.io.text.CBZip2InputStream
 
getReader(Schema) - Method in class org.apache.crunch.scrunch.ScalaReflectDataFactory
 
getReader(Schema) - Method in class org.apache.crunch.types.avro.ReflectDataFactory
 
getReadLimit() - Method in class org.apache.crunch.io.text.CBZip2InputStream
 
getReadyJobsList() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.crunch.types.avro.AvroOutputFormat
 
getReflectData() - Method in class org.apache.crunch.scrunch.ScalaReflectDataFactory
 
getReflectData() - Method in class org.apache.crunch.types.avro.ReflectDataFactory
 
getReflectDataFactory(Configuration) - Static method in class org.apache.crunch.types.avro.Avros
 
getRootFile() - Method in class org.apache.crunch.test.TemporaryPath
Get the root directory which will be deleted automatically.
getRootFileName() - Method in class org.apache.crunch.test.TemporaryPath
Get the root directory as an absolute file name.
getRootPath() - Method in class org.apache.crunch.test.TemporaryPath
Get the root directory as a Path.
getRunningJobList() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
getSchema() - Method in class org.apache.crunch.types.avro.AvroType
 
getSecond() - Method in class org.apache.crunch.fn.CompositeMapFn
 
getSerializationClass() - Method in class org.apache.crunch.types.writable.WritableType
 
getSerializer(Class<AvroWrapper<T>>) - Method in class org.apache.crunch.types.avro.SafeAvroSerialization
Returns the specified output serializer.
getSize() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
getSize() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getSize(Configuration) - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
getSize(Configuration) - Method in class org.apache.crunch.io.impl.FileSourceImpl
 
getSize(Configuration) - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
getSize(Configuration) - Method in class org.apache.crunch.io.text.TextFileSource
 
getSize() - Method in interface org.apache.crunch.PCollection
Returns the size of the data represented by this PCollection in bytes.
getSize(Configuration) - Method in interface org.apache.crunch.Source
Returns the number of bytes in this Source.
getSortComparatorClass() - Method in class org.apache.crunch.GroupingOptions
 
getSource() - Method in class org.apache.crunch.impl.mr.collect.InputCollection
 
getSource() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
getSourceTarget() - Method in class org.apache.crunch.materialize.MaterializableIterable
 
getSplits(JobContext) - Method in class org.apache.crunch.impl.mr.run.CrunchInputFormat
 
getStageName() - Method in class org.apache.crunch.PipelineResult.StageResult
 
getStageResults() - Method in class org.apache.crunch.PipelineResult
 
getSubTypes() - Method in class org.apache.crunch.types.avro.AvroType
 
getSubTypes() - Method in class org.apache.crunch.types.PGroupedTableType
 
getSubTypes() - Method in interface org.apache.crunch.types.PType
Returns the sub-types that make up this PType if it is a composite instance, such as a tuple.
getSubTypes() - Method in class org.apache.crunch.types.writable.WritableType
 
getSuccessfulJobList() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
getTableType() - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
getTableType() - Method in class org.apache.crunch.io.impl.FileTableSourceImpl
 
getTableType() - Method in class org.apache.crunch.io.impl.TableSourcePathTargetImpl
 
getTableType() - Method in class org.apache.crunch.io.impl.TableSourceTargetImpl
 
getTableType() - Method in class org.apache.crunch.io.seq.SeqFileTableSourceTarget
 
getTableType() - Method in interface org.apache.crunch.TableSource
 
getTableType() - Method in class org.apache.crunch.types.PGroupedTableType
 
getThreadState() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
getTupleFactory(Class<T>) - Static method in class org.apache.crunch.types.TupleFactory
Get the TupleFactory for a given Tuple implementation.
getType() - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
getType() - Method in class org.apache.crunch.io.impl.FileSourceImpl
 
getType() - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
getType() - Method in interface org.apache.crunch.Source
Returns the PType for this source.
getTypeClass() - Method in class org.apache.crunch.types.avro.AvroGroupedTableType
 
getTypeClass() - Method in class org.apache.crunch.types.avro.AvroType
 
getTypeClass() - Method in interface org.apache.crunch.types.PType
Returns the Java type represented by this PType.
getTypeClass() - Method in class org.apache.crunch.types.writable.WritableGroupedTableType
 
getTypeClass() - Method in class org.apache.crunch.types.writable.WritableType
 
getTypeFamily() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
getTypeFamily() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
getTypeFamily() - Method in interface org.apache.crunch.PCollection
Returns the PTypeFamily of this PCollection.
getValueClass() - Method in class org.apache.crunch.types.avro.AvroKeyConverter
 
getValueClass() - Method in class org.apache.crunch.types.avro.AvroPairConverter
 
getValueClass() - Method in interface org.apache.crunch.types.Converter
 
getValueClass() - Method in class org.apache.crunch.types.writable.WritablePairConverter
 
getValueType() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
getValueType() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
getValueType() - Method in interface org.apache.crunch.PTable
Returns the PType of the value.
getValueType() - Method in class org.apache.crunch.types.avro.AvroTableType
 
getValueType() - Method in interface org.apache.crunch.types.PTableType
Returns the value type for the table.
getWaitingJobList() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
 
getWriter() - Method in class org.apache.crunch.scrunch.ScalaReflectDataFactory
 
getWriter() - Method in class org.apache.crunch.types.avro.ReflectDataFactory
 
groupByKey() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
groupByKey(int) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
groupByKey(GroupingOptions) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
groupByKey() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
groupByKey(int) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
groupByKey(GroupingOptions) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
groupByKey() - Method in interface org.apache.crunch.PTable
Performs a grouping operation on the keys of this table.
groupByKey(int) - Method in interface org.apache.crunch.PTable
Performs a grouping operation on the keys of this table, using the given number of partitions.
groupByKey(GroupingOptions) - Method in interface org.apache.crunch.PTable
Performs a grouping operation on the keys of this table, using the additional GroupingOptions to control how the grouping is executed.
groupingComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.crunch.GroupingOptions.Builder
 
GroupingOptions - Class in org.apache.crunch
Options that can be passed to a groupByKey operation in order to exercise finer control over how the partitioning, grouping, and sorting of keys is performed.
GroupingOptions.Builder - Class in org.apache.crunch
Builder class for creating GroupingOptions instances.
GroupingOptions.Builder() - Constructor for class org.apache.crunch.GroupingOptions.Builder
 

H

has(int) - Method in class org.apache.crunch.types.writable.TupleWritable
Return true if tuple has an element at the position provided.
hasCombineFn() - Method in class org.apache.crunch.impl.mr.collect.DoTableImpl
 
hashCode() - Method in class org.apache.crunch.impl.mr.collect.InputCollection
 
hashCode() - Method in class org.apache.crunch.impl.mr.collect.InputTable
 
hashCode() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
hashCode() - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
hashCode() - Method in class org.apache.crunch.io.hbase.HBaseTarget
 
hashCode() - Method in class org.apache.crunch.io.impl.FileSourceImpl
 
hashCode() - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
hashCode() - Method in class org.apache.crunch.io.impl.InputBundle
 
hashCode() - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
hashCode() - Method in class org.apache.crunch.Pair
 
hashCode() - Method in class org.apache.crunch.Tuple3
 
hashCode() - Method in class org.apache.crunch.Tuple4
 
hashCode() - Method in class org.apache.crunch.TupleN
 
hashCode() - Method in class org.apache.crunch.types.avro.AvroType
 
hashCode() - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
hashCode() - Method in class org.apache.crunch.types.writable.TupleWritable
 
hashCode() - Method in class org.apache.crunch.types.writable.WritableType
 
hasNext() - Method in class org.apache.crunch.io.impl.AutoClosingIterator
 
hasReflect() - Method in class org.apache.crunch.types.avro.AvroType
Determine if the wrapped type is a reflection-based avro type or wraps one.
hasSpecific() - Method in class org.apache.crunch.types.avro.AvroType
Determine if the wrapped type is a specific data avro type or wraps one.
HBaseSourceTarget - Class in org.apache.crunch.io.hbase
 
HBaseSourceTarget(String, Scan) - Constructor for class org.apache.crunch.io.hbase.HBaseSourceTarget
 
HBaseTarget - Class in org.apache.crunch.io.hbase
 
HBaseTarget(String) - Constructor for class org.apache.crunch.io.hbase.HBaseTarget
 

I

IdentityFn<T> - Class in org.apache.crunch.fn
 
initialize() - Method in class org.apache.crunch.DoFn
Called during the setup of the MapReduce job this DoFn is associated with.
initialize() - Method in class org.apache.crunch.fn.CompositeMapFn
 
initialize() - Method in class org.apache.crunch.fn.ExtractKeyFn
 
initialize() - Method in class org.apache.crunch.fn.PairMapFn
 
initialize(CrunchTaskContext) - Method in class org.apache.crunch.impl.mr.run.RTNode
 
initialize() - Method in class org.apache.crunch.lib.Aggregate.TopKFn
 
initialize() - Method in class org.apache.crunch.lib.join.FullOuterJoinFn
Called during the setup of the MapReduce job this DoFn is associated with.
initialize() - Method in class org.apache.crunch.lib.join.InnerJoinFn
Called during the setup of the MapReduce job this DoFn is associated with.
initialize() - Method in class org.apache.crunch.lib.join.LeftOuterJoinFn
Called during the setup of the MapReduce job this DoFn is associated with.
initialize() - Method in class org.apache.crunch.lib.join.RightOuterJoinFn
Called during the setup of the MapReduce job this DoFn is associated with.
initialize() - Method in class org.apache.crunch.lib.Sample.SamplerFn
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
initialize() - Method in class org.apache.crunch.types.PGroupedTableType.PairIterableMapFn
 
initialize() - Method in class org.apache.crunch.types.TupleFactory
 
initialize() - Method in class org.apache.crunch.util.Protos.TextToProtoFn
 
initialize() - Method in class org.apache.crunch.util.PTypes.JacksonInputMapFn
 
initialize() - Method in class org.apache.crunch.util.PTypes.JacksonOutputMapFn
 
initialize() - Method in class org.apache.crunch.util.PTypes.ProtoInputMapFn
 
initialize() - Method in class org.apache.crunch.util.PTypes.ThriftInputMapFn
 
initialize() - Method in class org.apache.crunch.util.PTypes.ThriftOutputMapFn
 
InMemoryEmitter<T> - Class in org.apache.crunch.test
An Emitter instance that writes emitted records to a backing List.
InMemoryEmitter() - Constructor for class org.apache.crunch.test.InMemoryEmitter
 
InMemoryEmitter(List<T>) - Constructor for class org.apache.crunch.test.InMemoryEmitter
 
innerJoin(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
Performs an inner join on the specified PTables.
InnerJoinFn<K,U,V> - Class in org.apache.crunch.lib.join
Used to perform the last step of an inner join.
InnerJoinFn(PType<K>, PType<U>) - Constructor for class org.apache.crunch.lib.join.InnerJoinFn
 
InputBundle - Class in org.apache.crunch.io.impl
A combination of an InputFormat and any configuration information that InputFormat needs to run properly.
InputBundle(Class<? extends InputFormat>) - Constructor for class org.apache.crunch.io.impl.InputBundle
 
InputCollection<S> - Class in org.apache.crunch.impl.mr.collect
 
InputCollection(Source<S>, MRPipeline) - Constructor for class org.apache.crunch.impl.mr.collect.InputCollection
 
InputTable<K,V> - Class in org.apache.crunch.impl.mr.collect
 
InputTable(TableSource<K, V>, MRPipeline) - Constructor for class org.apache.crunch.impl.mr.collect.InputTable
 
IntermediateEmitter - Class in org.apache.crunch.impl.mr.emit
An Emitter implementation that links the output of one DoFn to the input of another DoFn.
IntermediateEmitter(List<RTNode>) - Constructor for class org.apache.crunch.impl.mr.emit.IntermediateEmitter
 
intersection(PCollection<T>, PCollection<T>) - Static method in class org.apache.crunch.lib.Set
Compute the intersection of two sets of elements.
ints() - Static method in class org.apache.crunch.types.avro.Avros
 
ints() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
ints() - Method in interface org.apache.crunch.types.PTypeFamily
 
ints() - Static method in class org.apache.crunch.types.writable.Writables
 
ints() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
isCompatibleWith(GroupingOptions) - Method in class org.apache.crunch.GroupingOptions
 
isCompleted() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
isDebugRun() - Method in class org.apache.crunch.impl.mr.run.CrunchTaskContext
 
isGeneric() - Method in class org.apache.crunch.types.avro.AvroType
Determine if the wrapped type is a generic data avro type.
isInputNode() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
isLeafNode() - Method in class org.apache.crunch.impl.mr.run.RTNode
 
isMapOnlyJob() - Method in class org.apache.crunch.impl.mr.plan.MSCROutputHandler
 
isOutputNode() - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
isReady() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
iterator() - Method in class org.apache.crunch.io.CompositePathIterable
 
iterator() - Method in class org.apache.crunch.materialize.MaterializableIterable
 
iterator() - Method in class org.apache.crunch.util.Tuples.PairIterable
 
iterator() - Method in class org.apache.crunch.util.Tuples.QuadIterable
 
iterator() - Method in class org.apache.crunch.util.Tuples.TripIterable
 
iterator() - Method in class org.apache.crunch.util.Tuples.TupleNIterable
 

J

JobNameBuilder - Class in org.apache.crunch.impl.mr.plan
Visitor that traverses the DoNode instances in a job and builds a String that identifies the stages of the pipeline that belong to this job.
JobNameBuilder(String) - Constructor for class org.apache.crunch.impl.mr.plan.JobNameBuilder
 
JobPrototype - Class in org.apache.crunch.impl.mr.plan
 
join(PTable<K, U>) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
join(PTable<K, U>) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
Join - Class in org.apache.crunch.lib
Utilities for joining multiple PTable instances based on a common lastKey.
Join() - Constructor for class org.apache.crunch.lib.Join
 
join(K, int, Iterable<Pair<U, V>>, Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.FullOuterJoinFn
Performs the actual joining.
join(K, int, Iterable<Pair<U, V>>, Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.InnerJoinFn
Performs the actual joining.
join(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
Performs an inner join on the specified PTables.
join(PTable<K, U>, PTable<K, V>, JoinFn<K, U, V>) - Static method in class org.apache.crunch.lib.Join
 
join(K, int, Iterable<Pair<U, V>>, Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.JoinFn
Performs the actual joining.
join(K, int, Iterable<Pair<U, V>>, Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.LeftOuterJoinFn
Performs the actual joining.
join(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.join.MapsideJoin
Join two tables using a map side join.
join(K, int, Iterable<Pair<U, V>>, Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.RightOuterJoinFn
Performs the actual joining.
join(PTable<K, U>) - Method in interface org.apache.crunch.PTable
Perform an inner join on this table and the one passed in as an argument on their common keys.
JoinFn<K,U,V> - Class in org.apache.crunch.lib.join
Represents a DoFn for performing joins.
JoinFn(PType<K>, PType<U>) - Constructor for class org.apache.crunch.lib.join.JoinFn
Instantiate with the PType of the value of the left side of the join (used for creating deep copies of values).
JoinUtils - Class in org.apache.crunch.lib.join
Utilities that are useful in joining multiple data sets via a MapReduce.
JoinUtils() - Constructor for class org.apache.crunch.lib.join.JoinUtils
 
JoinUtils.AvroIndexedRecordPartitioner<K,V> - Class in org.apache.crunch.lib.join
 
JoinUtils.AvroIndexedRecordPartitioner() - Constructor for class org.apache.crunch.lib.join.JoinUtils.AvroIndexedRecordPartitioner
 
JoinUtils.AvroPairGroupingComparator<T> - Class in org.apache.crunch.lib.join
 
JoinUtils.AvroPairGroupingComparator() - Constructor for class org.apache.crunch.lib.join.JoinUtils.AvroPairGroupingComparator
 
JoinUtils.TupleWritableComparator - Class in org.apache.crunch.lib.join
 
JoinUtils.TupleWritableComparator() - Constructor for class org.apache.crunch.lib.join.JoinUtils.TupleWritableComparator
 
JoinUtils.TupleWritablePartitioner - Class in org.apache.crunch.lib.join
 
JoinUtils.TupleWritablePartitioner() - Constructor for class org.apache.crunch.lib.join.JoinUtils.TupleWritablePartitioner
 
jsons(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
jsons(Class<T>) - Static method in class org.apache.crunch.types.writable.Writables
 
jsonString(Class<T>, PTypeFamily) - Static method in class org.apache.crunch.util.PTypes
 

K

keys() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
keys() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
keys(PTable<K, V>) - Static method in class org.apache.crunch.lib.PTables
 
keys() - Method in interface org.apache.crunch.PTable
Returns a PCollection made up of the keys in this PTable.
killJob() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 

L

LAST_N(int) - Static method in class org.apache.crunch.CombineFn
 
leftJoin(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
Performs a left outer join on the specified PTables.
LeftOuterJoinFn<K,U,V> - Class in org.apache.crunch.lib.join
Used to perform the last step of an left outer join.
LeftOuterJoinFn(PType<K>, PType<U>) - Constructor for class org.apache.crunch.lib.join.LeftOuterJoinFn
 
lineParser(String, Class<M>) - Static method in class org.apache.crunch.util.Protos
 
longs() - Static method in class org.apache.crunch.types.avro.Avros
 
longs() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
longs() - Method in interface org.apache.crunch.types.PTypeFamily
 
longs() - Static method in class org.apache.crunch.types.writable.Writables
 
longs() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 

M

main(String[]) - Static method in class org.apache.crunch.examples.AverageBytesByIP
 
main(String[]) - Static method in class org.apache.crunch.examples.TotalBytesByIP
 
main(String[]) - Static method in class org.apache.crunch.examples.WordAggregationHBase
 
main(String[]) - Static method in class org.apache.crunch.examples.WordCount
 
makeTuple(Object...) - Method in class org.apache.crunch.types.TupleFactory
 
map(R) - Method in class org.apache.crunch.fn.CompositeMapFn
 
map(V) - Method in class org.apache.crunch.fn.ExtractKeyFn
 
map(T) - Method in class org.apache.crunch.fn.IdentityFn
 
map(K1) - Method in class org.apache.crunch.fn.MapKeysFn
 
map(V1) - Method in class org.apache.crunch.fn.MapValuesFn
 
map(Pair<K, V>) - Method in class org.apache.crunch.fn.PairMapFn
 
map(S) - Method in class org.apache.crunch.MapFn
Maps the given input into an instance of the output type.
map(Pair<Object, Iterable<Object>>) - Method in class org.apache.crunch.types.PGroupedTableType.PairIterableMapFn
 
map(M) - Method in class org.apache.crunch.util.Protos.ExtractKeyFn
 
map(String) - Method in class org.apache.crunch.util.PTypes.JacksonInputMapFn
 
map(T) - Method in class org.apache.crunch.util.PTypes.JacksonOutputMapFn
 
map(ByteBuffer) - Method in class org.apache.crunch.util.PTypes.ProtoInputMapFn
 
map(T) - Method in class org.apache.crunch.util.PTypes.ProtoOutputMapFn
 
map(ByteBuffer) - Method in class org.apache.crunch.util.PTypes.ThriftInputMapFn
 
map(T) - Method in class org.apache.crunch.util.PTypes.ThriftOutputMapFn
 
MapDeepCopier<T> - Class in org.apache.crunch.types
 
MapDeepCopier(PType<T>) - Constructor for class org.apache.crunch.types.MapDeepCopier
 
MapFn<S,T> - Class in org.apache.crunch
A DoFn for the common case of emitting exactly one value for each input record.
MapFn() - Constructor for class org.apache.crunch.MapFn
 
MapKeysFn<K1,K2,V> - Class in org.apache.crunch.fn
 
MapKeysFn() - Constructor for class org.apache.crunch.fn.MapKeysFn
 
MapReduceTarget - Interface in org.apache.crunch.io
 
maps(PType<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
maps(PType<T>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
maps(PType<T>) - Method in interface org.apache.crunch.types.PTypeFamily
 
maps(PType<T>) - Static method in class org.apache.crunch.types.writable.Writables
 
maps(PType<T>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
MapsideJoin - Class in org.apache.crunch.lib.join
Utility for doing map side joins on a common key between two PTables.
MapsideJoin() - Constructor for class org.apache.crunch.lib.join.MapsideJoin
 
MapValuesFn<K,V1,V2> - Class in org.apache.crunch.fn
 
MapValuesFn() - Constructor for class org.apache.crunch.fn.MapValuesFn
 
markLogged() - Method in exception org.apache.crunch.impl.mr.run.CrunchRuntimeException
 
MaterializableIterable<E> - Class in org.apache.crunch.materialize
 
MaterializableIterable(Pipeline, ReadableSourceTarget<E>) - Constructor for class org.apache.crunch.materialize.MaterializableIterable
 
MaterializableMap<K,V> - Class in org.apache.crunch.materialize
 
MaterializableMap(Iterable<Pair<K, V>>) - Constructor for class org.apache.crunch.materialize.MaterializableMap
 
materialize() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
materialize(PCollection<T>) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
materialize() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
materialize(PCollection<T>) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
materialize() - Method in class org.apache.crunch.materialize.MaterializableIterable
 
materialize() - Method in interface org.apache.crunch.PCollection
Returns a reference to the data set represented by this PCollection that may be used by the client to read the data locally.
materialize(PCollection<T>) - Method in interface org.apache.crunch.Pipeline
Create the given PCollection and read the data it contains into the returned Collection instance for client use.
materializeAt(SourceTarget<S>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
materializeToMap() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
materializeToMap() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
Returns a Map made up of the keys and values in this PTable.
materializeToMap() - Method in interface org.apache.crunch.PTable
Returns a Map made up of the keys and values in this PTable.
max() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
max() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
max(PCollection<S>) - Static method in class org.apache.crunch.lib.Aggregate
Returns the largest numerical element from the input collection.
max() - Method in interface org.apache.crunch.PCollection
Returns a PCollection made up of only the maximum element of this instance.
MAX_BIGINTS - Static variable in class org.apache.crunch.CombineFn
 
MAX_BIGINTS() - Static method in class org.apache.crunch.CombineFn
 
MAX_BIGINTS(int) - Static method in class org.apache.crunch.CombineFn
 
MAX_DOUBLES - Static variable in class org.apache.crunch.CombineFn
 
MAX_DOUBLES() - Static method in class org.apache.crunch.CombineFn
 
MAX_DOUBLES(int) - Static method in class org.apache.crunch.CombineFn
 
MAX_FLOATS - Static variable in class org.apache.crunch.CombineFn
 
MAX_FLOATS() - Static method in class org.apache.crunch.CombineFn
 
MAX_FLOATS(int) - Static method in class org.apache.crunch.CombineFn
 
MAX_INTS - Static variable in class org.apache.crunch.CombineFn
 
MAX_INTS() - Static method in class org.apache.crunch.CombineFn
 
MAX_INTS(int) - Static method in class org.apache.crunch.CombineFn
 
MAX_LONGS - Static variable in class org.apache.crunch.CombineFn
 
MAX_LONGS() - Static method in class org.apache.crunch.CombineFn
 
MAX_LONGS(int) - Static method in class org.apache.crunch.CombineFn
 
MemCollection<S> - Class in org.apache.crunch.impl.mem.collect
 
MemCollection(Iterable<S>) - Constructor for class org.apache.crunch.impl.mem.collect.MemCollection
 
MemCollection(Iterable<S>, PType<S>) - Constructor for class org.apache.crunch.impl.mem.collect.MemCollection
 
MemCollection(Iterable<S>, PType<S>, String) - Constructor for class org.apache.crunch.impl.mem.collect.MemCollection
 
MemPipeline - Class in org.apache.crunch.impl.mem
 
MemTable<K,V> - Class in org.apache.crunch.impl.mem.collect
 
MemTable(Iterable<Pair<K, V>>) - Constructor for class org.apache.crunch.impl.mem.collect.MemTable
 
MemTable(Iterable<Pair<K, V>>, PTableType<K, V>, String) - Constructor for class org.apache.crunch.impl.mem.collect.MemTable
 
min() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
min() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
min(PCollection<S>) - Static method in class org.apache.crunch.lib.Aggregate
Returns the smallest numerical element from the input collection.
min() - Method in interface org.apache.crunch.PCollection
Returns a PCollection made up of only the minimum element of this instance.
MIN_BIGINTS - Static variable in class org.apache.crunch.CombineFn
 
MIN_BIGINTS() - Static method in class org.apache.crunch.CombineFn
 
MIN_BIGINTS(int) - Static method in class org.apache.crunch.CombineFn
 
MIN_DOUBLES - Static variable in class org.apache.crunch.CombineFn
 
MIN_DOUBLES() - Static method in class org.apache.crunch.CombineFn
 
MIN_DOUBLES(int) - Static method in class org.apache.crunch.CombineFn
 
MIN_FLOATS - Static variable in class org.apache.crunch.CombineFn
 
MIN_FLOATS() - Static method in class org.apache.crunch.CombineFn
 
MIN_FLOATS(int) - Static method in class org.apache.crunch.CombineFn
 
MIN_INTS - Static variable in class org.apache.crunch.CombineFn
 
MIN_INTS() - Static method in class org.apache.crunch.CombineFn
 
MIN_INTS(int) - Static method in class org.apache.crunch.CombineFn
 
MIN_LONGS - Static variable in class org.apache.crunch.CombineFn
 
MIN_LONGS() - Static method in class org.apache.crunch.CombineFn
 
MIN_LONGS(int) - Static method in class org.apache.crunch.CombineFn
 
MRExecutor - Class in org.apache.crunch.impl.mr.exec
 
MRExecutor(Class<?>) - Constructor for class org.apache.crunch.impl.mr.exec.MRExecutor
 
MRPipeline - Class in org.apache.crunch.impl.mr
 
MRPipeline(Class<?>) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
 
MRPipeline(Class<?>, String) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
 
MRPipeline(Class<?>, Configuration) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
 
MRPipeline(Class<?>, String, Configuration) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
 
MSCROutputHandler - Class in org.apache.crunch.impl.mr.plan
 
MSCROutputHandler(Job, Path, boolean) - Constructor for class org.apache.crunch.impl.mr.plan.MSCROutputHandler
 
MSCRPlanner - Class in org.apache.crunch.impl.mr.plan
 
MSCRPlanner(MRPipeline, Map<PCollectionImpl<?>, Set<Target>>) - Constructor for class org.apache.crunch.impl.mr.plan.MSCRPlanner
 
MULTI_INPUTS - Static variable in class org.apache.crunch.impl.mr.run.RuntimeParameters
 
MULTI_OUTPUT_PREFIX - Static variable in class org.apache.crunch.impl.mr.plan.PlanningParameters
 
MultipleOutputEmitter<T,K,V> - Class in org.apache.crunch.impl.mr.emit
 
MultipleOutputEmitter(Converter, CrunchMultipleOutputs<K, V>, String) - Constructor for class org.apache.crunch.impl.mr.emit.MultipleOutputEmitter
 

N

newArrayList() - Static method in class org.apache.crunch.util.Collects
 
newArrayList(T...) - Static method in class org.apache.crunch.util.Collects
 
newArrayList(Iterable<? extends T>) - Static method in class org.apache.crunch.util.Collects
 
newArrayList(Iterator<? extends T>) - Static method in class org.apache.crunch.util.Collects
 
next() - Method in class org.apache.crunch.io.impl.AutoClosingIterator
 
nextKeyValue() - Method in class org.apache.crunch.types.avro.AvroRecordReader
 
NodeContext - Enum in org.apache.crunch.impl.mr.run
Enum that is associated with a serialized DoNode instance, so we know how to use it within the context of a particular MR job.
not(FilterFn<S>) - Static method in class org.apache.crunch.FilterFn
 
nulls() - Static method in class org.apache.crunch.types.avro.Avros
 
nulls() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
nulls() - Method in interface org.apache.crunch.types.PTypeFamily
 
nulls() - Static method in class org.apache.crunch.types.writable.Writables
 
nulls() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
numReducers(int) - Method in class org.apache.crunch.GroupingOptions.Builder
 

O

of(T, U) - Static method in class org.apache.crunch.Pair
 
of(A, B, C) - Static method in class org.apache.crunch.Tuple3
 
of(A, B, C, D) - Static method in class org.apache.crunch.Tuple4
 
or(FilterFn<S>...) - Static method in class org.apache.crunch.FilterFn
 
org.apache.crunch - package org.apache.crunch
 
org.apache.crunch.examples - package org.apache.crunch.examples
 
org.apache.crunch.fn - package org.apache.crunch.fn
 
org.apache.crunch.hadoop.mapreduce.lib.jobcontrol - package org.apache.crunch.hadoop.mapreduce.lib.jobcontrol
 
org.apache.crunch.hadoop.mapreduce.lib.output - package org.apache.crunch.hadoop.mapreduce.lib.output
 
org.apache.crunch.impl.mem - package org.apache.crunch.impl.mem
 
org.apache.crunch.impl.mem.collect - package org.apache.crunch.impl.mem.collect
 
org.apache.crunch.impl.mr - package org.apache.crunch.impl.mr
 
org.apache.crunch.impl.mr.collect - package org.apache.crunch.impl.mr.collect
 
org.apache.crunch.impl.mr.emit - package org.apache.crunch.impl.mr.emit
 
org.apache.crunch.impl.mr.exec - package org.apache.crunch.impl.mr.exec
 
org.apache.crunch.impl.mr.plan - package org.apache.crunch.impl.mr.plan
 
org.apache.crunch.impl.mr.run - package org.apache.crunch.impl.mr.run
 
org.apache.crunch.io - package org.apache.crunch.io
 
org.apache.crunch.io.avro - package org.apache.crunch.io.avro
 
org.apache.crunch.io.hbase - package org.apache.crunch.io.hbase
 
org.apache.crunch.io.impl - package org.apache.crunch.io.impl
 
org.apache.crunch.io.seq - package org.apache.crunch.io.seq
 
org.apache.crunch.io.text - package org.apache.crunch.io.text
 
org.apache.crunch.lib - package org.apache.crunch.lib
 
org.apache.crunch.lib.join - package org.apache.crunch.lib.join
 
org.apache.crunch.materialize - package org.apache.crunch.materialize
 
org.apache.crunch.scrunch - package org.apache.crunch.scrunch
 
org.apache.crunch.test - package org.apache.crunch.test
Provides a collection of test utilities.
org.apache.crunch.tool - package org.apache.crunch.tool
 
org.apache.crunch.types - package org.apache.crunch.types
 
org.apache.crunch.types.avro - package org.apache.crunch.types.avro
 
org.apache.crunch.types.writable - package org.apache.crunch.types.writable
 
org.apache.crunch.util - package org.apache.crunch.util
 
OutputEmitter<T,K,V> - Class in org.apache.crunch.impl.mr.emit
 
OutputEmitter(Converter<K, V, Object, Object>, TaskInputOutputContext<?, ?, K, V>) - Constructor for class org.apache.crunch.impl.mr.emit.OutputEmitter
 
OutputHandler - Interface in org.apache.crunch.io
 
outputKey(K) - Method in class org.apache.crunch.types.avro.AvroKeyConverter
 
outputKey(Pair<K, V>) - Method in class org.apache.crunch.types.avro.AvroPairConverter
 
outputKey(S) - Method in interface org.apache.crunch.types.Converter
 
outputKey(Pair<K, V>) - Method in class org.apache.crunch.types.writable.WritablePairConverter
 
outputValue(K) - Method in class org.apache.crunch.types.avro.AvroKeyConverter
 
outputValue(Pair<K, V>) - Method in class org.apache.crunch.types.avro.AvroPairConverter
 
outputValue(S) - Method in interface org.apache.crunch.types.Converter
 
outputValue(Pair<K, V>) - Method in class org.apache.crunch.types.writable.WritablePairConverter
 
overridePathProperties(Configuration) - Method in class org.apache.crunch.test.TemporaryPath
Set all keys specified in the constructor to temporary directories.

P

Pair<K,V> - Class in org.apache.crunch
A convenience class for two-element Tuples.
Pair(K, V) - Constructor for class org.apache.crunch.Pair
 
PAIR - Static variable in class org.apache.crunch.types.TupleFactory
 
pairAggregator(CombineFn.AggregatorFactory<V1>, CombineFn.AggregatorFactory<V2>) - Static method in class org.apache.crunch.CombineFn
 
PairMapFn<K,V,S,T> - Class in org.apache.crunch.fn
 
PairMapFn(MapFn<K, S>, MapFn<V, T>) - Constructor for class org.apache.crunch.fn.PairMapFn
 
pairs(PType<V1>, PType<V2>) - Static method in class org.apache.crunch.types.avro.Avros
 
pairs(PType<V1>, PType<V2>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
pairs(PType<V1>, PType<V2>) - Method in interface org.apache.crunch.types.PTypeFamily
 
pairs(PType<V1>, PType<V2>) - Static method in class org.apache.crunch.types.writable.Writables
 
pairs(PType<V1>, PType<V2>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
parallelDo(DoFn<S, T>, PType<T>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
parallelDo(String, DoFn<S, T>, PType<T>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
parallelDo(DoFn<S, Pair<K, V>>, PTableType<K, V>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
parallelDo(String, DoFn<S, Pair<K, V>>, PTableType<K, V>) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
parallelDo(DoFn<S, T>, PType<T>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
parallelDo(String, DoFn<S, T>, PType<T>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
parallelDo(DoFn<S, Pair<K, V>>, PTableType<K, V>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
parallelDo(String, DoFn<S, Pair<K, V>>, PTableType<K, V>) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
parallelDo(DoFn<S, T>, PType<T>) - Method in interface org.apache.crunch.PCollection
Applies the given doFn to the elements of this PCollection and returns a new PCollection that is the output of this processing.
parallelDo(String, DoFn<S, T>, PType<T>) - Method in interface org.apache.crunch.PCollection
Applies the given doFn to the elements of this PCollection and returns a new PCollection that is the output of this processing.
parallelDo(DoFn<S, Pair<K, V>>, PTableType<K, V>) - Method in interface org.apache.crunch.PCollection
Similar to the other parallelDo instance, but returns a PTable instance instead of a PCollection.
parallelDo(String, DoFn<S, Pair<K, V>>, PTableType<K, V>) - Method in interface org.apache.crunch.PCollection
Similar to the other parallelDo instance, but returns a PTable instance instead of a PCollection.
partitionerClass(Class<? extends Partitioner>) - Method in class org.apache.crunch.GroupingOptions.Builder
 
PathTarget - Interface in org.apache.crunch.io
 
PathTargetImpl - Class in org.apache.crunch.io
 
PathTargetImpl(String, Class<OutputFormat>, Class, Class) - Constructor for class org.apache.crunch.io.PathTargetImpl
 
PathTargetImpl(Path, Class<OutputFormat>, Class, Class) - Constructor for class org.apache.crunch.io.PathTargetImpl
 
PCollection<S> - Interface in org.apache.crunch
A representation of an immutable, distributed collection of elements that is the fundamental target of computations in Crunch.
PCollectionImpl<S> - Class in org.apache.crunch.impl.mr.collect
 
PCollectionImpl(String) - Constructor for class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
PCollectionImpl.Visitor - Interface in org.apache.crunch.impl.mr.collect
 
PGroupedTable<K,V> - Interface in org.apache.crunch
The Crunch representation of a grouped PTable.
PGroupedTableImpl<K,V> - Class in org.apache.crunch.impl.mr.collect
 
PGroupedTableType<K,V> - Class in org.apache.crunch.types
The PType instance for PGroupedTable instances.
PGroupedTableType(PTableType<K, V>) - Constructor for class org.apache.crunch.types.PGroupedTableType
 
PGroupedTableType.PairIterableMapFn<K,V> - Class in org.apache.crunch.types
 
PGroupedTableType.PairIterableMapFn(MapFn<Object, K>, MapFn<Object, V>) - Constructor for class org.apache.crunch.types.PGroupedTableType.PairIterableMapFn
 
Pipeline - Interface in org.apache.crunch
Manages the state of a pipeline execution.
PipelineResult - Class in org.apache.crunch
Container for the results of a call to run or done on the Pipeline interface that includes details and statistics about the component stages of the data pipeline.
PipelineResult(List<PipelineResult.StageResult>) - Constructor for class org.apache.crunch.PipelineResult
 
PipelineResult.StageResult - Class in org.apache.crunch
 
PipelineResult.StageResult(String, Counters) - Constructor for class org.apache.crunch.PipelineResult.StageResult
 
plan(Class<?>, Configuration) - Method in class org.apache.crunch.impl.mr.plan.MSCRPlanner
 
PlanningParameters - Class in org.apache.crunch.impl.mr.plan
 
process(Pair<K, Iterable<V>>, Emitter<Pair<K, V>>) - Method in class org.apache.crunch.CombineFn.AggregatorCombineFn
 
process(S, Emitter<T>) - Method in class org.apache.crunch.DoFn
Processes the records from a PCollection.
process(T, Emitter<T>) - Method in class org.apache.crunch.FilterFn
 
process(Pair<K1, V>, Emitter<Pair<K2, V>>) - Method in class org.apache.crunch.fn.MapKeysFn
 
process(Pair<K, V1>, Emitter<Pair<K, V2>>) - Method in class org.apache.crunch.fn.MapValuesFn
 
process(Object) - Method in class org.apache.crunch.impl.mr.run.RTNode
 
process(Object, Object) - Method in class org.apache.crunch.impl.mr.run.RTNode
 
process(Pair<Integer, Iterable<Pair<K, V>>>, Emitter<Pair<Integer, Pair<K, V>>>) - Method in class org.apache.crunch.lib.Aggregate.TopKCombineFn
 
process(Pair<K, V>, Emitter<Pair<Integer, Pair<K, V>>>) - Method in class org.apache.crunch.lib.Aggregate.TopKFn
 
process(Pair<Pair<K, Integer>, Iterable<Pair<U, V>>>, Emitter<Pair<K, Pair<U, V>>>) - Method in class org.apache.crunch.lib.join.JoinFn
Split up the input record to make coding a bit more manageable.
process(S, Emitter<S>) - Method in class org.apache.crunch.lib.Sample.SamplerFn
 
process(S, Emitter<T>) - Method in class org.apache.crunch.MapFn
 
process(String, Emitter<M>) - Method in class org.apache.crunch.util.Protos.TextToProtoFn
 
processIterable(Object, Iterable) - Method in class org.apache.crunch.impl.mr.run.RTNode
 
Protos - Class in org.apache.crunch.util
Utility functions for working with protocol buffers in Crunch.
Protos() - Constructor for class org.apache.crunch.util.Protos
 
protos(Class<T>, PTypeFamily) - Static method in class org.apache.crunch.util.PTypes
 
Protos.ExtractKeyFn<M extends com.google.protobuf.Message,K> - Class in org.apache.crunch.util
 
Protos.ExtractKeyFn(String) - Constructor for class org.apache.crunch.util.Protos.ExtractKeyFn
 
Protos.TextToProtoFn<M extends com.google.protobuf.Message> - Class in org.apache.crunch.util
 
Protos.TextToProtoFn(String, Class<M>) - Constructor for class org.apache.crunch.util.Protos.TextToProtoFn
 
PTable<K,V> - Interface in org.apache.crunch
A sub-interface of PCollection that represents an immutable, distributed multi-map of keys and values.
PTableBase<K,V> - Class in org.apache.crunch.impl.mr.collect
 
PTableBase(String) - Constructor for class org.apache.crunch.impl.mr.collect.PTableBase
 
PTables - Class in org.apache.crunch.lib
Methods for performing common operations on PTables.
PTables() - Constructor for class org.apache.crunch.lib.PTables
 
PTableType<K,V> - Interface in org.apache.crunch.types
An extension of PType specifically for PTable objects.
PType<T> - Interface in org.apache.crunch.types
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.
PTypeFamily - Interface in org.apache.crunch.types
An abstract factory for creating PType instances that have the same serialization/storage backing format.
PTypes - Class in org.apache.crunch.util
Utility functions for creating common types of derived PTypes, e.g., for JSON data, protocol buffers, and Thrift records.
PTypes() - Constructor for class org.apache.crunch.util.PTypes
 
PTypes.JacksonInputMapFn<T> - Class in org.apache.crunch.util
 
PTypes.JacksonInputMapFn(Class<T>) - Constructor for class org.apache.crunch.util.PTypes.JacksonInputMapFn
 
PTypes.JacksonOutputMapFn<T> - Class in org.apache.crunch.util
 
PTypes.JacksonOutputMapFn() - Constructor for class org.apache.crunch.util.PTypes.JacksonOutputMapFn
 
PTypes.ProtoInputMapFn<T extends com.google.protobuf.Message> - Class in org.apache.crunch.util
 
PTypes.ProtoInputMapFn(Class<T>) - Constructor for class org.apache.crunch.util.PTypes.ProtoInputMapFn
 
PTypes.ProtoOutputMapFn<T extends com.google.protobuf.Message> - Class in org.apache.crunch.util
 
PTypes.ProtoOutputMapFn() - Constructor for class org.apache.crunch.util.PTypes.ProtoOutputMapFn
 
PTypes.ThriftInputMapFn<T extends org.apache.thrift.TBase> - Class in org.apache.crunch.util
 
PTypes.ThriftInputMapFn(Class<T>) - Constructor for class org.apache.crunch.util.PTypes.ThriftInputMapFn
 
PTypes.ThriftOutputMapFn<T extends org.apache.thrift.TBase> - Class in org.apache.crunch.util
 
PTypes.ThriftOutputMapFn() - Constructor for class org.apache.crunch.util.PTypes.ThriftOutputMapFn
 
PTypeUtils - Class in org.apache.crunch.types
Utilities for converting between PTypes from different PTypeFamily implementations.
put(Text, T) - Method in class org.apache.crunch.types.writable.TextMapWritable
 

Q

quadAggregator(CombineFn.AggregatorFactory<A>, CombineFn.AggregatorFactory<B>, CombineFn.AggregatorFactory<C>, CombineFn.AggregatorFactory<D>) - Static method in class org.apache.crunch.CombineFn
 
quads(PType<V1>, PType<V2>, PType<V3>, PType<V4>) - Static method in class org.apache.crunch.types.avro.Avros
 
quads(PType<V1>, PType<V2>, PType<V3>, PType<V4>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
quads(PType<V1>, PType<V2>, PType<V3>, PType<V4>) - Method in interface org.apache.crunch.types.PTypeFamily
 
quads(PType<V1>, PType<V2>, PType<V3>, PType<V4>) - Static method in class org.apache.crunch.types.writable.Writables
 
quads(PType<V1>, PType<V2>, PType<V3>, PType<V4>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 

R

read(Source<T>) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
read(TableSource<K, V>) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
read(Source<S>) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
read(TableSource<K, V>) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
read(FileSystem, Path) - Method in class org.apache.crunch.io.avro.AvroFileReaderFactory
 
read(Configuration) - Method in class org.apache.crunch.io.avro.AvroFileSource
 
read(FileSystem, Path) - Method in interface org.apache.crunch.io.FileReaderFactory
 
read(Configuration) - Method in class org.apache.crunch.io.impl.ReadableSourcePathTargetImpl
 
read(Configuration) - Method in class org.apache.crunch.io.impl.ReadableSourceTargetImpl
 
read(Configuration) - Method in interface org.apache.crunch.io.ReadableSource
 
read(FileSystem, Path) - Method in class org.apache.crunch.io.seq.SeqFileReaderFactory
 
read(Configuration) - Method in class org.apache.crunch.io.seq.SeqFileSource
 
read(FileSystem, Path) - Method in class org.apache.crunch.io.seq.SeqFileTableReaderFactory
 
read(Configuration) - Method in class org.apache.crunch.io.seq.SeqFileTableSource
 
read() - Method in class org.apache.crunch.io.text.CBZip2InputStream
 
read(FileSystem, Path) - Method in class org.apache.crunch.io.text.TextFileReaderFactory
 
read(Configuration) - Method in class org.apache.crunch.io.text.TextFileSource
 
read(Source<T>) - Method in interface org.apache.crunch.Pipeline
Converts the given Source into a PCollection that is available to jobs run using this Pipeline instance.
read(TableSource<K, V>) - Method in interface org.apache.crunch.Pipeline
A version of the read method for TableSource instances that map to PTables.
read(Source<T>) - Method in class org.apache.crunch.tool.CrunchTool
 
read(TableSource<K, V>) - Method in class org.apache.crunch.tool.CrunchTool
 
read(Configuration, Path) - Static method in class org.apache.crunch.util.DistCache
 
ReadableSource<T> - Interface in org.apache.crunch.io
 
ReadableSourcePathTargetImpl<T> - Class in org.apache.crunch.io.impl
 
ReadableSourcePathTargetImpl(ReadableSource<T>, PathTarget) - Constructor for class org.apache.crunch.io.impl.ReadableSourcePathTargetImpl
 
ReadableSourceTarget<T> - Interface in org.apache.crunch.io
An interface that indicates that a SourceTarget instance can be read into the local client.
ReadableSourceTargetImpl<T> - Class in org.apache.crunch.io.impl
 
ReadableSourceTargetImpl(ReadableSource<T>, Target) - Constructor for class org.apache.crunch.io.impl.ReadableSourceTargetImpl
 
readFields(DataInput) - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
readFields(DataInput) - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
readFields(DataInput) - Method in class org.apache.crunch.types.writable.TextMapWritable
 
readFields(DataInput) - Method in class org.apache.crunch.types.writable.TupleWritable
readTextFile(String) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
readTextFile(String) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
readTextFile(String) - Method in interface org.apache.crunch.Pipeline
A convenience method for reading a text file.
readTextFile(String) - Method in class org.apache.crunch.tool.CrunchTool
 
records(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
records(Class<T>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
records(Class<T>) - Method in interface org.apache.crunch.types.PTypeFamily
 
records(Class<T>) - Static method in class org.apache.crunch.types.writable.Writables
 
records(Class<T>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
REFLECT_DATA_FACTORY - Static variable in class org.apache.crunch.types.avro.Avros
The instance we use for generating reflected schemas.
REFLECT_DATA_FACTORY_CLASS - Static variable in class org.apache.crunch.types.avro.Avros
The name of the configuration parameter that tracks which reflection factory to use.
ReflectDataFactory - Class in org.apache.crunch.types.avro
A Factory class for constructing Avro reflection-related objects.
ReflectDataFactory() - Constructor for class org.apache.crunch.types.avro.ReflectDataFactory
 
reflects(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
register(Class<T>, AvroType<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
register(Class<T>, WritableType<T, ? extends Writable>) - Static method in class org.apache.crunch.types.writable.Writables
 
reset() - Method in interface org.apache.crunch.CombineFn.Aggregator
Clears the internal state of this Aggregator and prepares it for the values associated with the next key.
reset() - Method in class org.apache.crunch.CombineFn.FirstNAggregator
 
reset() - Method in class org.apache.crunch.CombineFn.LastNAggregator
 
reset() - Method in class org.apache.crunch.CombineFn.MaxBigInts
 
reset() - Method in class org.apache.crunch.CombineFn.MaxDoubles
 
reset() - Method in class org.apache.crunch.CombineFn.MaxFloats
 
reset() - Method in class org.apache.crunch.CombineFn.MaxInts
 
reset() - Method in class org.apache.crunch.CombineFn.MaxLongs
 
reset() - Method in class org.apache.crunch.CombineFn.MaxNAggregator
 
reset() - Method in class org.apache.crunch.CombineFn.MinBigInts
 
reset() - Method in class org.apache.crunch.CombineFn.MinDoubles
 
reset() - Method in class org.apache.crunch.CombineFn.MinFloats
 
reset() - Method in class org.apache.crunch.CombineFn.MinInts
 
reset() - Method in class org.apache.crunch.CombineFn.MinLongs
 
reset() - Method in class org.apache.crunch.CombineFn.MinNAggregator
 
reset() - Method in class org.apache.crunch.CombineFn.StringConcatAggregator
 
reset() - Method in class org.apache.crunch.CombineFn.SumBigInts
 
reset() - Method in class org.apache.crunch.CombineFn.SumDoubles
 
reset() - Method in class org.apache.crunch.CombineFn.SumFloats
 
reset() - Method in class org.apache.crunch.CombineFn.SumInts
 
reset() - Method in class org.apache.crunch.CombineFn.SumLongs
 
results() - Method in interface org.apache.crunch.CombineFn.Aggregator
Returns the current aggregated state of this instance.
results() - Method in class org.apache.crunch.CombineFn.FirstNAggregator
 
results() - Method in class org.apache.crunch.CombineFn.LastNAggregator
 
results() - Method in class org.apache.crunch.CombineFn.MaxBigInts
 
results() - Method in class org.apache.crunch.CombineFn.MaxDoubles
 
results() - Method in class org.apache.crunch.CombineFn.MaxFloats
 
results() - Method in class org.apache.crunch.CombineFn.MaxInts
 
results() - Method in class org.apache.crunch.CombineFn.MaxLongs
 
results() - Method in class org.apache.crunch.CombineFn.MaxNAggregator
 
results() - Method in class org.apache.crunch.CombineFn.MinBigInts
 
results() - Method in class org.apache.crunch.CombineFn.MinDoubles
 
results() - Method in class org.apache.crunch.CombineFn.MinFloats
 
results() - Method in class org.apache.crunch.CombineFn.MinInts
 
results() - Method in class org.apache.crunch.CombineFn.MinLongs
 
results() - Method in class org.apache.crunch.CombineFn.MinNAggregator
 
results() - Method in class org.apache.crunch.CombineFn.PairAggregator
 
results() - Method in class org.apache.crunch.CombineFn.QuadAggregator
 
results() - Method in class org.apache.crunch.CombineFn.StringConcatAggregator
 
results() - Method in class org.apache.crunch.CombineFn.SumBigInts
 
results() - Method in class org.apache.crunch.CombineFn.SumDoubles
 
results() - Method in class org.apache.crunch.CombineFn.SumFloats
 
results() - Method in class org.apache.crunch.CombineFn.SumInts
 
results() - Method in class org.apache.crunch.CombineFn.SumLongs
 
results() - Method in class org.apache.crunch.CombineFn.TripAggregator
 
results() - Method in class org.apache.crunch.CombineFn.TupleNAggregator
 
resume() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
resume the suspended thread
rightJoin(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
Performs a right outer join on the specified PTables.
RightOuterJoinFn<K,U,V> - Class in org.apache.crunch.lib.join
Used to perform the last step of an right outer join.
RightOuterJoinFn(PType<K>, PType<U>) - Constructor for class org.apache.crunch.lib.join.RightOuterJoinFn
 
RTNode - Class in org.apache.crunch.impl.mr.run
 
RTNode(DoFn<Object, Object>, String, List<RTNode>, Converter, Converter, String) - Constructor for class org.apache.crunch.impl.mr.run.RTNode
 
run(String[]) - Method in class org.apache.crunch.examples.AverageBytesByIP
 
run(String[]) - Method in class org.apache.crunch.examples.TotalBytesByIP
 
run(String[]) - Method in class org.apache.crunch.examples.WordAggregationHBase
 
run(String[]) - Method in class org.apache.crunch.examples.WordCount
 
run() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
The main loop for the thread.
run() - Method in class org.apache.crunch.impl.mem.MemPipeline
 
run() - Method in class org.apache.crunch.impl.mr.MRPipeline
 
run() - Method in interface org.apache.crunch.Pipeline
Constructs and executes a series of MapReduce jobs in order to write data to the output targets.
run() - Method in class org.apache.crunch.tool.CrunchTool
 
RuntimeParameters - Class in org.apache.crunch.impl.mr.run
Parameters used during the runtime execution.

S

SafeAvroSerialization<T> - Class in org.apache.crunch.types.avro
The Serialization used by jobs configured with AvroJob.
SafeAvroSerialization() - Constructor for class org.apache.crunch.types.avro.SafeAvroSerialization
 
sample(double) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
sample(double, long) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
sample(double) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
sample(double, long) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
Sample - Class in org.apache.crunch.lib
 
Sample() - Constructor for class org.apache.crunch.lib.Sample
 
sample(PCollection<S>, double) - Static method in class org.apache.crunch.lib.Sample
 
sample(PCollection<S>, long, double) - Static method in class org.apache.crunch.lib.Sample
 
sample(double) - Method in interface org.apache.crunch.PCollection
Randomly sample items from this PCollection instance with the given probability of an item being accepted.
sample(double, long) - Method in interface org.apache.crunch.PCollection
Randomly sample items from this PCollection instance with the given probability of an item being accepted and using the given seed.
Sample.SamplerFn<S> - Class in org.apache.crunch.lib
 
Sample.SamplerFn(long, double) - Constructor for class org.apache.crunch.lib.Sample.SamplerFn
 
scalaIterableCheck(Object, Schema) - Static method in class org.apache.crunch.scrunch.ScalaSafeReflectDatumReader
 
scalaMapCheck(Object, Schema) - Static method in class org.apache.crunch.scrunch.ScalaSafeReflectDatumReader
 
ScalaReflectDataFactory - Class in org.apache.crunch.scrunch
An implementation of the ReflectDataFactory class to work with Scala classes.
ScalaReflectDataFactory() - Constructor for class org.apache.crunch.scrunch.ScalaReflectDataFactory
 
ScalaSafeReflectData - Class in org.apache.crunch.scrunch
Scala-oriented support class for serialization via reflection.
ScalaSafeReflectData() - Constructor for class org.apache.crunch.scrunch.ScalaSafeReflectData
 
ScalaSafeReflectDatumReader<T> - Class in org.apache.crunch.scrunch
 
ScalaSafeReflectDatumReader(Schema) - Constructor for class org.apache.crunch.scrunch.ScalaSafeReflectDatumReader
 
ScalaSafeReflectDatumWriter<T> - Class in org.apache.crunch.scrunch
 
ScalaSafeReflectDatumWriter() - Constructor for class org.apache.crunch.scrunch.ScalaSafeReflectDatumWriter
 
scaleFactor() - Method in class org.apache.crunch.DoFn
Returns an estimate of how applying this function to a PCollection will cause it to change in side.
scaleFactor() - Method in class org.apache.crunch.FilterFn.AndFn
 
scaleFactor() - Method in class org.apache.crunch.FilterFn.NotFn
 
scaleFactor() - Method in class org.apache.crunch.FilterFn.OrFn
 
scaleFactor() - Method in class org.apache.crunch.FilterFn
 
scaleFactor() - Method in class org.apache.crunch.MapFn
 
second() - Method in class org.apache.crunch.Pair
 
second() - Method in class org.apache.crunch.Tuple3
 
second() - Method in class org.apache.crunch.Tuple4
 
SeqFileHelper - Class in org.apache.crunch.io.seq
 
SeqFileHelper() - Constructor for class org.apache.crunch.io.seq.SeqFileHelper
 
SeqFileReaderFactory<T> - Class in org.apache.crunch.io.seq
 
SeqFileReaderFactory(PType<T>, Configuration) - Constructor for class org.apache.crunch.io.seq.SeqFileReaderFactory
 
SeqFileSource<T> - Class in org.apache.crunch.io.seq
 
SeqFileSource(Path, PType<T>) - Constructor for class org.apache.crunch.io.seq.SeqFileSource
 
SeqFileSourceTarget<T> - Class in org.apache.crunch.io.seq
 
SeqFileSourceTarget(String, PType<T>) - Constructor for class org.apache.crunch.io.seq.SeqFileSourceTarget
 
SeqFileSourceTarget(Path, PType<T>) - Constructor for class org.apache.crunch.io.seq.SeqFileSourceTarget
 
SeqFileTableReaderFactory<K,V> - Class in org.apache.crunch.io.seq
 
SeqFileTableReaderFactory(PTableType<K, V>, Configuration) - Constructor for class org.apache.crunch.io.seq.SeqFileTableReaderFactory
 
SeqFileTableSource<K,V> - Class in org.apache.crunch.io.seq
 
SeqFileTableSource(String, PTableType<K, V>) - Constructor for class org.apache.crunch.io.seq.SeqFileTableSource
 
SeqFileTableSource(Path, PTableType<K, V>) - Constructor for class org.apache.crunch.io.seq.SeqFileTableSource
 
SeqFileTableSourceTarget<K,V> - Class in org.apache.crunch.io.seq
 
SeqFileTableSourceTarget(String, PTableType<K, V>) - Constructor for class org.apache.crunch.io.seq.SeqFileTableSourceTarget
 
SeqFileTableSourceTarget(Path, PTableType<K, V>) - Constructor for class org.apache.crunch.io.seq.SeqFileTableSourceTarget
 
SeqFileTarget - Class in org.apache.crunch.io.seq
 
SeqFileTarget(String) - Constructor for class org.apache.crunch.io.seq.SeqFileTarget
 
SeqFileTarget(Path) - Constructor for class org.apache.crunch.io.seq.SeqFileTarget
 
sequenceFile(String, PType<T>) - Static method in class org.apache.crunch.io.At
 
sequenceFile(Path, PType<T>) - Static method in class org.apache.crunch.io.At
 
sequenceFile(String, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.At
 
sequenceFile(Path, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.At
 
sequenceFile(String, PType<T>) - Static method in class org.apache.crunch.io.From
 
sequenceFile(Path, PType<T>) - Static method in class org.apache.crunch.io.From
 
sequenceFile(String, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
 
sequenceFile(Path, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
 
sequenceFile(String) - Static method in class org.apache.crunch.io.To
 
sequenceFile(Path) - Static method in class org.apache.crunch.io.To
 
serialize() - Method in class org.apache.crunch.io.impl.InputBundle
 
set(String, String) - Method in class org.apache.crunch.io.impl.InputBundle
 
Set - Class in org.apache.crunch.lib
Utilities for performing set operations (difference, intersection, etc) on PCollection instances.
Set() - Constructor for class org.apache.crunch.lib.Set
 
set(Writable[]) - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
setConf(Configuration) - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
setConf(Configuration) - Method in class org.apache.crunch.lib.join.JoinUtils.AvroPairGroupingComparator
 
setConf(Configuration) - Method in class org.apache.crunch.tool.CrunchTool
 
setConfiguration(Configuration) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
setConfiguration(Configuration) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
setConfiguration(Configuration) - Method in interface org.apache.crunch.Pipeline
Set the Configuration to use with this pipeline.
setConfigurationForTest(Configuration) - Method in class org.apache.crunch.DoFn
Sets a Configuration instance to be used during unit tests.
setConfigurationForTest(Configuration) - Method in class org.apache.crunch.fn.CompositeMapFn
 
setConfigurationForTest(Configuration) - Method in class org.apache.crunch.fn.PairMapFn
 
setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.DoFn
Called during setup to pass the TaskInputOutputContext to this DoFn instance.
setCountersEnabled(Job, boolean) - Static method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Enables or disables counters for the named outputs.
setJob(Job) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Set the mapreduce job
setJobID(String) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Set the job ID for this job.
setJobName(String) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Set the job name for this job.
setMessage(String) - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
Set the message for this job.
setOutputName(String) - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
setReadLimit(long) - Method in class org.apache.crunch.io.text.CBZip2InputStream
 
setWritten(int) - Method in class org.apache.crunch.types.writable.TupleWritable
Record that the tuple contains an element at the position provided.
size() - Method in class org.apache.crunch.Pair
 
size() - Method in interface org.apache.crunch.Tuple
Returns the number of elements in this Tuple.
size() - Method in class org.apache.crunch.Tuple3
 
size() - Method in class org.apache.crunch.Tuple4
 
size() - Method in class org.apache.crunch.TupleN
 
size() - Method in class org.apache.crunch.types.writable.TupleWritable
The number of children in this Tuple.
sort(boolean) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
sort(boolean) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
Sort - Class in org.apache.crunch.lib
Utilities for sorting PCollection instances.
Sort() - Constructor for class org.apache.crunch.lib.Sort
 
sort(PCollection<T>) - Static method in class org.apache.crunch.lib.Sort
Sorts the PCollection using the natural ordering of its elements.
sort(PCollection<T>, Sort.Order) - Static method in class org.apache.crunch.lib.Sort
Sorts the PCollection using the natural ordering of its elements in the order specified.
sort(PTable<K, V>) - Static method in class org.apache.crunch.lib.Sort
Sorts the PTable using the natural ordering of its keys.
sort(PTable<K, V>, Sort.Order) - Static method in class org.apache.crunch.lib.Sort
Sorts the PTable using the natural ordering of its keys in the order specified.
sort(boolean) - Method in interface org.apache.crunch.PCollection
Returns a PCollection instance that contains all of the elements of this instance in sorted order.
Sort.ColumnOrder - Class in org.apache.crunch.lib
To sort by column 2 ascending then column 1 descending, you would use: sortPairs(coll, by(2, ASCENDING), by(1, DESCENDING)) Column numbering is 1-based.
Sort.ColumnOrder(int, Sort.Order) - Constructor for class org.apache.crunch.lib.Sort.ColumnOrder
 
Sort.Order - Enum in org.apache.crunch.lib
 
sortComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.crunch.GroupingOptions.Builder
 
sortPairs(PCollection<Pair<U, V>>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
Sorts the PCollection of Pairs using the specified column ordering.
sortQuads(PCollection<Tuple4<V1, V2, V3, V4>>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
Sorts the PCollection of Tuple4s using the specified column ordering.
sortTriples(PCollection<Tuple3<V1, V2, V3>>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
Sorts the PCollection of Tuple3s using the specified column ordering.
sortTuples(PCollection<TupleN>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
Sorts the PCollection of TupleNs using the specified column ordering.
Source<T> - Interface in org.apache.crunch
A Source represents an input data set that is an input to one or more MapReduce jobs.
SourcePathTargetImpl<T> - Class in org.apache.crunch.io.impl
 
SourcePathTargetImpl(Source<T>, PathTarget) - Constructor for class org.apache.crunch.io.impl.SourcePathTargetImpl
 
SourceTarget<T> - Interface in org.apache.crunch
An interface for classes that implement both the Source and the Target interfaces.
SourceTargetHelper - Class in org.apache.crunch.io
Functions for configuring the inputs/outputs of MapReduce jobs.
SourceTargetHelper() - Constructor for class org.apache.crunch.io.SourceTargetHelper
 
SourceTargetImpl<T> - Class in org.apache.crunch.io.impl
 
SourceTargetImpl(Source<T>, Target) - Constructor for class org.apache.crunch.io.impl.SourceTargetImpl
 
specifics(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
stop() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
set the thread state to STOPPING so that the thread will stop when it wakes up.
STRING_CONCAT(String, boolean) - Static method in class org.apache.crunch.CombineFn
Used to concatenate strings, with a separator between each strings.
STRING_CONCAT(String, boolean, long, long) - Static method in class org.apache.crunch.CombineFn
Used to concatenate strings, with a separator between each strings.
STRING_TO_UTF8 - Static variable in class org.apache.crunch.types.avro.Avros
 
strings() - Static method in class org.apache.crunch.types.avro.Avros
 
strings() - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
strings() - Method in interface org.apache.crunch.types.PTypeFamily
 
strings() - Static method in class org.apache.crunch.types.writable.Writables
 
strings() - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
succeeded() - Method in class org.apache.crunch.PipelineResult
 
SUM_BIGINTS - Static variable in class org.apache.crunch.CombineFn
 
SUM_BIGINTS() - Static method in class org.apache.crunch.CombineFn
 
SUM_DOUBLES - Static variable in class org.apache.crunch.CombineFn
 
SUM_DOUBLES() - Static method in class org.apache.crunch.CombineFn
 
SUM_FLOATS - Static variable in class org.apache.crunch.CombineFn
 
SUM_FLOATS() - Static method in class org.apache.crunch.CombineFn
 
SUM_INTS - Static variable in class org.apache.crunch.CombineFn
 
SUM_INTS() - Static method in class org.apache.crunch.CombineFn
 
SUM_LONGS - Static variable in class org.apache.crunch.CombineFn
 
SUM_LONGS() - Static method in class org.apache.crunch.CombineFn
 
suspend() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl
suspend the running thread

T

table(String) - Static method in class org.apache.crunch.io.hbase.AtHBase
 
table(String, Scan) - Static method in class org.apache.crunch.io.hbase.AtHBase
 
table(String) - Static method in class org.apache.crunch.io.hbase.FromHBase
 
table(String, Scan) - Static method in class org.apache.crunch.io.hbase.FromHBase
 
table(String) - Static method in class org.apache.crunch.io.hbase.ToHBase
 
tableOf(S, T, Object...) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
tableOf(Iterable<Pair<S, T>>) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
tableOf(PType<K>, PType<V>) - Static method in class org.apache.crunch.types.avro.Avros
 
tableOf(PType<K>, PType<V>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
tableOf(PType<K>, PType<V>) - Method in interface org.apache.crunch.types.PTypeFamily
 
tableOf(PType<K>, PType<V>) - Static method in class org.apache.crunch.types.writable.Writables
 
tableOf(PType<K>, PType<V>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
TableSource<K,V> - Interface in org.apache.crunch
The interface Source implementations that return a PTable.
TableSourcePathTargetImpl<K,V> - Class in org.apache.crunch.io.impl
 
TableSourcePathTargetImpl(TableSource<K, V>, PathTarget) - Constructor for class org.apache.crunch.io.impl.TableSourcePathTargetImpl
 
TableSourceTargetImpl<K,V> - Class in org.apache.crunch.io.impl
 
TableSourceTargetImpl(TableSource<K, V>, Target) - Constructor for class org.apache.crunch.io.impl.TableSourceTargetImpl
 
Target - Interface in org.apache.crunch
A Target represents the output destination of a Crunch job.
TaskAttemptContextFactory - Class in org.apache.crunch.impl.mr.run
 
tempDir - Variable in class org.apache.crunch.test.CrunchTestSupport
 
TemporaryPath - Class in org.apache.crunch.test
Creates a temporary directory for a test case and destroys it afterwards.
TemporaryPath(String...) - Constructor for class org.apache.crunch.test.TemporaryPath
Construct TemporaryPath.
TestCounters - Class in org.apache.crunch.test
A utility class used during unit testing to update and read counters.
TestCounters() - Constructor for class org.apache.crunch.test.TestCounters
 
textFile(String) - Static method in class org.apache.crunch.io.At
 
textFile(Path) - Static method in class org.apache.crunch.io.At
 
textFile(String, PType<T>) - Static method in class org.apache.crunch.io.At
 
textFile(Path, PType<T>) - Static method in class org.apache.crunch.io.At
 
textFile(String) - Static method in class org.apache.crunch.io.From
 
textFile(Path) - Static method in class org.apache.crunch.io.From
 
textFile(String, PType<T>) - Static method in class org.apache.crunch.io.From
 
textFile(Path, PType<T>) - Static method in class org.apache.crunch.io.From
 
textFile(String) - Static method in class org.apache.crunch.io.To
 
textFile(Path) - Static method in class org.apache.crunch.io.To
 
TextFileReaderFactory<T> - Class in org.apache.crunch.io.text
 
TextFileReaderFactory(PType<T>, Configuration) - Constructor for class org.apache.crunch.io.text.TextFileReaderFactory
 
TextFileSource<T> - Class in org.apache.crunch.io.text
 
TextFileSource(Path, PType<T>) - Constructor for class org.apache.crunch.io.text.TextFileSource
 
TextFileSourceTarget<T> - Class in org.apache.crunch.io.text
 
TextFileSourceTarget(String, PType<T>) - Constructor for class org.apache.crunch.io.text.TextFileSourceTarget
 
TextFileSourceTarget(Path, PType<T>) - Constructor for class org.apache.crunch.io.text.TextFileSourceTarget
 
TextFileTarget - Class in org.apache.crunch.io.text
 
TextFileTarget(String) - Constructor for class org.apache.crunch.io.text.TextFileTarget
 
TextFileTarget(Path) - Constructor for class org.apache.crunch.io.text.TextFileTarget
 
TextMapWritable<T extends org.apache.hadoop.io.Writable> - Class in org.apache.crunch.types.writable
 
TextMapWritable() - Constructor for class org.apache.crunch.types.writable.TextMapWritable
 
TextMapWritable(Class<T>) - Constructor for class org.apache.crunch.types.writable.TextMapWritable
 
third() - Method in class org.apache.crunch.Tuple3
 
third() - Method in class org.apache.crunch.Tuple4
 
thrifts(Class<T>, PTypeFamily) - Static method in class org.apache.crunch.util.PTypes
 
TMP_DIR - Static variable in class org.apache.crunch.impl.mr.run.RuntimeParameters
 
To - Class in org.apache.crunch.io
Static factory methods for creating various Target types.
To() - Constructor for class org.apache.crunch.io.To
 
ToHBase - Class in org.apache.crunch.io.hbase
Static factory methods for creating HBase Target types.
ToHBase() - Constructor for class org.apache.crunch.io.hbase.ToHBase
 
top(int) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
top(int) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
top(PTable<K, V>, int, boolean) - Static method in class org.apache.crunch.lib.Aggregate
 
top(int) - Method in interface org.apache.crunch.PTable
Returns a PTable made up of the pairs in this PTable with the largest value field.
toRTNode(boolean, Configuration, NodeContext) - Method in class org.apache.crunch.impl.mr.plan.DoNode
 
toString() - Method in class org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob
 
toString() - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
toString() - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
toString() - Method in class org.apache.crunch.impl.mr.run.RTNode
 
toString() - Method in class org.apache.crunch.io.avro.AvroFileSource
 
toString() - Method in class org.apache.crunch.io.avro.AvroFileSourceTarget
 
toString() - Method in class org.apache.crunch.io.avro.AvroFileTarget
 
toString() - Method in class org.apache.crunch.io.hbase.HBaseSourceTarget
 
toString() - Method in class org.apache.crunch.io.hbase.HBaseTarget
 
toString() - Method in class org.apache.crunch.io.impl.FileSourceImpl
 
toString() - Method in class org.apache.crunch.io.impl.FileTargetImpl
 
toString() - Method in class org.apache.crunch.io.impl.SourceTargetImpl
 
toString() - Method in class org.apache.crunch.io.seq.SeqFileSource
 
toString() - Method in class org.apache.crunch.io.seq.SeqFileSourceTarget
 
toString() - Method in class org.apache.crunch.io.seq.SeqFileTableSource
 
toString() - Method in class org.apache.crunch.io.seq.SeqFileTableSourceTarget
 
toString() - Method in class org.apache.crunch.io.seq.SeqFileTarget
 
toString() - Method in class org.apache.crunch.io.text.TextFileSource
 
toString() - Method in class org.apache.crunch.io.text.TextFileSourceTarget
 
toString() - Method in class org.apache.crunch.io.text.TextFileTarget
 
toString() - Method in class org.apache.crunch.lib.Sort.ColumnOrder
 
toString() - Method in class org.apache.crunch.Pair
 
toString() - Method in class org.apache.crunch.Tuple3
 
toString() - Method in class org.apache.crunch.Tuple4
 
toString() - Method in class org.apache.crunch.TupleN
 
toString() - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
toString() - Method in class org.apache.crunch.types.writable.TupleWritable
Convert Tuple to String as in the following.
TotalBytesByIP - Class in org.apache.crunch.examples
 
TotalBytesByIP() - Constructor for class org.apache.crunch.examples.TotalBytesByIP
 
tripAggregator(CombineFn.AggregatorFactory<A>, CombineFn.AggregatorFactory<B>, CombineFn.AggregatorFactory<C>) - Static method in class org.apache.crunch.CombineFn
 
triples(PType<V1>, PType<V2>, PType<V3>) - Static method in class org.apache.crunch.types.avro.Avros
 
triples(PType<V1>, PType<V2>, PType<V3>) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
triples(PType<V1>, PType<V2>, PType<V3>) - Method in interface org.apache.crunch.types.PTypeFamily
 
triples(PType<V1>, PType<V2>, PType<V3>) - Static method in class org.apache.crunch.types.writable.Writables
 
triples(PType<V1>, PType<V2>, PType<V3>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
Tuple - Interface in org.apache.crunch
A fixed-size collection of Objects, used in Crunch for representing joins between PCollections.
Tuple3<V1,V2,V3> - Class in org.apache.crunch
A convenience class for three-element Tuples.
Tuple3(V1, V2, V3) - Constructor for class org.apache.crunch.Tuple3
 
TUPLE3 - Static variable in class org.apache.crunch.types.TupleFactory
 
Tuple4<V1,V2,V3,V4> - Class in org.apache.crunch
A convenience class for four-element Tuples.
Tuple4(V1, V2, V3, V4) - Constructor for class org.apache.crunch.Tuple4
 
TUPLE4 - Static variable in class org.apache.crunch.types.TupleFactory
 
tupleAggregator(CombineFn.AggregatorFactory<?>...) - Static method in class org.apache.crunch.CombineFn
 
TupleDeepCopier<T extends Tuple> - Class in org.apache.crunch.types
Performs deep copies (based on underlying PType deep copying) of Tuple-based objects.
TupleDeepCopier(Class<T>, PType...) - Constructor for class org.apache.crunch.types.TupleDeepCopier
 
TupleFactory<T extends Tuple> - Class in org.apache.crunch.types
 
TupleFactory() - Constructor for class org.apache.crunch.types.TupleFactory
 
TupleN - Class in org.apache.crunch
A Tuple instance for an arbitrary number of values.
TupleN(Object...) - Constructor for class org.apache.crunch.TupleN
 
TUPLEN - Static variable in class org.apache.crunch.types.TupleFactory
 
tuples(PType...) - Static method in class org.apache.crunch.types.avro.Avros
 
tuples(Class<T>, PType...) - Static method in class org.apache.crunch.types.avro.Avros
 
tuples(PType<?>...) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
tuples(Class<T>, PType<?>...) - Method in class org.apache.crunch.types.avro.AvroTypeFamily
 
tuples(PType<?>...) - Method in interface org.apache.crunch.types.PTypeFamily
 
tuples(Class<T>, PType<?>...) - Method in interface org.apache.crunch.types.PTypeFamily
 
tuples(PType...) - Static method in class org.apache.crunch.types.writable.Writables
 
tuples(Class<T>, PType...) - Static method in class org.apache.crunch.types.writable.Writables
 
tuples(PType<?>...) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
tuples(Class<T>, PType<?>...) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
Tuples - Class in org.apache.crunch.util
Utilities for working with subclasses of the Tuple interface.
Tuples() - Constructor for class org.apache.crunch.util.Tuples
 
Tuples.PairIterable<S,T> - Class in org.apache.crunch.util
 
Tuples.PairIterable(Iterable<S>, Iterable<T>) - Constructor for class org.apache.crunch.util.Tuples.PairIterable
 
Tuples.QuadIterable<A,B,C,D> - Class in org.apache.crunch.util
 
Tuples.QuadIterable(Iterable<A>, Iterable<B>, Iterable<C>, Iterable<D>) - Constructor for class org.apache.crunch.util.Tuples.QuadIterable
 
Tuples.TripIterable<A,B,C> - Class in org.apache.crunch.util
 
Tuples.TripIterable(Iterable<A>, Iterable<B>, Iterable<C>) - Constructor for class org.apache.crunch.util.Tuples.TripIterable
 
Tuples.TupleNIterable - Class in org.apache.crunch.util
 
Tuples.TupleNIterable(Iterable<?>...) - Constructor for class org.apache.crunch.util.Tuples.TupleNIterable
 
TupleWritable - Class in org.apache.crunch.types.writable
A straight copy of the TupleWritable implementation in the join package, added here because of its package visibility restrictions.
TupleWritable() - Constructor for class org.apache.crunch.types.writable.TupleWritable
Create an empty tuple with no allocated storage for writables.
TupleWritable(Writable[]) - Constructor for class org.apache.crunch.types.writable.TupleWritable
Initialize tuple with storage; unknown whether any of them contain "written" values.
typedCollectionOf(PType<T>, T...) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
typedCollectionOf(PType<T>, Iterable<T>) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
typedTableOf(PTableType<S, T>, S, T, Object...) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 
typedTableOf(PTableType<S, T>, Iterable<Pair<S, T>>) - Static method in class org.apache.crunch.impl.mem.MemPipeline
 

U

ungroup() - Method in class org.apache.crunch.impl.mr.collect.PGroupedTableImpl
 
ungroup() - Method in interface org.apache.crunch.PGroupedTable
Convert this grouping back into a multimap.
union(PCollection<S>...) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
union(PTable<K, V>...) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
union(PCollection<S>...) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
union(PTable<K, V>...) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
union(PCollection<S>...) - Method in interface org.apache.crunch.PCollection
Returns a PCollection instance that acts as the union of this PCollection and the input PCollections.
union(PTable<K, V>...) - Method in interface org.apache.crunch.PTable
Returns a PTable instance that acts as the union of this PTable and the input PTables.
UnionCollection<S> - Class in org.apache.crunch.impl.mr.collect
 
UnionTable<K,V> - Class in org.apache.crunch.impl.mr.collect
 
UnionTable(List<PTableBase<K, V>>) - Constructor for class org.apache.crunch.impl.mr.collect.UnionTable
 
update(T) - Method in interface org.apache.crunch.CombineFn.Aggregator
Incorporate the given value into the aggregate state maintained by this instance.
update(V) - Method in class org.apache.crunch.CombineFn.FirstNAggregator
 
update(V) - Method in class org.apache.crunch.CombineFn.LastNAggregator
 
update(BigInteger) - Method in class org.apache.crunch.CombineFn.MaxBigInts
 
update(Double) - Method in class org.apache.crunch.CombineFn.MaxDoubles
 
update(Float) - Method in class org.apache.crunch.CombineFn.MaxFloats
 
update(Integer) - Method in class org.apache.crunch.CombineFn.MaxInts
 
update(Long) - Method in class org.apache.crunch.CombineFn.MaxLongs
 
update(V) - Method in class org.apache.crunch.CombineFn.MaxNAggregator
 
update(BigInteger) - Method in class org.apache.crunch.CombineFn.MinBigInts
 
update(Double) - Method in class org.apache.crunch.CombineFn.MinDoubles
 
update(Float) - Method in class org.apache.crunch.CombineFn.MinFloats
 
update(Integer) - Method in class org.apache.crunch.CombineFn.MinInts
 
update(Long) - Method in class org.apache.crunch.CombineFn.MinLongs
 
update(V) - Method in class org.apache.crunch.CombineFn.MinNAggregator
 
update(Pair<V1, V2>) - Method in class org.apache.crunch.CombineFn.PairAggregator
 
update(Tuple4<A, B, C, D>) - Method in class org.apache.crunch.CombineFn.QuadAggregator
 
update(String) - Method in class org.apache.crunch.CombineFn.StringConcatAggregator
 
update(BigInteger) - Method in class org.apache.crunch.CombineFn.SumBigInts
 
update(Double) - Method in class org.apache.crunch.CombineFn.SumDoubles
 
update(Float) - Method in class org.apache.crunch.CombineFn.SumFloats
 
update(Integer) - Method in class org.apache.crunch.CombineFn.SumInts
 
update(Long) - Method in class org.apache.crunch.CombineFn.SumLongs
 
update(Tuple3<A, B, C>) - Method in class org.apache.crunch.CombineFn.TripAggregator
 
update(TupleN) - Method in class org.apache.crunch.CombineFn.TupleNAggregator
 
UTF8_TO_STRING - Static variable in class org.apache.crunch.types.avro.Avros
 

V

valueOf(String) - Static method in enum org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl.ThreadState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.crunch.impl.mr.run.NodeContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.crunch.lib.Sort.Order
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchControlledJob.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.crunch.hadoop.mapreduce.lib.jobcontrol.CrunchJobControl.ThreadState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
values() - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
values() - Static method in enum org.apache.crunch.impl.mr.run.NodeContext
Returns an array containing the constants of this enum type, in the order they are declared.
values(PTable<K, V>) - Static method in class org.apache.crunch.lib.PTables
 
values() - Static method in enum org.apache.crunch.lib.Sort.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.crunch.PTable
Returns a PCollection made up of the values in this PTable.
visit(DoNode) - Method in class org.apache.crunch.impl.mr.plan.JobNameBuilder
 
visit(List<DoNode>) - Method in class org.apache.crunch.impl.mr.plan.JobNameBuilder
 
visitDoFnCollection(DoCollectionImpl<?>) - Method in interface org.apache.crunch.impl.mr.collect.PCollectionImpl.Visitor
 
visitDoTable(DoTableImpl<?, ?>) - Method in interface org.apache.crunch.impl.mr.collect.PCollectionImpl.Visitor
 
visitGroupedTable(PGroupedTableImpl<?, ?>) - Method in interface org.apache.crunch.impl.mr.collect.PCollectionImpl.Visitor
 
visitInputCollection(InputCollection<?>) - Method in interface org.apache.crunch.impl.mr.collect.PCollectionImpl.Visitor
 
visitUnionCollection(UnionCollection<?>) - Method in interface org.apache.crunch.impl.mr.collect.PCollectionImpl.Visitor
 

W

wasLogged() - Method in exception org.apache.crunch.impl.mr.run.CrunchRuntimeException
 
WordAggregationHBase - Class in org.apache.crunch.examples
You need to have a HBase instance running.
WordAggregationHBase() - Constructor for class org.apache.crunch.examples.WordAggregationHBase
 
WordCount - Class in org.apache.crunch.examples
 
WordCount() - Constructor for class org.apache.crunch.examples.WordCount
 
WritableDeepCopier<T extends org.apache.hadoop.io.Writable> - Class in org.apache.crunch.types.writable
Performs deep copies of Writable values.
WritableDeepCopier(Class<T>) - Constructor for class org.apache.crunch.types.writable.WritableDeepCopier
 
WritableGroupedTableType<K,V> - Class in org.apache.crunch.types.writable
 
WritableGroupedTableType(WritableTableType<K, V>) - Constructor for class org.apache.crunch.types.writable.WritableGroupedTableType
 
WritablePairConverter<K,V> - Class in org.apache.crunch.types.writable
 
WritablePairConverter(Class<K>, Class<V>) - Constructor for class org.apache.crunch.types.writable.WritablePairConverter
 
writables(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
 
Writables - Class in org.apache.crunch.types.writable
Defines static methods that are analogous to the methods defined in WritableTypeFamily for convenient static importing.
writables(Class<W>) - Static method in class org.apache.crunch.types.writable.Writables
 
writables(Class<W>) - Method in class org.apache.crunch.types.writable.WritableTypeFamily
 
WritableType<T,W extends org.apache.hadoop.io.Writable> - Class in org.apache.crunch.types.writable
 
WritableTypeFamily - Class in org.apache.crunch.types.writable
The Writable-based implementation of the PTypeFamily interface.
write(String, K, V) - Method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Write key and value to the namedOutput.
write(String, K, V, String) - Method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Write key and value to baseOutputPath using the namedOutput.
write(KEYOUT, VALUEOUT, String) - Method in class org.apache.crunch.hadoop.mapreduce.lib.output.CrunchMultipleOutputs
Write key value to an output file name.
write(Target) - Method in class org.apache.crunch.impl.mem.collect.MemCollection
 
write(Target) - Method in class org.apache.crunch.impl.mem.collect.MemTable
 
write(PCollection<?>, Target) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
write(Target) - Method in class org.apache.crunch.impl.mr.collect.PCollectionImpl
 
write(Target) - Method in class org.apache.crunch.impl.mr.collect.PTableBase
 
write(PCollection<?>, Target) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
write(DataOutput) - Method in class org.apache.crunch.impl.mr.run.CrunchInputSplit
 
write(Target) - Method in interface org.apache.crunch.PCollection
Write the contents of this PCollection to the given Target, using the storage format specified by the target.
write(PCollection<?>, Target) - Method in interface org.apache.crunch.Pipeline
Write the given collection to the given target on the next pipeline run.
write(Target) - Method in interface org.apache.crunch.PTable
Writes this PTable to the given Target.
write(PCollection<?>, Target) - Method in class org.apache.crunch.tool.CrunchTool
 
write(DataOutput) - Method in class org.apache.crunch.types.writable.GenericArrayWritable
 
write(DataOutput) - Method in class org.apache.crunch.types.writable.TextMapWritable
 
write(DataOutput) - Method in class org.apache.crunch.types.writable.TupleWritable
Writes each Writable to out.
write(Configuration, Path, Object) - Static method in class org.apache.crunch.util.DistCache
 
writeTextFile(PCollection<T>, String) - Method in class org.apache.crunch.impl.mem.MemPipeline
 
writeTextFile(PCollection<T>, String) - Method in class org.apache.crunch.impl.mr.MRPipeline
 
writeTextFile(PCollection<T>, String) - Method in interface org.apache.crunch.Pipeline
A convenience method for writing a text file.
writeTextFile(PCollection<?>, String) - Method in class org.apache.crunch.tool.CrunchTool
 

A B C D E F G H I J K L M N O P Q R S T U V W

Copyright © 2012 The Apache Software Foundation. All Rights Reserved.