This project has retired. For details please refer to its
Attic page.
Class Hierarchy (Apache Crunch 0.14.0 API)
Class Hierarchy
- java.lang.Object
- org.apache.crunch.contrib.text.AbstractCompositeExtractor<T> (implements org.apache.crunch.contrib.text.Extractor<T>)
- com.google.common.util.concurrent.AbstractFuture<V> (implements com.google.common.util.concurrent.ListenableFuture<V>)
- org.apache.crunch.contrib.text.AbstractSimpleExtractor<T> (implements org.apache.crunch.contrib.text.Extractor<T>)
- org.apache.crunch.lib.Aggregate
- org.apache.crunch.lib.Aggregate.PairValueComparator<K,V> (implements java.util.Comparator<T>)
- org.apache.crunch.fn.Aggregators
- org.apache.crunch.fn.Aggregators.SimpleAggregator<T> (implements org.apache.crunch.Aggregator<T>)
- org.apache.crunch.io.At
- org.apache.crunch.lib.Average
- org.apache.crunch.types.avro.AvroDerivedValueDeepCopier<T,S> (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.types.avro.AvroMode (implements org.apache.crunch.types.avro.ReaderWriterFactory)
- org.apache.crunch.types.avro.Avros
- org.apache.crunch.impl.spark.serde.AvroSerDe<T> (implements org.apache.crunch.impl.spark.serde.SerDe<T>)
- org.apache.crunch.types.avro.AvroType<T> (implements org.apache.crunch.types.PType<T>)
- org.apache.crunch.types.avro.AvroTypeFamily (implements org.apache.crunch.types.PTypeFamily)
- org.apache.crunch.contrib.bloomfilter.BloomFilterFactory
- org.apache.crunch.lib.join.BloomFilterJoinStrategy<K,U,V> (implements org.apache.crunch.lib.join.JoinStrategy<K,U,V>)
- org.apache.crunch.impl.spark.ByteArray (implements java.lang.Comparable<T>, java.io.Serializable)
- org.apache.crunch.impl.spark.ByteArrayHelper (implements java.io.Serializable)
- org.apache.crunch.CachingOptions
- org.apache.crunch.CachingOptions.Builder
- org.apache.crunch.lib.Cartesian
- org.apache.crunch.lib.Channels
- org.apache.crunch.lib.Cogroup
- org.apache.crunch.types.CollectionDeepCopier<T> (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.impl.spark.fn.CombineMapsideFunction<K,V> (implements org.apache.spark.api.java.function.PairFlatMapFunction<T,K,V>)
- org.apache.crunch.io.CompositePathIterable<T> (implements java.lang.Iterable<T>)
- org.apache.crunch.io.Compress
- org.apache.hadoop.conf.Configured (implements org.apache.hadoop.conf.Configurable)
- org.apache.crunch.impl.spark.CounterAccumulatorParam (implements org.apache.spark.AccumulatorParam<T>)
- org.apache.hadoop.mapred.Counters.Counter (implements org.apache.hadoop.mapreduce.Counter)
- org.apache.crunch.CreateOptions
- org.apache.crunch.io.CrunchInputs
- org.apache.crunch.impl.spark.fn.CrunchIterable<S,T> (implements java.lang.Iterable<T>)
- org.apache.crunch.io.CrunchOutputs<K,V>
- org.apache.crunch.io.CrunchOutputs.OutputConfig<K,V>
- org.apache.crunch.impl.spark.fn.CrunchPairTuple2<K,V> (implements org.apache.spark.api.java.function.PairFlatMapFunction<T,K,V>)
- org.apache.crunch.test.CrunchTestSupport
- org.apache.crunch.contrib.io.jdbc.DataBaseSource.Builder<T>
- org.apache.crunch.test.DebugLogging
- org.apache.crunch.lib.join.DefaultJoinStrategy<K,U,V> (implements org.apache.crunch.lib.join.JoinStrategy<K,U,V>)
- org.apache.crunch.util.DelegatingReadableData<S,T> (implements org.apache.crunch.ReadableData<T>)
- org.apache.crunch.util.DistCache
- org.apache.crunch.lib.Distinct
- org.apache.crunch.impl.dist.DistributedPipeline (implements org.apache.crunch.Pipeline)
- org.apache.crunch.DoFn<S,T> (implements java.io.Serializable)
- org.apache.crunch.lib.Aggregate.TopKFn<K,V>
- org.apache.crunch.contrib.bloomfilter.BloomFilterFn<S>
- org.apache.crunch.CombineFn<S,T>
- org.apache.crunch.FilterFn<T>
- org.apache.crunch.lib.join.JoinFn<K,U,V>
- org.apache.crunch.MapFn<S,T>
- org.apache.crunch.fn.CompositeMapFn<R,S,T>
- org.apache.crunch.fn.ExtractKeyFn<K,V>
- org.apache.crunch.fn.IdentityFn<T>
- org.apache.crunch.fn.PairMapFn<K,V,S,T>
- org.apache.crunch.types.PGroupedTableType.PairIterableMapFn<K,V>
- org.apache.crunch.fn.SDoubleFunction<T> (implements org.apache.spark.api.java.function.DoubleFunction<T>)
- org.apache.crunch.fn.SFunction<T,R> (implements org.apache.spark.api.java.function.Function<T1,R>)
- org.apache.crunch.fn.SFunction2<K,V,R> (implements org.apache.spark.api.java.function.Function2<T1,T2,R>)
- org.apache.crunch.lib.sort.SortFns.AvroGenericFn<V>
- org.apache.crunch.lib.sort.SortFns.SingleKeyFn<V,K>
- org.apache.crunch.lib.sort.SortFns.TupleKeyFn<V,K>
- org.apache.crunch.fn.SPairFunction<T,K,V> (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.crunch.fn.SwapFn<V1,V2>
- org.apache.crunch.fn.SDoubleFlatMapFunction<T> (implements org.apache.spark.api.java.function.DoubleFlatMapFunction<T>)
- org.apache.crunch.fn.SFlatMapFunction<T,R> (implements org.apache.spark.api.java.function.FlatMapFunction<T,R>)
- org.apache.crunch.fn.SFlatMapFunction2<K,V,R> (implements org.apache.spark.api.java.function.FlatMapFunction2<T1,T2,R>)
- org.apache.crunch.fn.SPairFlatMapFunction<T,K,V> (implements org.apache.spark.api.java.function.PairFlatMapFunction<T,K,V>)
- org.apache.crunch.util.DoFnIterator<S,T> (implements java.util.Iterator<E>)
- org.apache.crunch.lib.DoFns
- org.junit.rules.ExternalResource (implements org.junit.rules.TestRule)
- org.apache.crunch.contrib.text.Extractors
- org.apache.crunch.contrib.text.ExtractorStats
- org.apache.crunch.io.impl.FileSourceImpl<T> (implements org.apache.crunch.io.ReadableSource<T>)
- org.apache.crunch.fn.FilterFns
- org.apache.crunch.impl.spark.fn.FlatMapIndexFn<S,T> (implements org.apache.spark.api.java.function.Function2<T1,T2,R>)
- org.apache.crunch.impl.spark.fn.FlatMapPairDoFn<K,V,T> (implements org.apache.spark.api.java.function.FlatMapFunction<T,R>)
- org.apache.crunch.io.FormatBundle<K> (implements org.apache.hadoop.conf.Configurable, java.io.Serializable, org.apache.hadoop.io.Writable)
- org.apache.crunch.io.From
- org.apache.crunch.GroupingOptions (implements java.io.Serializable)
- org.apache.crunch.GroupingOptions.Builder
- org.apache.crunch.impl.spark.GuavaUtils
- org.apache.crunch.util.HashUtil
- org.apache.crunch.contrib.io.jdbc.IdentifiableName (implements org.apache.hadoop.mapreduce.lib.db.DBWritable, org.apache.hadoop.io.Writable)
- org.apache.crunch.impl.spark.fn.InputConverterFunction<K,V,S> (implements org.apache.spark.api.java.function.Function<T1,R>)
- org.apache.hadoop.mapreduce.InputFormat<K,V>
- org.apache.hadoop.mapreduce.lib.input.FileInputFormat<K,V>
- java.io.InputStream (implements java.io.Closeable)
- org.apache.crunch.lib.Join
- org.apache.crunch.lib.join.JoinUtils
- org.apache.crunch.lib.join.JoinUtils.TupleWritableComparator (implements org.apache.hadoop.io.RawComparator<T>)
- org.apache.crunch.lambda.Lambda
- org.apache.crunch.types.MapDeepCopier<T> (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.impl.spark.fn.MapFunction (implements org.apache.spark.api.java.function.Function<T1,R>)
- org.apache.crunch.impl.spark.fn.MapOutputFunction<K,V> (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.crunch.lib.Mapred
- org.apache.crunch.lib.Mapreduce
- org.apache.crunch.lib.join.MapsideJoinStrategy<K,U,V> (implements org.apache.crunch.lib.join.JoinStrategy<K,U,V>)
- org.apache.crunch.impl.mem.MemPipeline (implements org.apache.crunch.Pipeline)
- org.apache.crunch.types.NoOpDeepCopier<T> (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.lib.join.OneToManyJoin
- org.apache.crunch.types.orc.Orcs
- org.apache.crunch.types.orc.OrcUtils
- org.apache.crunch.impl.spark.fn.OutputConverterFunction<K,V,S> (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.hadoop.mapreduce.OutputFormat<K,V>
- org.apache.hadoop.mapreduce.lib.output.FileOutputFormat<K,V>
- org.apache.crunch.Pair<K,V> (implements java.lang.Comparable<T>, java.io.Serializable, org.apache.crunch.Tuple)
- org.apache.crunch.impl.spark.fn.PairFlatMapDoFn<T,K,V> (implements org.apache.spark.api.java.function.PairFlatMapFunction<T,K,V>)
- org.apache.crunch.impl.spark.fn.PairMapFunction<K,V,S> (implements org.apache.spark.api.java.function.Function<T1,R>)
- org.apache.crunch.impl.spark.fn.PairMapIterableFunction<K,V,S,T> (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.crunch.ParallelDoOptions
- org.apache.crunch.ParallelDoOptions.Builder
- org.apache.crunch.contrib.text.Parse
- org.apache.crunch.impl.spark.fn.PartitionedMapOutputFunction<K,V> (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.hadoop.mapreduce.Partitioner<KEY,VALUE>
- org.apache.spark.Partitioner (implements scala.Serializable)
- org.apache.crunch.util.PartitionUtils
- org.apache.crunch.impl.dist.collect.PCollectionImpl<S> (implements org.apache.crunch.PCollection<S>)
- org.apache.crunch.types.PGroupedTableType<K,V> (implements org.apache.crunch.types.PType<T>)
- org.apache.crunch.PipelineCallable<Output> (implements java.util.concurrent.Callable<V>)
- org.apache.crunch.PipelineResult
- org.apache.crunch.PipelineResult.StageResult
- org.apache.crunch.types.Protos
- org.apache.crunch.lib.PTables
- org.apache.crunch.types.PTypes
- org.apache.crunch.types.PTypeUtils
- org.apache.crunch.lib.Quantiles
- org.apache.crunch.lib.Quantiles.Result<V>
- org.apache.avro.data.RecordBuilderBase<T> (implements org.apache.avro.data.RecordBuilder<T>)
- org.apache.avro.specific.SpecificRecordBuilderBase<T>
- org.apache.crunch.test.Employee.Builder (implements org.apache.avro.data.RecordBuilder<T>)
- org.apache.crunch.test.Person.Builder (implements org.apache.avro.data.RecordBuilder<T>)
- org.apache.crunch.impl.spark.fn.ReduceGroupingFunction (implements org.apache.spark.api.java.function.PairFlatMapFunction<T,K,V>)
- org.apache.crunch.impl.spark.fn.ReduceInputFunction<K,V> (implements org.apache.spark.api.java.function.Function<T1,R>)
- org.apache.crunch.types.avro.ReflectDataFactory (implements org.apache.crunch.types.avro.ReaderWriterFactory)
- org.apache.crunch.lib.Sample
- org.apache.crunch.lib.SecondarySort
- org.apache.crunch.io.SequentialFileNamingScheme (implements org.apache.crunch.io.FileNamingScheme)
- org.apache.crunch.impl.spark.serde.SerDeFactory
- org.apache.crunch.lib.Set
- org.apache.crunch.fn.SFunctions
- org.apache.crunch.lib.Shard
- org.apache.crunch.lib.join.ShardedJoinStrategy<K,U,V> (implements org.apache.crunch.lib.join.JoinStrategy<K,U,V>)
- org.apache.crunch.impl.SingleUseIterable<T> (implements java.lang.Iterable<T>)
- org.apache.crunch.lib.Sort
- org.apache.crunch.lib.Sort.ColumnOrder
- org.apache.crunch.lib.sort.SortFns
- org.apache.crunch.lib.sort.SortFns.KeyExtraction<V>
- org.apache.crunch.io.SourceTargetHelper
- org.apache.crunch.impl.spark.collect.SparkCollectFactory (implements org.apache.crunch.impl.dist.collect.PCollectionFactory)
- org.apache.crunch.impl.spark.SparkComparator (implements java.util.Comparator<T>, java.io.Serializable)
- org.apache.crunch.impl.spark.SparkRuntimeContext (implements java.io.Serializable)
- org.apache.avro.specific.SpecificRecordBase (implements java.lang.Comparable<T>, org.apache.avro.generic.GenericRecord, org.apache.avro.specific.SpecificRecord)
- org.apache.crunch.test.Employee (implements org.apache.avro.specific.SpecificRecord)
- org.apache.crunch.test.Person (implements org.apache.avro.specific.SpecificRecord)
- org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector (implements org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector)
- org.apache.crunch.test.TestCounters
- java.lang.Throwable (implements java.io.Serializable)
- org.apache.crunch.io.To
- org.apache.crunch.impl.spark.collect.ToByteArrayFunction (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.crunch.contrib.text.Tokenizer
- org.apache.crunch.contrib.text.TokenizerFactory (implements java.io.Serializable)
- org.apache.crunch.contrib.text.TokenizerFactory.Builder
- org.apache.crunch.lib.TopList
- org.apache.crunch.lib.sort.TotalOrderPartitioner.BinarySearchNode<K> (implements org.apache.crunch.lib.sort.TotalOrderPartitioner.Node<T>)
- org.apache.crunch.impl.spark.fn.Tuple2MapFunction<K,V> (implements org.apache.spark.api.java.function.PairFunction<T,K,V>)
- org.apache.crunch.Tuple3<V1,V2,V3> (implements org.apache.crunch.Tuple)
- org.apache.crunch.Tuple4<V1,V2,V3,V4> (implements org.apache.crunch.Tuple)
- org.apache.crunch.types.TupleDeepCopier<T> (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.types.TupleFactory<T> (implements java.io.Serializable)
- org.apache.crunch.TupleN (implements org.apache.crunch.Tuple)
- org.apache.crunch.util.Tuples
- org.apache.crunch.util.Tuples.PairIterable<S,T> (implements java.lang.Iterable<T>)
- org.apache.crunch.util.Tuples.QuadIterable<A,B,C,D> (implements java.lang.Iterable<T>)
- org.apache.crunch.util.Tuples.TripIterable<A,B,C> (implements java.lang.Iterable<T>)
- org.apache.crunch.util.Tuples.TupleNIterable (implements java.lang.Iterable<T>)
- org.apache.crunch.Union
- org.apache.crunch.types.UnionDeepCopier (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.util.UnionReadableData<T> (implements org.apache.crunch.ReadableData<T>)
- org.apache.crunch.types.writable.UnionWritable (implements org.apache.hadoop.io.WritableComparable<T>)
- org.apache.hadoop.io.WritableComparator (implements org.apache.hadoop.conf.Configurable, org.apache.hadoop.io.RawComparator<T>)
- org.apache.crunch.types.writable.WritableDeepCopier<T> (implements org.apache.crunch.types.DeepCopier<T>)
- org.apache.crunch.types.writable.Writables
- org.apache.crunch.impl.spark.serde.WritableSerDe (implements org.apache.crunch.impl.spark.serde.SerDe<T>)
- org.apache.crunch.types.writable.WritableType<T,W> (implements org.apache.crunch.types.PType<T>)
- org.apache.crunch.types.writable.WritableTypeFamily (implements org.apache.crunch.types.PTypeFamily)
Interface Hierarchy
- java.util.function.BiConsumer<T,U>
- java.util.function.BiFunction<T,U,R>
- java.util.function.Consumer<T>
- org.apache.crunch.Emitter<T>
- org.apache.crunch.io.FileNamingScheme
- org.apache.crunch.io.FileReaderFactory<T>
- java.util.function.Function<T,R>
- java.util.concurrent.Future<V>
- org.apache.crunch.lambda.LCollection<S>
- org.apache.crunch.lambda.LCollectionFactory
- org.apache.crunch.lambda.LDoFnContext<S,T>
- org.apache.crunch.impl.dist.collect.MRCollection
- org.apache.crunch.impl.mr.MRJob
- org.apache.crunch.io.OutputHandler
- org.apache.crunch.PCollection<S>
- org.apache.crunch.impl.dist.collect.PCollectionFactory
- org.apache.crunch.impl.dist.collect.PCollectionImpl.Visitor
- org.apache.crunch.Pipeline
- org.apache.crunch.PObject<T>
- java.util.function.Predicate<T>
- org.apache.crunch.types.PTypeFamily
- org.apache.crunch.types.avro.ReaderWriterFactory
- java.io.Serializable
- org.apache.crunch.Aggregator<T>
- org.apache.crunch.types.Converter<K,V,S,T>
- org.apache.crunch.types.DeepCopier<T>
- org.apache.crunch.contrib.text.Extractor<T>
- org.apache.crunch.lib.join.JoinStrategy<K,U,V>
- org.apache.crunch.lambda.LDoFn<S,T>
- org.apache.crunch.types.PTableType<K,V>
- org.apache.crunch.types.PType<T>
- org.apache.crunch.ReadableData<T>
- org.apache.crunch.lambda.fn.SBiConsumer<K,V> (also extends java.util.function.BiConsumer<T,U>)
- org.apache.crunch.lambda.fn.SBiFunction<K,V,T> (also extends java.util.function.BiFunction<T,U,R>)
- org.apache.crunch.lambda.fn.SBinaryOperator<T> (also extends java.util.function.BinaryOperator<T>)
- org.apache.crunch.lambda.fn.SConsumer<T> (also extends java.util.function.Consumer<T>)
- org.apache.crunch.impl.spark.serde.SerDe<T>
- org.apache.crunch.util.SerializableSupplier<T> (also extends com.google.common.base.Supplier<T>)
- org.apache.crunch.lambda.fn.SFunction<S,T> (also extends java.util.function.Function<T,R>)
- org.apache.crunch.lib.join.ShardedJoinStrategy.ShardingStrategy<K>
- org.apache.crunch.lambda.fn.SPredicate<T> (also extends java.util.function.Predicate<T>)
- org.apache.crunch.lambda.fn.SSupplier<T> (also extends java.util.function.Supplier<T>)
- org.apache.crunch.Source<T>
- org.apache.crunch.impl.spark.SparkCollection
- com.google.common.base.Supplier<T>
- java.util.function.Supplier<T>
- org.apache.crunch.Target
- org.apache.crunch.lib.sort.TotalOrderPartitioner.Node<T>
- org.apache.crunch.Tuple
Enum Hierarchy
Copyright © 2016 The Apache Software Foundation. All rights reserved.