- AbstractCompositeExtractor<T> - Class in org.apache.crunch.contrib.text
-
Base class for Extractor
instances that delegates the parsing of fields to other
Extractor
instances, primarily used for constructing composite records that implement
the Tuple
interface.
- AbstractCompositeExtractor(TokenizerFactory, List<Extractor<?>>) - Constructor for class org.apache.crunch.contrib.text.AbstractCompositeExtractor
-
- AbstractSimpleExtractor<T> - Class in org.apache.crunch.contrib.text
-
Base class for the common case Extractor
instances that construct a single
object from a block of text stored in a String
, with support for error handling
and reporting.
- AbstractSimpleExtractor(T) - Constructor for class org.apache.crunch.contrib.text.AbstractSimpleExtractor
-
- AbstractSimpleExtractor(T, TokenizerFactory) - Constructor for class org.apache.crunch.contrib.text.AbstractSimpleExtractor
-
- 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
-
Deprecated.
- accept(S) - Method in class org.apache.crunch.FilterFn.NotFn
-
Deprecated.
- accept(S) - Method in class org.apache.crunch.FilterFn.OrFn
-
Deprecated.
- accept(OutputHandler, PType<?>) - Method in interface org.apache.crunch.Target
-
Checks to see if this Target
instance is compatible with the
given PType
.
- ACCEPT_ALL() - Static method in class org.apache.crunch.fn.FilterFns
-
Accept everything.
- addInputPath(Job, Path, FormatBundle, int) - Static method in class org.apache.crunch.io.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.
- addNamedOutput(Job, String, Class<? extends OutputFormat>, Class, Class) - Static method in class org.apache.crunch.io.CrunchOutputs
-
- addNamedOutput(Job, String, FormatBundle<? extends OutputFormat>, Class, Class) - Static method in class org.apache.crunch.io.CrunchOutputs
-
- 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<T> - Interface in org.apache.crunch
-
Aggregate a sequence of values into a possibly smaller sequence of the same type.
- aggregator(CombineFn.Aggregator<V>) - Static method in class org.apache.crunch.CombineFn
-
- aggregatorFactory(CombineFn.AggregatorFactory<V>) - Static method in class org.apache.crunch.CombineFn
-
- Aggregators - Class in org.apache.crunch.fn
-
- Aggregators.SimpleAggregator<T> - Class in org.apache.crunch.fn
-
Base class for aggregators that do not require any initialization.
- Aggregators.SimpleAggregator() - Constructor for class org.apache.crunch.fn.Aggregators.SimpleAggregator
-
- and(FilterFn<S>...) - Static method in class org.apache.crunch.FilterFn
-
- and(FilterFn<S>, FilterFn<S>) - Static method in class org.apache.crunch.fn.FilterFns
-
Accept an entry if all of the given filters accept it, using short-circuit evaluation.
- and(FilterFn<S>...) - Static method in class org.apache.crunch.fn.FilterFns
-
Accept an entry if all of the given filters accept it, using short-circuit evaluation.
- 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
-
- asCollection() - Method in interface org.apache.crunch.PCollection
-
- asMap() - Method in interface org.apache.crunch.PTable
-
Returns a
PObject
encapsulating a
Map
made up of the keys and values in this
PTable
.
- asPTable(PCollection<Pair<K, V>>) - Static method in class org.apache.crunch.lib.PTables
-
Convert the given PCollection<Pair<K, V>>
to a PTable<K, V>
.
- asSourceTarget(PType<T>) - Method in interface org.apache.crunch.Target
-
Attempt to create the SourceTarget
type that corresponds to this Target
for the given PType
, if possible.
- At - Class in org.apache.crunch.io
-
Static factory methods for creating common
SourceTarget
types, which may be treated as both a
Source
and a
Target
.
- At() - Constructor for class org.apache.crunch.io.At
-
- AverageBytesByIP - Class in org.apache.crunch.examples
-
- AverageBytesByIP() - Constructor for class org.apache.crunch.examples.AverageBytesByIP
-
- avroFile(String, Class<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the Avro file(s) at the given path name.
- avroFile(Path, Class<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the Avro file(s) at the given Path
.
- avroFile(String, AvroType<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the Avro file(s) at the given path name.
- avroFile(Path, AvroType<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the Avro file(s) at the given Path
.
- avroFile(String, Class<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the Avro file(s) at the given path name.
- avroFile(Path, Class<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the Avro file(s) at the given Path
.
- avroFile(String, AvroType<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the Avro file(s) at the given path name.
- avroFile(Path, AvroType<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the Avro file(s) at the given Path
.
- avroFile(String) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given path name that writes data to
Avro files.
- avroFile(Path) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given Path
that writes data to
Avro files.
- 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
-
- 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
-
- Avros - Class in org.apache.crunch.types.avro
-
Defines static methods that are analogous to the methods defined in
AvroTypeFamily
for convenient static importing.
- AvroTextOutputFormat<K,V> - Class in org.apache.crunch.types.avro
-
- AvroTextOutputFormat() - Constructor for class org.apache.crunch.types.avro.AvroTextOutputFormat
-
- 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
-
- 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
-
- checkCombiningSpecificAndReflectionSchemas() - Static method in class org.apache.crunch.types.avro.Avros
-
- cleanup(Emitter<Pair<String, BloomFilter>>) - Method in class org.apache.crunch.contrib.bloomfilter.BloomFilterFn
-
- cleanup(Emitter<T>) - Method in class org.apache.crunch.DoFn
-
Called during the cleanup of the MapReduce job this DoFn
is
associated with.
- cleanup() - Method in class org.apache.crunch.FilterFn.AndFn
-
Deprecated.
- cleanup(Emitter<T>) - Method in class org.apache.crunch.FilterFn
-
- cleanup() - Method in class org.apache.crunch.FilterFn
-
Called during the cleanup of the MapReduce job this FilterFn
is
associated with.
- cleanup() - Method in class org.apache.crunch.FilterFn.NotFn
-
Deprecated.
- cleanup() - Method in class org.apache.crunch.FilterFn.OrFn
-
Deprecated.
- 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(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.io.CrunchOutputs
-
- 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
-
- 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
-
- CombineFn.AggregatorCombineFn(CombineFn.Aggregator<V>) - Constructor for class org.apache.crunch.CombineFn.AggregatorCombineFn
-
Deprecated.
- CombineFn.AggregatorFactory<T> - Interface in org.apache.crunch
-
- CombineFn.FirstNAggregator<V> - Class in org.apache.crunch
-
- CombineFn.FirstNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.FirstNAggregator
-
Deprecated.
- CombineFn.LastNAggregator<V> - Class in org.apache.crunch
-
- CombineFn.LastNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.LastNAggregator
-
Deprecated.
- CombineFn.MaxBigInts - Class in org.apache.crunch
-
- CombineFn.MaxBigInts() - Constructor for class org.apache.crunch.CombineFn.MaxBigInts
-
Deprecated.
- CombineFn.MaxDoubles - Class in org.apache.crunch
-
- CombineFn.MaxDoubles() - Constructor for class org.apache.crunch.CombineFn.MaxDoubles
-
Deprecated.
- CombineFn.MaxFloats - Class in org.apache.crunch
-
- CombineFn.MaxFloats() - Constructor for class org.apache.crunch.CombineFn.MaxFloats
-
Deprecated.
- CombineFn.MaxInts - Class in org.apache.crunch
-
- CombineFn.MaxInts() - Constructor for class org.apache.crunch.CombineFn.MaxInts
-
Deprecated.
- CombineFn.MaxLongs - Class in org.apache.crunch
-
- CombineFn.MaxLongs() - Constructor for class org.apache.crunch.CombineFn.MaxLongs
-
Deprecated.
- CombineFn.MaxNAggregator<V extends Comparable<V>> - Class in org.apache.crunch
-
- CombineFn.MaxNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.MaxNAggregator
-
Deprecated.
- CombineFn.MinBigInts - Class in org.apache.crunch
-
- CombineFn.MinBigInts() - Constructor for class org.apache.crunch.CombineFn.MinBigInts
-
Deprecated.
- CombineFn.MinDoubles - Class in org.apache.crunch
-
- CombineFn.MinDoubles() - Constructor for class org.apache.crunch.CombineFn.MinDoubles
-
Deprecated.
- CombineFn.MinFloats - Class in org.apache.crunch
-
- CombineFn.MinFloats() - Constructor for class org.apache.crunch.CombineFn.MinFloats
-
Deprecated.
- CombineFn.MinInts - Class in org.apache.crunch
-
- CombineFn.MinInts() - Constructor for class org.apache.crunch.CombineFn.MinInts
-
Deprecated.
- CombineFn.MinLongs - Class in org.apache.crunch
-
- CombineFn.MinLongs() - Constructor for class org.apache.crunch.CombineFn.MinLongs
-
Deprecated.
- CombineFn.MinNAggregator<V extends Comparable<V>> - Class in org.apache.crunch
-
- CombineFn.MinNAggregator(int) - Constructor for class org.apache.crunch.CombineFn.MinNAggregator
-
Deprecated.
- 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
-
Deprecated.
- 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
-
Deprecated.
- CombineFn.SimpleAggregator<T> - Class in org.apache.crunch
-
- CombineFn.SimpleAggregator() - Constructor for class org.apache.crunch.CombineFn.SimpleAggregator
-
Deprecated.
- CombineFn.StringConcatAggregator - Class in org.apache.crunch
-
- CombineFn.StringConcatAggregator(String, boolean) - Constructor for class org.apache.crunch.CombineFn.StringConcatAggregator
-
Deprecated.
- CombineFn.StringConcatAggregator(String, boolean, long, long) - Constructor for class org.apache.crunch.CombineFn.StringConcatAggregator
-
Deprecated.
- CombineFn.SumBigInts - Class in org.apache.crunch
-
- CombineFn.SumBigInts() - Constructor for class org.apache.crunch.CombineFn.SumBigInts
-
Deprecated.
- CombineFn.SumDoubles - Class in org.apache.crunch
-
- CombineFn.SumDoubles() - Constructor for class org.apache.crunch.CombineFn.SumDoubles
-
Deprecated.
- CombineFn.SumFloats - Class in org.apache.crunch
-
- CombineFn.SumFloats() - Constructor for class org.apache.crunch.CombineFn.SumFloats
-
Deprecated.
- CombineFn.SumInts - Class in org.apache.crunch
-
- CombineFn.SumInts() - Constructor for class org.apache.crunch.CombineFn.SumInts
-
Deprecated.
- CombineFn.SumLongs - Class in org.apache.crunch
-
- CombineFn.SumLongs() - Constructor for class org.apache.crunch.CombineFn.SumLongs
-
Deprecated.
- 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
-
Deprecated.
- CombineFn.TupleNAggregator - Class in org.apache.crunch
-
- CombineFn.TupleNAggregator(CombineFn.Aggregator<?>...) - Constructor for class org.apache.crunch.CombineFn.TupleNAggregator
-
Deprecated.
- combineValues(CombineFn<K, V>) - Method in interface org.apache.crunch.PGroupedTable
-
Combines the values of this grouping using the given CombineFn
.
- combineValues(Aggregator<V>) - Method in interface org.apache.crunch.PGroupedTable
-
Combine the values in each group using the given
Aggregator
.
- 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
-
Configure this DoFn.
- configure(Configuration) - Method in class org.apache.crunch.FilterFn.AndFn
-
Deprecated.
- configure(Configuration) - Method in class org.apache.crunch.FilterFn.NotFn
-
Deprecated.
- configure(Configuration) - Method in class org.apache.crunch.FilterFn.OrFn
-
Deprecated.
- 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(Configuration) - Method in class org.apache.crunch.io.FormatBundle
-
- configure(Target, PType<?>) - Method in interface org.apache.crunch.io.OutputHandler
-
- configure(Configuration) - Method in class org.apache.crunch.types.avro.AvroUtf8InputFormat
-
- configure(Configuration) - Method in class org.apache.crunch.types.PGroupedTableType.PairIterableMapFn
-
- 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
-
- configureReflectDataFactory(Configuration) - Static method in class org.apache.crunch.types.avro.Avros
-
- configureShuffle(Job, GroupingOptions) - Method in class org.apache.crunch.types.PGroupedTableType
-
- configureSource(Job, int) - Method in class org.apache.crunch.contrib.io.jdbc.DataBaseSource
-
- 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(K, V) - Method in interface org.apache.crunch.types.Converter
-
- convertIterableInput(K, Iterable<V>) - Method in interface org.apache.crunch.types.Converter
-
- 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(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.
- countClause - Variable in class org.apache.crunch.contrib.io.jdbc.DataBaseSource
-
- create() - Method in interface org.apache.crunch.CombineFn.AggregatorFactory
-
Deprecated.
- create(String) - Method in class org.apache.crunch.contrib.text.TokenizerFactory
-
Return a Scanner
instance that wraps the input string and uses the delimiter,
skip, and locale settings for this TokenizerFactory
instance.
- 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
-
- createFilter(Path, BloomFilterFn<String>) - Static method in class org.apache.crunch.contrib.bloomfilter.BloomFilterFactory
-
The method will take an input path and generates BloomFilters for all text
files in that path.
- createFilter(PCollection<T>, BloomFilterFn<T>) - Static method in class org.apache.crunch.contrib.bloomfilter.BloomFilterFactory
-
- createIntermediateOutput(PType<T>) - Method in class org.apache.crunch.impl.mr.MRPipeline
-
- 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.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
PTable
s (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
PTable
s (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
PCollection
s (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
PCollection
s (using the
same strategy as Pig's CROSS operator).
- CRUNCH_FILTER_NAME - Static variable in class org.apache.crunch.contrib.bloomfilter.BloomFilterFn
-
- CRUNCH_FILTER_SIZE - Static variable in class org.apache.crunch.contrib.bloomfilter.BloomFilterFn
-
- CRUNCH_INPUTS - Static variable in class org.apache.crunch.io.CrunchInputs
-
- CRUNCH_OUTPUTS - Static variable in class org.apache.crunch.io.CrunchOutputs
-
- CrunchInputs - Class in org.apache.crunch.io
-
Helper functions for configuring multiple InputFormat
instances within a single
Crunch MapReduce job.
- CrunchInputs() - Constructor for class org.apache.crunch.io.CrunchInputs
-
- CrunchOutputs<K,V> - Class in org.apache.crunch.io
-
An analogue of
CrunchInputs
for handling multiple
OutputFormat
instances
writing to multiple files within a single MapReduce job.
- CrunchOutputs(TaskInputOutputContext<?, ?, K, V>) - Constructor for class org.apache.crunch.io.CrunchOutputs
-
Creates and initializes multiple outputs support,
it should be instantiated in the Mapper/Reducer setup method.
- CrunchRuntimeException - Exception in org.apache.crunch
-
A RuntimeException
implementation that includes some additional options
for the Crunch execution engine to track reporting status.
- CrunchRuntimeException(String) - Constructor for exception org.apache.crunch.CrunchRuntimeException
-
- CrunchRuntimeException(Exception) - Constructor for exception org.apache.crunch.CrunchRuntimeException
-
- CrunchRuntimeException(String, Exception) - Constructor for exception org.apache.crunch.CrunchRuntimeException
-
- 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.util
-
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.util.CrunchTool
-
- CrunchTool(boolean) - Constructor for class org.apache.crunch.util.CrunchTool
-
- DataBaseSource<T extends org.apache.hadoop.mapreduce.lib.db.DBWritable & org.apache.hadoop.io.Writable> - Class in org.apache.crunch.contrib.io.jdbc
-
Source from reading from a database via a JDBC connection.
- DebugLogging - Class in org.apache.crunch.test
-
Allows direct manipulation of the Hadoop log4j settings to aid in
unit testing.
- 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(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
-
- delimiter(String) - Method in class org.apache.crunch.contrib.text.TokenizerFactory.Builder
-
Sets the delimiter used by the TokenizerFactory
instances constructed by
this instance.
- 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
-
- Distinct - Class in org.apache.crunch.lib
-
Functions for computing the distinct elements of a PCollection
.
- distinct(PCollection<S>) - Static method in class org.apache.crunch.lib.Distinct
-
Construct a new PCollection
that contains the unique elements of a
given input PCollection
.
- distinct(PTable<K, V>) - Static method in class org.apache.crunch.lib.Distinct
-
A PTable<K, V>
analogue of the distinct
function.
- distinct(PCollection<S>, int) - Static method in class org.apache.crunch.lib.Distinct
-
A distinct
operation that gives the client more control over how frequently
elements are flushed to disk in order to allow control over performance or
memory consumption.
- distinct(PTable<K, V>, int) - Static method in class org.apache.crunch.lib.Distinct
-
A PTable<K, V>
analogue of the distinct
function.
- 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.util.CrunchTool
-
- 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
-
- drop(Integer...) - Method in class org.apache.crunch.contrib.text.TokenizerFactory.Builder
-
Drop the specified fields found by the input scanner, counting from zero.
- FileNamingScheme - Interface in org.apache.crunch.io
-
Encapsulates rules for naming output files.
- FileReaderFactory<T> - Interface in org.apache.crunch.io
-
- 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
.
- filter(FilterFn<Pair<K, V>>) - Method in interface org.apache.crunch.PTable
-
Apply the given filter function to this instance and return the resulting
PTable
.
- filter(String, FilterFn<Pair<K, V>>) - Method in interface org.apache.crunch.PTable
-
Apply the given filter function to this instance and return the resulting
PTable
.
- 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
-
Deprecated.
- FilterFn.NotFn<S> - Class in org.apache.crunch
-
- FilterFn.NotFn(FilterFn<S>) - Constructor for class org.apache.crunch.FilterFn.NotFn
-
Deprecated.
- FilterFn.OrFn<S> - Class in org.apache.crunch
-
- FilterFn.OrFn(FilterFn<S>...) - Constructor for class org.apache.crunch.FilterFn.OrFn
-
Deprecated.
- FilterFns - Class in org.apache.crunch.fn
-
A collection of pre-defined
FilterFn
implementations.
- 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
-
- FIRST_N(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the first n
values (or fewer if there are fewer values than n
).
- 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.
- forInput(Class<T>) - Static method in class org.apache.crunch.io.FormatBundle
-
- FormatBundle<K> - Class in org.apache.crunch.io
-
A combination of an InputFormat
or OutputFormat
and any extra
configuration information that format class needs to run.
- formattedFile(String, Class<? extends FileInputFormat<K, V>>, Class<K>, Class<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
for reading data from files that have custom
FileInputFormat<K, V>
implementations not covered by the provided TableSource
and Source
factory methods.
- formattedFile(Path, Class<? extends FileInputFormat<K, V>>, Class<K>, Class<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
for reading data from files that have custom
FileInputFormat<K, V>
implementations not covered by the provided TableSource
and Source
factory methods.
- formattedFile(String, Class<? extends FileInputFormat<?, ?>>, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
for reading data from files that have custom
FileInputFormat
implementations not covered by the provided TableSource
and Source
factory methods.
- formattedFile(Path, Class<? extends FileInputFormat<?, ?>>, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
for reading data from files that have custom
FileInputFormat
implementations not covered by the provided TableSource
and Source
factory methods.
- formattedFile(String, Class<? extends FileOutputFormat<K, V>>) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given path name that writes data to
a custom FileOutputFormat
.
- formattedFile(Path, Class<? extends FileOutputFormat<K, V>>) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given Path
that writes data to
a custom FileOutputFormat
.
- forOutput(Class<T>) - Static method in class org.apache.crunch.io.FormatBundle
-
- fourth() - Method in class org.apache.crunch.Tuple4
-
- From - Class in org.apache.crunch.io
-
Static factory methods for creating common
Source
types.
- From() - Constructor for class org.apache.crunch.io.From
-
- fromSerialized(String, Class<T>) - Static method in class org.apache.crunch.io.FormatBundle
-
- fullJoin(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
-
Performs a full outer join on the specified
PTable
s.
- 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
-
- generateKeys(S) - Method in class org.apache.crunch.contrib.bloomfilter.BloomFilterFn
-
- 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(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(int) - Method in class org.apache.crunch.types.writable.TupleWritable
-
Get ith Writable from Tuple.
- getConf() - Method in class org.apache.crunch.util.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.
- 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() - Static method in class org.apache.crunch.impl.mem.MemPipeline
-
- getCounters() - Method in class org.apache.crunch.PipelineResult.StageResult
-
- getCounterValue(Enum<?>) - Method in class org.apache.crunch.PipelineResult.StageResult
-
- 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
-
- getDefaultInstance() - Static method in class org.apache.crunch.contrib.text.TokenizerFactory
-
Returns a default TokenizerFactory
that uses whitespace as a delimiter and does
not skip any input fields.
- getDefaultInstance(Class<M>) - Static method in class org.apache.crunch.types.Protos
-
Utility function for creating a default PB Messgae from a Class object that
works with both protoc 2.3.0 and 2.4.x.
- getDefaultValue() - Method in class org.apache.crunch.contrib.text.AbstractSimpleExtractor
-
- getDefaultValue() - Method in interface org.apache.crunch.contrib.text.Extractor
-
Returns the default value for this Extractor
in case of an
error.
- 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(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(T) - Method in class org.apache.crunch.types.writable.WritableType
-
- getErrorCount() - Method in class org.apache.crunch.contrib.text.ExtractorStats
-
The overall number of records that had some kind of parsing error.
- 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
-
- getFieldErrors() - Method in class org.apache.crunch.contrib.text.ExtractorStats
-
Returns the number of errors that occurred when parsing the individual fields of
a composite record type, like a Pair
or TupleN
.
- 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.
- getFileNamingScheme() - Method in interface org.apache.crunch.io.PathTarget
-
Get the naming scheme to be used for outputs being written to an output
path.
- getFirst() - Method in class org.apache.crunch.fn.CompositeMapFn
-
- getFormatClass() - Method in class org.apache.crunch.io.FormatBundle
-
- getFormatNodeMap(JobContext) - Static method in class org.apache.crunch.io.CrunchInputs
-
- getGroupedDetachedValue(PGroupedTableType<K, V>, Pair<K, Iterable<V>>) - Static method in class org.apache.crunch.lib.PTables
-
- 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
-
- getGroupingComparatorClass() - Method in class org.apache.crunch.GroupingOptions
-
- getGroupingConverter() - Method in class org.apache.crunch.types.PGroupedTableType
-
- 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.WritableType
-
- 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
-
- 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 interface org.apache.crunch.types.Converter
-
- getKeyType() - Method in interface org.apache.crunch.PTable
-
Returns the PType
of the key.
- getKeyType() - Method in interface org.apache.crunch.types.PTableType
-
Returns the key type for the table.
- getMapOutputName(Configuration, Path) - Method in interface org.apache.crunch.io.FileNamingScheme
-
Get the output file name for a map task.
- getMapOutputName(Configuration, Path) - Method in class org.apache.crunch.io.SequentialFileNamingScheme
-
- getMaterializeSourceTarget(PCollection<T>) - Method in class org.apache.crunch.impl.mr.MRPipeline
-
Retrieve a ReadableSourceTarget that provides access to the contents of a
PCollection
.
- getName() - Method in class org.apache.crunch.impl.mem.MemPipeline
-
- getName() - Method in class org.apache.crunch.impl.mr.MRPipeline
-
- getName() - Method in class org.apache.crunch.io.FormatBundle
-
- 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
-
- getNumReducers() - Method in class org.apache.crunch.GroupingOptions
-
- 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.WritableType
-
- 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() - Method in class org.apache.crunch.GroupingOptions
-
- getPartitionerClass(PTypeFamily) - Static method in class org.apache.crunch.lib.join.JoinUtils
-
- getPath() - Method in interface org.apache.crunch.io.PathTarget
-
- getPath() - Method in class org.apache.crunch.io.PathTargetImpl
-
- 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 interface org.apache.crunch.PCollection
-
Returns the Pipeline
associated with this PCollection.
- 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
-
- getPTableType() - Method in interface org.apache.crunch.PTable
-
Returns the PTableType
of this PTable
.
- getPType(PTypeFamily) - Method in interface org.apache.crunch.contrib.text.Extractor
-
Returns the PType
associated with this data type for the
given PTypeFamily
.
- getPType() - Method in interface org.apache.crunch.PCollection
-
Returns the PType
of this PCollection
.
- getReader(Schema) - Method in class org.apache.crunch.types.avro.ReflectDataFactory
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.crunch.types.avro.AvroOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.crunch.types.avro.AvroTextOutputFormat
-
- getReduceOutputName(Configuration, Path, int) - Method in interface org.apache.crunch.io.FileNamingScheme
-
Get the output file name for a reduce task.
- getReduceOutputName(Configuration, Path, int) - Method in class org.apache.crunch.io.SequentialFileNamingScheme
-
- 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
.
- 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
-
- getSize(Configuration) - Method in class org.apache.crunch.contrib.io.jdbc.DataBaseSource
-
- 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
-
- getSourceTargets() - Method in class org.apache.crunch.ParallelDoOptions
-
- getStageName() - Method in class org.apache.crunch.PipelineResult.StageResult
-
- getStageResults() - Method in class org.apache.crunch.PipelineResult
-
- getStats() - Method in class org.apache.crunch.contrib.text.AbstractCompositeExtractor
-
- getStats() - Method in class org.apache.crunch.contrib.text.AbstractSimpleExtractor
-
- getStats() - Method in interface org.apache.crunch.contrib.text.Extractor
-
Return statistics about how many errors this Extractor
instance
encountered while parsing input data.
- 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
-
- getTableType() - Method in interface org.apache.crunch.TableSource
-
- getTableType() - Method in class org.apache.crunch.types.PGroupedTableType
-
- getTestContext(Configuration) - Static method in class org.apache.crunch.test.CrunchTestSupport
-
The method creates a TaskInputOutputContext which can be used
in unit tests.
- getTupleFactory(Class<T>) - Static method in class org.apache.crunch.types.TupleFactory
-
- getType() - Method in class org.apache.crunch.contrib.io.jdbc.DataBaseSource
-
- getType() - Method in interface org.apache.crunch.Source
-
Returns the PType
for this source.
- 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.WritableType
-
- getTypeFamily() - Method in interface org.apache.crunch.PCollection
-
Returns the PTypeFamily
of this PCollection
.
- getValue() - Method in interface org.apache.crunch.PObject
-
Gets the value associated with this PObject
.
- getValueClass() - Method in interface org.apache.crunch.types.Converter
-
- getValueType() - Method in interface org.apache.crunch.PTable
-
Returns the PType
of the value.
- getValueType() - Method in interface org.apache.crunch.types.PTableType
-
Returns the value type for the table.
- getWriter(Schema) - Method in class org.apache.crunch.types.avro.ReflectDataFactory
-
- 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
-
- main(String[]) - Static method in class org.apache.crunch.examples.AverageBytesByIP
-
- main(String[]) - Static method in class org.apache.crunch.examples.SecondarySortExample
-
- 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
-
- 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
PTable
s.
- 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.CrunchRuntimeException
-
Indicate that this exception has been written to the debug logs.
- materialize(PCollection<T>) - Method in class org.apache.crunch.impl.mem.MemPipeline
-
- materialize(PCollection<T>) - Method in class org.apache.crunch.impl.mr.MRPipeline
-
- 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.
- materializeToMap() - Method in interface org.apache.crunch.PTable
-
Returns a Map made up of the keys and values in this PTable.
- 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 PObject
of 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_BIGINTS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the maximum of all given
BigInteger
values.
- MAX_BIGINTS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the
n
largest
BigInteger
values (or fewer if there are fewer
values than
n
).
- 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_DOUBLES() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the maximum of all given double
values.
- MAX_DOUBLES(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
largest double
values (or fewer if there are fewer
values than n
).
- 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_FLOATS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the maximum of all given float
values.
- MAX_FLOATS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
largest float
values (or fewer if there are fewer
values than n
).
- 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_INTS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the maximum of all given int
values.
- MAX_INTS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
largest int
values (or fewer if there are fewer
values than n
).
- 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
-
- MAX_LONGS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the maximum of all given long
values.
- MAX_LONGS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
largest long
values (or fewer if there are fewer
values than n
).
- MAX_N(int, Class<V>) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
largest values (or fewer if there are fewer
values than n
).
- MemPipeline - Class in org.apache.crunch.impl.mem
-
- 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 PObject
of 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_BIGINTS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the minimum of all given
BigInteger
values.
- MIN_BIGINTS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the
n
smallest
BigInteger
values (or fewer if there are fewer
values than
n
).
- 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_DOUBLES() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the minimum of all given double
values.
- MIN_DOUBLES(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
smallest double
values (or fewer if there are fewer
values than n
).
- 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_FLOATS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the minimum of all given float
values.
- MIN_FLOATS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
smallest float
values (or fewer if there are fewer
values than n
).
- 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_INTS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the minimum of all given int
values.
- MIN_INTS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
smallest int
values (or fewer if there are fewer
values than n
).
- 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
-
- MIN_LONGS() - Static method in class org.apache.crunch.fn.Aggregators
-
Return the minimum of all given long
values.
- MIN_LONGS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
smallest long
values (or fewer if there are fewer
values than n
).
- MIN_N(int, Class<V>) - Static method in class org.apache.crunch.fn.Aggregators
-
Return the n
smallest values (or fewer if there are fewer
values than n
).
- MRPipeline - Class in org.apache.crunch.impl.mr
-
Pipeline implementation that is executed within Hadoop MapReduce.
- MRPipeline(Class<?>) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
-
Instantiate with a default Configuration and name.
- MRPipeline(Class<?>, String) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
-
Instantiate with a custom pipeline name.
- MRPipeline(Class<?>, Configuration) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
-
Instantiate with a custom configuration and default naming.
- MRPipeline(Class<?>, String, Configuration) - Constructor for class org.apache.crunch.impl.mr.MRPipeline
-
Instantiate with a custom name and configuration.
- 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
-
- of(Object...) - Static method in class org.apache.crunch.TupleN
-
- or(FilterFn<S>...) - Static method in class org.apache.crunch.FilterFn
-
- or(FilterFn<S>, FilterFn<S>) - Static method in class org.apache.crunch.fn.FilterFns
-
Accept an entry if at least one of the given filters accept it, using short-circuit evaluation.
- or(FilterFn<S>...) - Static method in class org.apache.crunch.fn.FilterFns
-
Accept an entry if at least one of the given filters accept it, using short-circuit evaluation.
- org.apache.crunch - package org.apache.crunch
-
Client-facing API and core abstractions.
- org.apache.crunch.contrib - package org.apache.crunch.contrib
-
User contributions that may be interesting for special applications.
- org.apache.crunch.contrib.bloomfilter - package org.apache.crunch.contrib.bloomfilter
-
Support for creating Bloom Filters.
- org.apache.crunch.contrib.io.jdbc - package org.apache.crunch.contrib.io.jdbc
-
Support for reading data from RDBMS using JDBC
- org.apache.crunch.contrib.text - package org.apache.crunch.contrib.text
-
- org.apache.crunch.examples - package org.apache.crunch.examples
-
Example applications demonstrating various aspects of Crunch.
- org.apache.crunch.fn - package org.apache.crunch.fn
-
Commonly used functions for manipulating collections.
- org.apache.crunch.impl.mem - package org.apache.crunch.impl.mem
-
In-memory Pipeline implementation for rapid prototyping and testing.
- org.apache.crunch.impl.mr - package org.apache.crunch.impl.mr
-
A Pipeline implementation that runs on Hadoop MapReduce.
- org.apache.crunch.io - package org.apache.crunch.io
-
Data input and output for Pipelines.
- org.apache.crunch.lib - package org.apache.crunch.lib
-
Joining, sorting, aggregating, and other commonly used functionality.
- org.apache.crunch.lib.join - package org.apache.crunch.lib.join
-
Inner and outer joins on collections.
- org.apache.crunch.test - package org.apache.crunch.test
-
Utilities for testing Crunch-based applications.
- org.apache.crunch.types - package org.apache.crunch.types
-
Common functionality for business object serialization.
- org.apache.crunch.types.avro - package org.apache.crunch.types.avro
-
Business object serialization using Apache Avro.
- org.apache.crunch.types.writable - package org.apache.crunch.types.writable
-
Business object serialization using Hadoop's Writables framework.
- org.apache.crunch.util - package org.apache.crunch.util
-
An assorted set of utilities.
- OutputHandler - Interface in org.apache.crunch.io
-
- outputKey(S) - Method in interface org.apache.crunch.types.Converter
-
- outputValue(S) - Method in interface org.apache.crunch.types.Converter
-
- overridePathProperties(Configuration) - Method in class org.apache.crunch.test.TemporaryPath
-
Set all keys specified in the constructor to temporary directories.
- Pair<K,V> - Class in org.apache.crunch
-
A convenience class for two-element
Tuple
s.
- 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
-
- pairAggregator(Aggregator<V1>, Aggregator<V2>) - Static method in class org.apache.crunch.fn.Aggregators
-
Apply separate aggregators to each component of a
Pair
.
- 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 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(String, DoFn<S, T>, PType<T>, ParallelDoOptions) - 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
.
- parallelDo(String, DoFn<S, Pair<K, V>>, PTableType<K, V>, ParallelDoOptions) - Method in interface org.apache.crunch.PCollection
-
Similar to the other parallelDo
instance, but returns a
PTable
instance instead of a PCollection
.
- ParallelDoOptions - Class in org.apache.crunch
-
Container class that includes optional information about a parallelDo
operation
applied to a PCollection
.
- ParallelDoOptions.Builder - Class in org.apache.crunch
-
- ParallelDoOptions.Builder() - Constructor for class org.apache.crunch.ParallelDoOptions.Builder
-
- Parse - Class in org.apache.crunch.contrib.text
-
Methods for parsing instances of PCollection<String>
into PCollection
's of strongly-typed
tuples.
- parse(String, PCollection<String>, Extractor<T>) - Static method in class org.apache.crunch.contrib.text.Parse
-
Parses the lines of the input PCollection<String>
and returns a PCollection<T>
using
the given Extractor<T>
.
- parse(String, PCollection<String>, PTypeFamily, Extractor<T>) - Static method in class org.apache.crunch.contrib.text.Parse
-
Parses the lines of the input PCollection<String>
and returns a PCollection<T>
using
the given Extractor<T>
that uses the given PTypeFamily
.
- parseTable(String, PCollection<String>, Extractor<Pair<K, V>>) - Static method in class org.apache.crunch.contrib.text.Parse
-
Parses the lines of the input PCollection<String>
and returns a PTable<K, V>
using
the given Extractor<Pair<K, V>>
.
- parseTable(String, PCollection<String>, PTypeFamily, Extractor<Pair<K, V>>) - Static method in class org.apache.crunch.contrib.text.Parse
-
Parses the lines of the input PCollection<String>
and returns a PTable<K, V>
using
the given Extractor<Pair<K, V>>
that uses the given PTypeFamily
.
- partitionerClass(Class<? extends Partitioner>) - Method in class org.apache.crunch.GroupingOptions.Builder
-
- PathTarget - Interface in org.apache.crunch.io
-
A target whose output goes to a given path on a file system.
- 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.
- PGroupedTable<K,V> - Interface in org.apache.crunch
-
The Crunch representation of a grouped
PTable
.
- PGroupedTableType<K,V> - Class in org.apache.crunch.types
-
- 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() - Method in class org.apache.crunch.impl.mr.MRPipeline
-
- PObject<T> - Interface in org.apache.crunch
-
A PObject
represents a singleton object value that results from a distributed
computation.
- process(Pair<K, Iterable<V>>, Emitter<Pair<K, V>>) - Method in class org.apache.crunch.CombineFn.AggregatorCombineFn
-
Deprecated.
- process(S, Emitter<Pair<String, BloomFilter>>) - Method in class org.apache.crunch.contrib.bloomfilter.BloomFilterFn
-
- process(S, Emitter<T>) - Method in class org.apache.crunch.DoFn
-
- 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(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<T>) - Method in class org.apache.crunch.MapFn
-
- Protos - Class in org.apache.crunch.types
-
Utility functions for working with protocol buffers in Crunch.
- Protos() - Constructor for class org.apache.crunch.types.Protos
-
- protos(Class<T>, PTypeFamily) - Static method in class org.apache.crunch.types.PTypes
-
- PTable<K,V> - Interface in org.apache.crunch
-
A sub-interface of PCollection
that represents an immutable,
distributed multi-map of keys and values.
- 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.types
-
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.types.PTypes
-
- PTypeUtils - Class in org.apache.crunch.types
-
Utilities for converting between PType
s from different
PTypeFamily
implementations.
- 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 interface org.apache.crunch.io.FileReaderFactory
-
- read(Configuration) - Method in interface org.apache.crunch.io.ReadableSource
-
Returns an Iterable
that contains the contents of this source.
- 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
PTable
s.
- read(Source<T>) - Method in class org.apache.crunch.util.CrunchTool
-
- read(TableSource<K, V>) - Method in class org.apache.crunch.util.CrunchTool
-
- read(Configuration, Path) - Static method in class org.apache.crunch.util.DistCache
-
- ReadableSource<T> - Interface in org.apache.crunch.io
-
An extension of the Source
interface that indicates that a
Source
instance may be read as a series of records by the client
code.
- ReadableSourceTarget<T> - Interface in org.apache.crunch.io
-
An interface that indicates that a SourceTarget
instance can be read
into the local client.
- 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.util.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
-
- REJECT_ALL() - Static method in class org.apache.crunch.fn.FilterFns
-
Reject everything.
- reset() - Method in interface org.apache.crunch.Aggregator
-
Clears the internal state of this Aggregator and prepares it for the
values associated with the next key.
- reset() - Method in interface org.apache.crunch.CombineFn.Aggregator
-
Deprecated.
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
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.LastNAggregator
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MaxBigInts
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MaxDoubles
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MaxFloats
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MaxInts
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MaxLongs
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MaxNAggregator
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MinBigInts
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MinDoubles
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MinFloats
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MinInts
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MinLongs
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.MinNAggregator
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.StringConcatAggregator
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.SumBigInts
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.SumDoubles
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.SumFloats
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.SumInts
-
Deprecated.
- reset() - Method in class org.apache.crunch.CombineFn.SumLongs
-
Deprecated.
- results() - Method in interface org.apache.crunch.Aggregator
-
Returns the current aggregated state of this instance.
- results() - Method in interface org.apache.crunch.CombineFn.Aggregator
-
Deprecated.
Returns the current aggregated state of this instance.
- results() - Method in class org.apache.crunch.CombineFn.FirstNAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.LastNAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MaxBigInts
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MaxDoubles
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MaxFloats
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MaxInts
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MaxLongs
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MaxNAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MinBigInts
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MinDoubles
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MinFloats
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MinInts
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MinLongs
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.MinNAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.PairAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.QuadAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.StringConcatAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.SumBigInts
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.SumDoubles
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.SumFloats
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.SumInts
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.SumLongs
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.TripAggregator
-
Deprecated.
- results() - Method in class org.apache.crunch.CombineFn.TupleNAggregator
-
Deprecated.
- rightJoin(PTable<K, U>, PTable<K, V>) - Static method in class org.apache.crunch.lib.Join
-
Performs a right outer join on the specified
PTable
s.
- 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
-
- run(String[]) - Method in class org.apache.crunch.examples.AverageBytesByIP
-
- run(String[]) - Method in class org.apache.crunch.examples.SecondarySortExample
-
- 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.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.util.CrunchTool
-
- 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
-
Output records from the given PCollection
with the given probability.
- sample(PCollection<S>, long, double) - Static method in class org.apache.crunch.lib.Sample
-
Output records from the given PCollection
using a given seed.
- sample(PTable<K, V>, double) - Static method in class org.apache.crunch.lib.Sample
-
A PTable<K, V>
analogue of the sample
function.
- sample(PTable<K, V>, long, double) - Static method in class org.apache.crunch.lib.Sample
-
A PTable<K, V>
analogue of the sample
function.
- SAMPLE_UNIQUE_ELEMENTS(int) - Static method in class org.apache.crunch.fn.Aggregators
-
Collect a sample of unique elements from the input, where 'unique' is defined by
the equals
method for the input objects.
- 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
-
Deprecated.
- scaleFactor() - Method in class org.apache.crunch.FilterFn.NotFn
-
Deprecated.
- scaleFactor() - Method in class org.apache.crunch.FilterFn.OrFn
-
Deprecated.
- 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
-
- SecondarySort - Class in org.apache.crunch.lib
-
Utilities for performing a secondary sort on a PTable<K, Pair<V1, V2>>
collection.
- SecondarySort() - Constructor for class org.apache.crunch.lib.SecondarySort
-
- SecondarySortExample - Class in org.apache.crunch.examples
-
- SecondarySortExample() - Constructor for class org.apache.crunch.examples.SecondarySortExample
-
- sequenceFile(String, Class<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the SequenceFile(s) at the given path name
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(Path, Class<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the SequenceFile(s) at the given Path
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(String, PType<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the SequenceFile(s) at the given path name
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(Path, PType<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance from the SequenceFile(s) at the given Path
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(String, Class<K>, Class<V>) - Static method in class org.apache.crunch.io.At
-
Creates a TableSourceTarget<K, V>
instance from the SequenceFile(s) at the given path name
from the key-value pairs in the SequenceFile(s).
- sequenceFile(Path, Class<K>, Class<V>) - Static method in class org.apache.crunch.io.At
-
Creates a TableSourceTarget<K, V>
instance from the SequenceFile(s) at the given Path
from the key-value pairs in the SequenceFile(s).
- sequenceFile(String, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.At
-
Creates a TableSourceTarget<K, V>
instance from the SequenceFile(s) at the given path name
from the key-value pairs in the SequenceFile(s).
- sequenceFile(Path, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.At
-
Creates a TableSourceTarget<K, V>
instance from the SequenceFile(s) at the given Path
from the key-value pairs in the SequenceFile(s).
- sequenceFile(String, Class<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the SequenceFile(s) at the given path name
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(Path, Class<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the SequenceFile(s) at the given Path
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(String, PType<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the SequenceFile(s) at the given path name
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(Path, PType<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance from the SequenceFile(s) at the given Path
from the value field of each key-value pair in the SequenceFile(s).
- sequenceFile(String, Class<K>, Class<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
instance for the SequenceFile(s) at the given path name.
- sequenceFile(Path, Class<K>, Class<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
instance for the SequenceFile(s) at the given Path
.
- sequenceFile(String, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
instance for the SequenceFile(s) at the given path name.
- sequenceFile(Path, PType<K>, PType<V>) - Static method in class org.apache.crunch.io.From
-
Creates a TableSource<K, V>
instance for the SequenceFile(s) at the given Path
.
- sequenceFile(String) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given path name that writes data to
SequenceFiles.
- sequenceFile(Path) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given Path
that writes data to
SequenceFiles.
- SequentialFileNamingScheme - Class in org.apache.crunch.io
-
Default
FileNamingScheme
that uses an incrementing sequence number in
order to generate unique file names.
- SequentialFileNamingScheme() - Constructor for class org.apache.crunch.io.SequentialFileNamingScheme
-
- serialize() - Method in class org.apache.crunch.io.FormatBundle
-
- set(String, String) - Method in class org.apache.crunch.io.FormatBundle
-
- 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
-
- setConf(Configuration) - Method in class org.apache.crunch.lib.join.JoinUtils.AvroPairGroupingComparator
-
- setConf(Configuration) - Method in class org.apache.crunch.util.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.
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.DoFn
-
Called during setup to pass the TaskInputOutputContext
to this
DoFn
instance.
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.FilterFn.AndFn
-
Deprecated.
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.FilterFn.NotFn
-
Deprecated.
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.FilterFn.OrFn
-
Deprecated.
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.fn.CompositeMapFn
-
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.fn.ExtractKeyFn
-
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.fn.PairMapFn
-
- setContext(TaskInputOutputContext<?, ?, ?, ?>) - Method in class org.apache.crunch.types.PGroupedTableType.PairIterableMapFn
-
- 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.
- skip(String) - Method in class org.apache.crunch.contrib.text.TokenizerFactory.Builder
-
Sets the regular expression that determines which input characters should be
ignored by the Scanner
that is returned by the constructed
TokenizerFactory
.
- 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.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
-
- sortAndApply(PTable<K, Pair<V1, V2>>, DoFn<Pair<K, Iterable<Pair<V1, V2>>>, T>, PType<T>) - Static method in class org.apache.crunch.lib.SecondarySort
-
Perform a secondary sort on the given PTable
instance and then apply a
DoFn
to the resulting sorted data to yield an output PCollection<T>
.
- sortAndApply(PTable<K, Pair<V1, V2>>, DoFn<Pair<K, Iterable<Pair<V1, V2>>>, Pair<U, V>>, PTableType<U, V>) - Static method in class org.apache.crunch.lib.SecondarySort
-
Perform a secondary sort on the given PTable
instance and then apply a
DoFn
to the resulting sorted data to yield an output PTable<U, V>
.
- 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
-
- sortQuads(PCollection<Tuple4<V1, V2, V3, V4>>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
-
- sortTriples(PCollection<Tuple3<V1, V2, V3>>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
-
- sortTuples(PCollection<TupleN>, Sort.ColumnOrder...) - Static method in class org.apache.crunch.lib.Sort
-
- Source<T> - Interface in org.apache.crunch
-
A Source
represents an input data set that is an input to one or more
MapReduce jobs.
- 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
-
- sourceTargets(SourceTarget<?>...) - Method in class org.apache.crunch.ParallelDoOptions.Builder
-
- specifics(Class<T>) - Static method in class org.apache.crunch.types.avro.Avros
-
- STRING_CONCAT(String, boolean) - Static method in class org.apache.crunch.CombineFn
-
- STRING_CONCAT(String, boolean, long, long) - Static method in class org.apache.crunch.CombineFn
-
- STRING_CONCAT(String, boolean) - Static method in class org.apache.crunch.fn.Aggregators
-
Concatenate strings, with a separator between strings.
- STRING_CONCAT(String, boolean, long, long) - Static method in class org.apache.crunch.fn.Aggregators
-
Concatenate strings, with a separator between 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_BIGINTS() - Static method in class org.apache.crunch.fn.Aggregators
-
- SUM_DOUBLES - Static variable in class org.apache.crunch.CombineFn
-
- SUM_DOUBLES() - Static method in class org.apache.crunch.CombineFn
-
- SUM_DOUBLES() - Static method in class org.apache.crunch.fn.Aggregators
-
Sum up all double
values.
- SUM_FLOATS - Static variable in class org.apache.crunch.CombineFn
-
- SUM_FLOATS() - Static method in class org.apache.crunch.CombineFn
-
- SUM_FLOATS() - Static method in class org.apache.crunch.fn.Aggregators
-
Sum up all float
values.
- SUM_INTS - Static variable in class org.apache.crunch.CombineFn
-
- SUM_INTS() - Static method in class org.apache.crunch.CombineFn
-
- SUM_INTS() - Static method in class org.apache.crunch.fn.Aggregators
-
Sum up all int
values.
- SUM_LONGS - Static variable in class org.apache.crunch.CombineFn
-
- SUM_LONGS() - Static method in class org.apache.crunch.CombineFn
-
- SUM_LONGS() - Static method in class org.apache.crunch.fn.Aggregators
-
Sum up all long
values.
- 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
.
- TableSourceTarget<K,V> - Interface in org.apache.crunch
-
An interface for classes that implement both the TableSource
and the
Target
interfaces.
- Target - Interface in org.apache.crunch
-
A Target
represents the output destination of a Crunch PCollection
in the context of a Crunch job.
- Target.WriteMode - Enum in org.apache.crunch
-
An enum to represent different options the client may specify
for handling the case where the output path, table, etc.
- 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
-
- 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
-
Creates a SourceTarget<String>
instance for the text file(s) at the given path name.
- textFile(Path) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<String>
instance for the text file(s) at the given Path
.
- textFile(String, PType<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance for the text file(s) at the given path name using
the provided PType<T>
to convert the input text.
- textFile(Path, PType<T>) - Static method in class org.apache.crunch.io.At
-
Creates a SourceTarget<T>
instance for the text file(s) at the given Path
using
the provided PType<T>
to convert the input text.
- textFile(String) - Static method in class org.apache.crunch.io.From
-
Creates a Source<String>
instance for the text file(s) at the given path name.
- textFile(Path) - Static method in class org.apache.crunch.io.From
-
Creates a Source<String>
instance for the text file(s) at the given Path
.
- textFile(String, PType<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance for the text file(s) at the given path name using
the provided PType<T>
to convert the input text.
- textFile(Path, PType<T>) - Static method in class org.apache.crunch.io.From
-
Creates a Source<T>
instance for the text file(s) at the given Path
using
the provided PType<T>
to convert the input text.
- textFile(String) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given path name that writes data to
text files.
- textFile(Path) - Static method in class org.apache.crunch.io.To
-
Creates a Target
at the given Path
that writes data to
text files.
- 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.types.PTypes
-
- To - Class in org.apache.crunch.io
-
Static factory methods for creating common
Target
types.
- To() - Constructor for class org.apache.crunch.io.To
-
- toCombineFn(Aggregator<V>) - Static method in class org.apache.crunch.fn.Aggregators
-
Wrap a
CombineFn
adapter around the given aggregator.
- Tokenizer - Class in org.apache.crunch.contrib.text
-
Manages a
Scanner
instance and provides support for returning only a subset
of the fields returned by the underlying
Scanner
.
- Tokenizer(Scanner, Set<Integer>, boolean) - Constructor for class org.apache.crunch.contrib.text.Tokenizer
-
Create a new Tokenizer
instance.
- TokenizerFactory - Class in org.apache.crunch.contrib.text
-
Factory class that constructs
Tokenizer
instances for input strings that use a fixed
set of delimiters, skip patterns, locales, and sets of indices to keep or drop.
- TokenizerFactory.Builder - Class in org.apache.crunch.contrib.text
-
A class for constructing new TokenizerFactory
instances using the Builder pattern.
- TokenizerFactory.Builder() - Constructor for class org.apache.crunch.contrib.text.TokenizerFactory.Builder
-
- 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.
- 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.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
-
- tripAggregator(Aggregator<V1>, Aggregator<V2>, Aggregator<V3>) - Static method in class org.apache.crunch.fn.Aggregators
-
Apply separate aggregators to each component of a
Tuple3
.
- 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 PCollection
s.
- Tuple3<V1,V2,V3> - Class in org.apache.crunch
-
A convenience class for three-element
Tuple
s.
- 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
Tuple
s.
- 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
-
- tupleAggregator(Aggregator<?>...) - Static method in class org.apache.crunch.fn.Aggregators
-
Apply separate aggregators to each component of a
Tuple
.
- 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
-
- xboolean() - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for booleans.
- xboolean(Boolean) - Static method in class org.apache.crunch.contrib.text.Extractors
-
- xcollect(TokenizerFactory, Extractor<T>) - Static method in class org.apache.crunch.contrib.text.Extractors
-
- xcustom(Class<T>, TokenizerFactory, Extractor...) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for a subclass of Tuple
with a constructor that
has the given extractor types that uses the given TokenizerFactory
for parsing the sub-fields.
- xdouble() - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for doubles.
- xdouble(Double) - Static method in class org.apache.crunch.contrib.text.Extractors
-
- xfloat() - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for floats.
- xfloat(Float) - Static method in class org.apache.crunch.contrib.text.Extractors
-
- xint() - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for integers.
- xint(Integer) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for integers.
- xlong() - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for longs.
- xlong(Long) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for longs.
- xpair(TokenizerFactory, Extractor<K>, Extractor<V>) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for pairs of the given types that uses the given TokenizerFactory
for parsing the sub-fields.
- xquad(TokenizerFactory, Extractor<A>, Extractor<B>, Extractor<C>, Extractor<D>) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for quads of the given types that uses the given TokenizerFactory
for parsing the sub-fields.
- xstring() - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for strings.
- xstring(String) - Static method in class org.apache.crunch.contrib.text.Extractors
-
- xtriple(TokenizerFactory, Extractor<A>, Extractor<B>, Extractor<C>) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for triples of the given types that uses the given TokenizerFactory
for parsing the sub-fields.
- xtupleN(TokenizerFactory, Extractor...) - Static method in class org.apache.crunch.contrib.text.Extractors
-
Returns an Extractor for an arbitrary number of types that uses the given TokenizerFactory
for parsing the sub-fields.