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

A

acceptsAll() - Method in class cascading.flow.planner.iso.expression.PathScopeExpression
 
acceptsAll() - Method in class cascading.flow.planner.iso.expression.ScopeExpression
 
add(ElementGraph) - Method in class cascading.flow.planner.graph.IgnoreAnnotationsHashSet
 
add(Tuple) - Method in class cascading.tuple.collect.SpillableTupleList
Method add will add the given Tuple to this list.
add(Comparable) - Method in class cascading.tuple.Tuple
Method add adds a new element value to this instance.
add(Object) - Method in class cascading.tuple.Tuple
Method add adds a new element value to this instance.
add(TupleEntry) - Method in class cascading.tuple.TupleEntryCollector
Method add inserts the given TupleEntry into the outgoing stream.
add(Tuple) - Method in class cascading.tuple.TupleEntryCollector
Method add inserts the given Tuple into the outgoing stream.
add(TupleEntry) - Method in class cascading.tuple.TupleEntrySchemeCollector
 
add(Tuple) - Method in class cascading.tuple.TupleEntrySchemeCollector
 
addAll(Collection<? extends Tuple>) - Method in class cascading.tuple.collect.SpillableTupleList
 
addAll(Object...) - Method in class cascading.tuple.Tuple
Method addAll adds all given values to this instance.
addAll(Tuple) - Method in class cascading.tuple.Tuple
Method addAll adds all the element values of the given Tuple instance to this instance.
addAll(MultiMap<C, K, V>) - Method in class cascading.util.MultiMap
 
addAll(K, V...) - Method in class cascading.util.MultiMap
 
addAll(K, Collection<V>) - Method in class cascading.util.MultiMap
 
addAllGroups() - Method in class cascading.flow.planner.BaseFlowStep
 
addAnnotation(ElementAnnotation) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
addAnnotationExclude(Enum) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
addApplicationFramework(Map<Object, Object>, String) - Static method in class cascading.property.AppProps
Adds a framework "name:version" string to the property set and to the System properties.
addApplicationTag(Map<Object, Object>, String) - Static method in class cascading.property.AppProps
 
addAssemblyPlanner(AssemblyPlanner) - Method in class cascading.flow.FlowDef
Method addAssemblyPlanner adds new AssemblyPlanner instances to be evaluated.
addBoolean(boolean) - Method in class cascading.tuple.Tuple
Method addBoolean adds a new element value to this instance.
addCheckpoint(String, Tap) - Method in class cascading.flow.FlowDef
Method addCheckpoint adds a new named checkpoint Tap for use in the resulting Flow.
addCheckpoint(Checkpoint, Tap) - Method in class cascading.flow.FlowDef
Method addCheckpoint adds a new checkpoint Tap named after the given Checkpoint for use in the resulting Flow.
addCheckpoints(Map<String, Tap>) - Method in class cascading.flow.FlowDef
Method addCheckpoints adds a Map of the names and Tap pairs.
addChildTransform(Transformed) - Method in class cascading.flow.planner.iso.assertion.Asserted
 
addChildTransform(Transformed) - Method in class cascading.flow.planner.iso.transformer.Transformed
 
addCodec(String) - Method in class cascading.tuple.collect.SpillableProps
Method addCodec adds a codec class names to use.
addCodecs(List<String>) - Method in class cascading.tuple.collect.SpillableProps
Method addCodecs adds a list of possible codec class names to use.
addDefaultElementFactory(String, ElementFactory) - Method in class cascading.flow.planner.rule.RuleRegistry
Adds the named elementFactory if it does not already exist.
addDescription(String) - Method in class cascading.flow.FlowDef
Method addDescription adds a user readable description to the flowDescriptor.
addDescription(String, String) - Method in class cascading.flow.FlowDef
Method addDescription adds a description to the flowDescriptor.
addDescriptions(Map<String, String>) - Method in class cascading.flow.FlowDef
Method addProperties adds all properties in the given map in order to the flowDescriptor.
addDouble(double) - Method in class cascading.tuple.Tuple
Method addDouble adds a new element value to this instance.
addEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
addEdge(FlowElement, FlowElement, Scope) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
addEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
addEdge(FlowElement, FlowElement, Scope) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
addEdge(FlowElement, FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
addEdge(FlowElement, FlowElement, Scope) - Method in interface cascading.flow.planner.graph.ElementGraph
 
addEdge(Process, Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
addEdge(Process, Process, ProcessEdge) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
addEdge(Process, Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
addEdge(Process, Process, ProcessEdge) - Method in interface cascading.flow.planner.process.ProcessGraph
 
addEdgeAnnotation(Enum) - Method in class cascading.flow.planner.process.ProcessEdge
 
addEdgeAnnotation(String, String) - Method in class cascading.flow.planner.process.ProcessEdge
 
addElementFactory(String, ElementFactory) - Method in class cascading.flow.planner.rule.RuleRegistry
 
addExclusions(ElementGraph) - Method in class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
addExclusions(E) - Method in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
addFloat(float) - Method in class cascading.tuple.Tuple
Method addFloat adds a new element value to this instance.
addFlow(Flow) - Method in class cascading.cascade.CascadeDef
Method addFlow adds a new Flow instance that is intended to participate in a Cascade.
addFlows(Flow...) - Method in class cascading.cascade.CascadeDef
Method addFlows adds many new Flow instances intended to participate in a Cascade.
addFlows(Collection<Flow>) - Method in class cascading.cascade.CascadeDef
Method addFlows adds many new Flow instances intended to participate in a Cascade.
addFlowStats(FlowStats) - Method in class cascading.stats.CascadeStats
Method addFlowStats add a child Flow {2link FlowStats} instance.
addFramework(String) - Method in class cascading.property.AppProps
Method addFramework adds a new framework name to the list of frameworks used.
addFramework(String, String) - Method in class cascading.property.AppProps
Method addFramework adds a new framework name and its version to the list of frameworks used.
addFrameworks(String...) - Method in class cascading.property.AppProps
Method addFrameworks adds new framework names to the list of frameworks used.
addGroup(Group) - Method in class cascading.flow.planner.BaseFlowStep
 
addGroups(Collection<Group>) - Method in class cascading.flow.planner.BaseFlowStep
 
addHead(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
addHeadVertex(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
addHeadVertex(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
addHeadVertex(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
addHook(ShutdownUtil.Hook) - Static method in class cascading.util.ShutdownUtil
 
addInteger(int) - Method in class cascading.tuple.Tuple
Method addInteger adds a new element value to this instance.
addListener(CascadeListener) - Method in class cascading.cascade.BaseCascade
 
addListener(CascadeListener) - Method in interface cascading.cascade.Cascade
 
addListener(FlowListener) - Method in class cascading.flow.BaseFlow
 
addListener(FlowListener) - Method in interface cascading.flow.Flow
Method addListener registers the given flowListener with this instance.
addListener(FlowStepListener) - Method in interface cascading.flow.FlowStep
Method addListener registers the given FlowStepListener with this instance.
addListener(FlowStepListener) - Method in class cascading.flow.planner.BaseFlowStep
 
addListener(StatsListener) - Method in class cascading.stats.CascadingStats
 
addLogCounter(Enum) - Method in class cascading.flow.FlowRuntimeProps
Method addLogCounter adds a new counter to be logged when a cluster side slice completes.
addLogCounter(String, String) - Method in class cascading.flow.FlowRuntimeProps
Method addLogCounter adds a new counter to be logged when a cluster side slice completes.
addLong(long) - Method in class cascading.tuple.Tuple
Method addLong adds a new element value to this instance.
addNodeStats(FlowNodeStats) - Method in class cascading.stats.FlowStepStats
 
addParentAnnotations(ElementGraph) - Method in class cascading.flow.planner.graph.BaseAnnotatedElementGraph
 
addParentAnnotations(ElementGraph) - Method in class cascading.flow.planner.graph.BoundedElementMultiGraph
 
addPath(Duct, Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
addPath(Duct, int, Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
addPlannerProperties() - Method in class cascading.flow.BaseFlow
 
addPriorNames(Scope, Scope) - Method in class cascading.flow.planner.Scope
 
addProcessAnnotation(Enum) - Method in class cascading.flow.planner.BaseFlowNode
 
addProcessAnnotation(String, String) - Method in class cascading.flow.planner.BaseFlowNode
 
addProcessAnnotation(Enum) - Method in class cascading.flow.planner.BaseFlowStep
 
addProcessAnnotation(String, String) - Method in class cascading.flow.planner.BaseFlowStep
 
addProcessAnnotation(Enum) - Method in interface cascading.flow.planner.process.ProcessModel
 
addProcessAnnotation(String, String) - Method in interface cascading.flow.planner.process.ProcessModel
 
addPropertiesTo(Properties) - Method in class cascading.cascade.CascadeProps
 
addPropertiesTo(Properties) - Method in class cascading.flow.FlowConnectorProps
 
addPropertiesTo(Properties) - Method in class cascading.flow.FlowProps
 
addPropertiesTo(Properties) - Method in class cascading.flow.FlowRuntimeProps
 
addPropertiesTo(Properties) - Method in class cascading.pipe.assembly.AggregateByProps
 
addPropertiesTo(Properties) - Method in class cascading.pipe.assembly.UniqueProps
 
addPropertiesTo(Properties) - Method in class cascading.property.AppProps
 
addPropertiesTo(Properties) - Method in class cascading.property.Props
 
addPropertiesTo(Properties) - Method in class cascading.tap.partition.PartitionTapProps
 
addPropertiesTo(Properties) - Method in class cascading.tap.TrapProps
 
addPropertiesTo(Properties) - Method in class cascading.tuple.collect.SpillableProps
 
addPropertiesTo(Properties) - Method in class cascading.tuple.TupleEntrySchemeIteratorProps
 
addRule(Rule) - Method in class cascading.flow.planner.rule.RuleRegistry
 
addSessionProperties(Map<Object, Object>) - Method in class cascading.flow.BaseFlow
 
addShort(short) - Method in class cascading.tuple.Tuple
Method addShort adds a new element value to this instance.
addSink(String, Tap) - Method in class cascading.flow.FlowDef
Method addSink adds a new named sink Tap for use in the resulting Flow.
addSink(Pipe, Tap) - Method in class cascading.flow.FlowDef
Method addSink adds a new sink Tap named after the given Pipe for use in the resulting Flow.
addSink(String, Tap) - Method in class cascading.flow.planner.BaseFlowStep
 
addSinks(Map<String, Tap>) - Method in class cascading.flow.FlowDef
Method addSinks adds a Map of the named and Tap pairs.
addSinks(BaseFlowStep, ElementGraph, Set<Tap>) - Static method in class cascading.flow.planner.BaseFlowStep
 
addSource(String, Tap) - Method in class cascading.flow.FlowDef
Method addSource adds a new named source Tap for use in the resulting Flow.
addSource(Pipe, Tap) - Method in class cascading.flow.FlowDef
Method addSource adds a new source Tap named after the given Pipe for use in the resulting Flow.
addSource(String, Tap) - Method in class cascading.flow.planner.BaseFlowStep
 
addSourcePartitionFilter(Fields, Filter) - Method in class cascading.tap.partition.BasePartitionTap
Add a Filter with its associated argument selector when using this PartitionTap as a source.
addSources(Map<String, Tap>) - Method in class cascading.flow.FlowDef
Method addSources adds a map of name and Tap pairs.
addSources(BaseFlowStep, ElementGraph, Set<Tap>) - Static method in class cascading.flow.planner.BaseFlowStep
 
addStepListener(FlowStepListener) - Method in class cascading.flow.BaseFlow
 
addStepListener(FlowStepListener) - Method in interface cascading.flow.Flow
Method addStepListener registers the given flowStepListener with this instance.
addStepStats(FlowStepStats) - Method in class cascading.stats.FlowStats
 
addString(String) - Method in class cascading.tuple.Tuple
Method addString adds a new element value to this instance.
addTag(String) - Method in class cascading.property.AppProps
Method addTag will associate a "tag" with this application.
addTag(String) - Method in class cascading.property.UnitOfWorkDef
Method addTag will associate a "tag" with this UnitOfWork.
addTags(String...) - Method in class cascading.property.AppProps
Method addTags will associate the given "tags" with this application.
addTags(String...) - Method in class cascading.property.UnitOfWorkDef
Method addTags will associate the given "tags" with this UnitOfWork.
addTail(Pipe) - Method in class cascading.flow.FlowDef
Method addTail adds a new Pipe to this FlowDef that represents a tail in a pipe assembly.
addTail(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
addTails(Collection<Pipe>) - Method in class cascading.flow.FlowDef
Method addTails adds a Collection of tails.
addTails(Pipe...) - Method in class cascading.flow.FlowDef
Method addTails adds an array of tails.
addTailSink(Pipe, Tap) - Method in class cascading.flow.FlowDef
Method addTailSink adds the tail Pipe and sink Tap to this FlowDef.
addTailVertex(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
addTailVertex(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
addTailVertex(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
addToClassPath(String) - Method in class cascading.flow.FlowDef
Adds each given artifact to the classpath the assembly will execute under allowing Operators to dynamically load classes and resources from a ClassLoader.
addTrap(String, Tap) - Method in class cascading.flow.FlowDef
Method addTrap adds a new named trap Tap for use in the resulting Flow.
addTrap(Pipe, Tap) - Method in class cascading.flow.FlowDef
Method addTrap adds a new trap Tap named after the given Pipe for use in the resulting Flow.
addTraps(Map<String, Tap>) - Method in class cascading.flow.FlowDef
Method addTraps adds a Map of the names and Tap pairs.
addVertex(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
addVertex(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
addVertex(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
addVertex(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
addVertex(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
aggregate(FlowProcess, AggregatorCall<Context>) - Method in interface cascading.operation.Aggregator
Method aggregate is called for each TupleEntry value in the current grouping.
aggregate(FlowProcess, AggregatorCall<Average.Context>) - Method in class cascading.operation.aggregator.Average
 
aggregate(FlowProcess, AggregatorCall<Pair<Long[], Tuple>>) - Method in class cascading.operation.aggregator.Count
 
aggregate(FlowProcess, AggregatorCall<Tuple[]>) - Method in class cascading.operation.aggregator.ExtentBase
 
aggregate(FlowProcess, AggregatorCall<ExtremaValueBase.Context>) - Method in class cascading.operation.aggregator.ExtremaValueBase
 
aggregate(FlowProcess, AggregatorCall<Pair<Double[], Tuple>>) - Method in class cascading.operation.aggregator.Sum
 
aggregate(FlowProcess, GroupAssertionCall<AssertGroupBase.Context>) - Method in class cascading.operation.assertion.AssertGroupBase
 
aggregate(FlowProcess, GroupAssertionCall<C>) - Method in interface cascading.operation.GroupAssertion
Method aggregate is called for each TupleEntry value in the current grouping.
aggregate(FlowProcess, TupleEntry, Tuple) - Method in interface cascading.pipe.assembly.AggregateBy.Functor
Method aggregate operates on the given args in tandem (optionally) with the given context values.
aggregate(FlowProcess, AggregatorCall<AverageBy.AverageFinal.Context>) - Method in class cascading.pipe.assembly.AverageBy.AverageFinal
 
aggregate(FlowProcess, TupleEntry, Tuple) - Method in class cascading.pipe.assembly.AverageBy.AveragePartials
 
aggregate(FlowProcess, TupleEntry, Tuple) - Method in class cascading.pipe.assembly.CountBy.CountPartials
 
aggregate(FlowProcess, TupleEntry, Tuple) - Method in class cascading.pipe.assembly.FirstBy.FirstPartials
 
aggregate(FlowProcess, TupleEntry, Tuple) - Method in class cascading.pipe.assembly.MaxBy.MaxPartials
 
aggregate(FlowProcess, TupleEntry, Tuple) - Method in class cascading.pipe.assembly.MinBy.MinPartials
 
aggregate(FlowProcess, TupleEntry, Tuple) - Method in class cascading.pipe.assembly.SumBy.SumPartials
 
AGGREGATE_BY_CACHE_FACTORY - Static variable in class cascading.pipe.assembly.AggregateByProps
property to control the cache factory used in AggregateBy.
AGGREGATE_BY_CAPACITY - Static variable in class cascading.pipe.assembly.AggregateByProps
property to control the capacity of the cache to use.
AGGREGATE_BY_DEFAULT_CAPACITY - Static variable in class cascading.pipe.assembly.AggregateByProps
default capacity of caches used in AggregateBy.
AggregateBy - Class in cascading.pipe.assembly
Class AggregateBy is a SubAssembly that serves two roles for handling aggregate operations.
AggregateBy(String, int) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(Fields, AggregateBy.Functor, Aggregator) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(Pipe, Fields, AggregateBy...) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(Pipe, Fields, int, AggregateBy...) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(String, Pipe, Fields, int, AggregateBy...) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(String, Pipe[], Fields, AggregateBy...) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(String, Pipe[], Fields, int, AggregateBy...) - Constructor for class cascading.pipe.assembly.AggregateBy
Constructor CompositeAggregator creates a new CompositeAggregator instance.
AggregateBy(String, Pipe[], Fields, Fields, AggregateBy.Functor, Aggregator, int) - Constructor for class cascading.pipe.assembly.AggregateBy
 
AggregateBy.Cache - Enum in cascading.pipe.assembly
 
AggregateBy.CompositeFunction - Class in cascading.pipe.assembly
Class CompositeFunction takes multiple Functor instances and manages them as a single Function.
AggregateBy.CompositeFunction(Fields, Fields, AggregateBy.Functor, int) - Constructor for class cascading.pipe.assembly.AggregateBy.CompositeFunction
Constructor CompositeFunction creates a new CompositeFunction instance.
AggregateBy.CompositeFunction(Fields, Fields[], AggregateBy.Functor[], int) - Constructor for class cascading.pipe.assembly.AggregateBy.CompositeFunction
Constructor CompositeFunction creates a new CompositeFunction instance.
AggregateBy.CompositeFunction.Context - Class in cascading.pipe.assembly
 
AggregateBy.CompositeFunction.Context() - Constructor for class cascading.pipe.assembly.AggregateBy.CompositeFunction.Context
 
AggregateBy.Functor - Interface in cascading.pipe.assembly
Interface Functor provides a means to create a simple function for use with the AggregateBy.CompositeFunction class.
AggregateByProps - Class in cascading.pipe.assembly
Class AggregateByProps is a fluent helper for setting various properties related to the cache used in AggregateBy.
AggregateByProps() - Constructor for class cascading.pipe.assembly.AggregateByProps
 
aggregateByProps() - Static method in class cascading.pipe.assembly.AggregateByProps
 
Aggregator<Context> - Interface in cascading.operation
An Aggregator takes the set of all values associated with a unique grouping and returns zero or more values.
AggregatorCall<C> - Interface in cascading.operation
Interface AggregatorCall provides access to the current Aggregator invocation arguments.
AggregatorEveryStage - Class in cascading.flow.stream.element
 
AggregatorEveryStage(FlowProcess, Every) - Constructor for class cascading.flow.stream.element.AggregatorEveryStage
 
ALL - Static variable in class cascading.flow.planner.iso.expression.ScopeExpression
Where this expression applies between ALL edges between two nodes.
ALL - Static variable in class cascading.tuple.Fields
Field ALL represents a wildcard for all fields
ALL_BLOCKING - Static variable in class cascading.flow.planner.iso.expression.PathScopeExpression
 
ALL_NON_BLOCKING - Static variable in class cascading.flow.planner.iso.expression.PathScopeExpression
 
allChildrenFinished - Variable in class cascading.stats.BaseCachedNodeStats
 
allNext - Variable in class cascading.flow.stream.duct.Fork
 
and(ElementExpression...) - Static method in class cascading.flow.planner.iso.expression.AndElementExpression
 
and(ElementCapture, ElementExpression...) - Static method in class cascading.flow.planner.iso.expression.AndElementExpression
 
And - Class in cascading.operation.filter
Class And is a Filter class that will logically 'and' the results of the constructor provided Filter instances.
And(Filter...) - Constructor for class cascading.operation.filter.And
Constructor And creates a new And instance where all Filter instances receive all arguments.
And(Fields, Filter, Fields, Filter) - Constructor for class cascading.operation.filter.And
Constructor And creates a new And instance.
And(Fields[], Filter[]) - Constructor for class cascading.operation.filter.And
Constructor And creates a new And instance.
AndElementExpression - Class in cascading.flow.planner.iso.expression
 
AndElementExpression(ElementExpression...) - Constructor for class cascading.flow.planner.iso.expression.AndElementExpression
 
AndElementExpression(ElementCapture, ElementExpression...) - Constructor for class cascading.flow.planner.iso.expression.AndElementExpression
 
AnnotatedDecoratedElementGraph - Class in cascading.flow.planner.graph
 
AnnotatedDecoratedElementGraph(ElementGraph, EnumMultiMap<FlowElement>) - Constructor for class cascading.flow.planner.graph.AnnotatedDecoratedElementGraph
 
AnnotatedGraph - Interface in cascading.flow.planner.graph
 
AnnotateGraphTransformer - Class in cascading.flow.planner.iso.transformer
 
AnnotateGraphTransformer(ExpressionGraph, ElementAnnotation) - Constructor for class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
AnnotateGraphTransformer(GraphTransformer, ExpressionGraph, ElementAnnotation) - Constructor for class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
AnnotationExpression - Class in cascading.flow.planner.iso.expression
 
AnnotationExpression(Enum) - Constructor for class cascading.flow.planner.iso.expression.AnnotationExpression
 
AnnotationExpression(ElementCapture, Enum) - Constructor for class cascading.flow.planner.iso.expression.AnnotationExpression
 
annotations - Variable in class cascading.flow.planner.graph.BaseAnnotatedElementGraph
 
annotations - Variable in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
ANY - Static variable in class cascading.flow.planner.iso.expression.ScopeExpression
Where this expression applies between ANY edge between two nodes.
ANY - Static variable in interface cascading.operation.Operation
Field ANY denotes that a given Operation will take any number of argument values
ANY_BLOCKING - Static variable in class cascading.flow.planner.iso.expression.PathScopeExpression
 
ANY_NON_BLOCKING - Static variable in class cascading.flow.planner.iso.expression.PathScopeExpression
 
APP_FRAMEWORKS - Static variable in class cascading.property.AppProps
 
APP_ID - Static variable in class cascading.property.AppProps
 
APP_JAR_CLASS - Static variable in class cascading.property.AppProps
 
APP_JAR_PATH - Static variable in class cascading.property.AppProps
 
APP_NAME - Static variable in class cascading.property.AppProps
 
APP_TAGS - Static variable in class cascading.property.AppProps
 
APP_VERSION - Static variable in class cascading.property.AppProps
 
append(Fields) - Method in class cascading.tuple.Fields
Method is used for appending the given Fields instance to this instance, into a new Fields instance suitable for use as a field declaration.
append(Tuple...) - Method in class cascading.tuple.Tuple
Method append appends all the values of the given Tuple instances to a copy of this instance.
appendNew(TupleEntry) - Method in class cascading.tuple.TupleEntry
Method appendNew appends the given TupleEntry instance to this instance.
appendSelector(Fields) - Method in class cascading.tuple.Fields
Method is used for appending the given Fields instance to this instance, into a new Fields instance suitable for use as a field selector.
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.AndElementExpression
 
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.AnnotationExpression
 
applies(PlannerContext, ElementGraph, Type) - Method in interface cascading.flow.planner.iso.expression.Expression
 
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.NonSafeOperationExpression
 
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.NotElementExpression
 
applies(PlannerContext, ElementGraph, Scope) - Method in class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.OrElementExpression
 
applies(PlannerContext, ElementGraph, Scope) - Method in class cascading.flow.planner.iso.expression.PathScopeExpression
 
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.PlannerLevelElementExpression
 
applies - Variable in class cascading.flow.planner.iso.expression.ScopeExpression
 
applies(PlannerContext, ElementGraph, FlowElement) - Method in class cascading.flow.planner.iso.expression.TypeExpression
 
appliesToAllPaths() - Method in class cascading.flow.planner.iso.expression.ScopeExpression
 
appliesToAnyPath() - Method in class cascading.flow.planner.iso.expression.ScopeExpression
 
appliesToEachPath() - Method in class cascading.flow.planner.iso.expression.ScopeExpression
 
apply(Flow<Config>, List<FlowStep<Config>>, FlowStep<Config>) - Method in interface cascading.flow.FlowStepStrategy
 
apply(Visibility, Object) - Method in interface cascading.management.annotation.Sanitizer
Applies the custom sanitization to the given value for the given visibility.
apply(Visibility, Object) - Method in class cascading.management.annotation.URISanitizer
 
apply(String, ConfigDef.Getter) - Method in class cascading.property.ConfigDef
 
apply(ConfigDef.Mode, ConfigDef.Setter) - Method in class cascading.property.ConfigDef
 
ApplyAssertionLevelTransformer - Class in cascading.flow.planner.rule.transformer
 
ApplyAssertionLevelTransformer() - Constructor for class cascading.flow.planner.rule.transformer.ApplyAssertionLevelTransformer
 
ApplyDebugLevelTransformer - Class in cascading.flow.planner.rule.transformer
 
ApplyDebugLevelTransformer() - Constructor for class cascading.flow.planner.rule.transformer.ApplyDebugLevelTransformer
 
applyFields(Comparable...) - Method in class cascading.tuple.Fields
Method applyFields returns a new Fields instance with the given field names, replacing any existing type information within the new instance.
applyType(Comparable, Type) - Method in class cascading.tuple.Fields
Method applyType should be used to associate a Type with a given field name or position.
applyTypes(Fields) - Method in class cascading.tuple.Fields
Method applyType should be used to associate Type with a given field name or position as declared in the given Fields parameter.
applyTypes(Type...) - Method in class cascading.tuple.Fields
Method applyTypes returns a new Fields instance with the given types, replacing any existing type information within the new instance.
AppProps - Class in cascading.property
Class AppProps is a fluent helper for setting various application level properties that every Flow may or may not be required to have set.
AppProps() - Constructor for class cascading.property.AppProps
 
AppProps(String, String) - Constructor for class cascading.property.AppProps
Sets the name and version of this application.
appProps() - Static method in class cascading.property.AppProps
Creates a new AppProps instance.
arc(ElementExpression, ScopeExpression, ElementExpression) - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
arcs(ElementExpression...) - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
areCountersAvailable(JobStatus) - Method in class cascading.stats.CounterCache
 
areSinksStale() - Method in class cascading.flow.BaseFlow
 
areSinksStale() - Method in interface cascading.flow.Flow
Method areSinksStale returns true if any of the sinks referenced are out of date in relation to the sources.
areSourcesNewer(long) - Method in class cascading.flow.BaseFlow
 
areSourcesNewer(long) - Method in interface cascading.flow.Flow
Method areSourcesNewer returns true if any source is newer than the given sinkModified date value.
ARGS - Static variable in class cascading.tuple.Fields
Field ARGS represents all fields used as the arguments for the current operation
argumentsBuilder - Variable in class cascading.flow.stream.element.OperatorStage
 
argumentSelector - Variable in class cascading.pipe.Operator
Field argumentSelector
argumentSelectors - Variable in class cascading.operation.filter.Logic
Field fields
argumentsEntry - Variable in class cascading.flow.stream.element.OperatorStage
 
argumentsSelector - Variable in class cascading.flow.stream.element.OperatorStage
 
asArray(Tuple, T[]) - Static method in class cascading.tuple.Tuples
Method asArray copies the elements of the given Tuple instance to the given Object array.
asArray(Tuple, CoercibleType[], Class[], Object[]) - Static method in class cascading.tuple.Tuples
 
asClass(Type) - Static method in class cascading.tuple.coerce.Coercions
Method asClass is a convenience method for casting the given type to a Class if an instance of Class or to Object if not.
asClasses(String, String) - Static method in class cascading.util.Util
Converts a given comma separated String of Exception names into a List of classes.
asCollection(Flow, Tap, C) - Static method in class cascading.CascadingTestCase
 
asCollection(Flow, Tap, Fields, C) - Static method in class cascading.CascadingTestCase
 
asCollection(TupleEntryIterator, C) - Static method in class cascading.CascadingTestCase
 
asCollection(TupleEntryIterator, Fields, C) - Static method in class cascading.CascadingTestCase
 
asCollection(Tuple) - Static method in class cascading.tuple.Tuples
 
asDeclaration(Fields) - Static method in class cascading.tuple.Fields
Method asDeclaration returns a new Fields instance for use as a declarator based on the given fields value.
asExtentMaskedSubGraph(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
Returns a new ElementGraph (a MaskedSubGraph) of the given ElementGraph that will not contain the Extent head or tail instances.
asFieldName(Comparable) - Static method in class cascading.tuple.Fields
 
asFlatMap(Map<Object, Object>) - Static method in class cascading.property.PropertyUtil
 
asIterableOf(Class<T>) - Method in class cascading.tuple.TupleEntry
Method asIterableOf returns an Iterable instance that will coerce all Tuple elements into the given type parameter.
asList(Flow, Tap) - Static method in class cascading.CascadingTestCase
 
asList(Flow, Tap, Fields) - Static method in class cascading.CascadingTestCase
 
asList() - Method in class cascading.flow.planner.graph.IgnoreAnnotationsHashSet
 
asModifiable(T) - Static method in class cascading.tuple.Tuples
Method asModifiable marks the given Tuple instance as modifiable.
asNonPrimitive(Class) - Static method in class cascading.tuple.coerce.Coercions
Returns the primitive wrapper fo the given type, if the given type represents a primitive, otherwise the type is returned.
asNonPrimitive(Class[]) - Static method in class cascading.tuple.coerce.Coercions
 
asPathList(List<GraphPath<Duct, DuctGraph.Ordinal>>) - Static method in class cascading.flow.stream.graph.StreamGraph
 
AssemblyPlanner - Interface in cascading.flow
Interface AssemblyPlanner is used to allow for lazy evaluation of a pipe assembly during planning of a Flow.
AssemblyPlanner.Context - Interface in cascading.flow
 
assemblyPlanners - Variable in class cascading.flow.FlowDef
 
Asserted - Class in cascading.flow.planner.iso.assertion
 
Asserted(PlannerContext, GraphAssert, ElementGraph, String, GraphAssert.AssertionType, Match) - Constructor for class cascading.flow.planner.iso.assertion.Asserted
 
AssertEquals - Class in cascading.operation.assertion
Class AssertEquals asserts the number of constructor values is equal to the number of argument values Tuple and each constructor value is .equals() to its corresponding argument value.
AssertEquals(Object...) - Constructor for class cascading.operation.assertion.AssertEquals
Constructor AssertEquals creates a new AssertEquals instance.
AssertEqualsAll - Class in cascading.operation.assertion
Class AssertEqualsAll asserts that every value in the argument values Tuple is equal to the value provided on the constructor.
AssertEqualsAll(Object) - Constructor for class cascading.operation.assertion.AssertEqualsAll
Constructor AssertEqualsAll creates a new AssertEqualsAll instance.
assertFails(Long) - Method in class cascading.operation.assertion.AssertGroupBase
 
assertFails(Long) - Method in class cascading.operation.assertion.AssertGroupSizeEquals
 
assertFails(Long) - Method in class cascading.operation.assertion.AssertGroupSizeLessThan
 
assertFails(Long) - Method in class cascading.operation.assertion.AssertGroupSizeMoreThan
 
AssertGroupBase - Class in cascading.operation.assertion
 
AssertGroupBase(String, long) - Constructor for class cascading.operation.assertion.AssertGroupBase
 
AssertGroupBase(String, String, long) - Constructor for class cascading.operation.assertion.AssertGroupBase
 
AssertGroupBase.Context - Class in cascading.operation.assertion
 
AssertGroupBase.Context() - Constructor for class cascading.operation.assertion.AssertGroupBase.Context
 
AssertGroupSizeEquals - Class in cascading.operation.assertion
Class AssertGroupSizeEquals is an GroupAssertion that asserts the number of items in the current group is equal the given size.
AssertGroupSizeEquals(long) - Constructor for class cascading.operation.assertion.AssertGroupSizeEquals
Constructor AssertGroupSizeEquals creates a new AssertGroupSizeEquals instance.
AssertGroupSizeEquals(String, long) - Constructor for class cascading.operation.assertion.AssertGroupSizeEquals
Constructor AssertGroupSizeEquals creates a new AssertGroupSizeEquals instance.
AssertGroupSizeLessThan - Class in cascading.operation.assertion
Class AssertGroupSizeEquals is an GroupAssertion that asserts the number of items in the current group is less than the given size.
AssertGroupSizeLessThan(long) - Constructor for class cascading.operation.assertion.AssertGroupSizeLessThan
Constructor AssertGroupSizeLessThan creates a new AssertGroupSizeLessThan instance.
AssertGroupSizeLessThan(String, long) - Constructor for class cascading.operation.assertion.AssertGroupSizeLessThan
Constructor AssertGroupSizeLessThan creates a new AssertGroupSizeLessThan instance.
AssertGroupSizeMoreThan - Class in cascading.operation.assertion
Class AssertGroupSizeEquals is an GroupAssertion that asserts the number of items in the current group is more than the given size.
AssertGroupSizeMoreThan(long) - Constructor for class cascading.operation.assertion.AssertGroupSizeMoreThan
Constructor AssertGroupSizeMoreThan creates a new AssertGroupSizeMoreThan instance.
AssertGroupSizeMoreThan(String, long) - Constructor for class cascading.operation.assertion.AssertGroupSizeMoreThan
Constructor AssertGroupSizeMoreThan creates a new AssertGroupSizeMoreThan instance.
assertion(PlannerContext, E) - Method in class cascading.flow.planner.iso.assertion.GraphAssert
 
Assertion<PC> - Interface in cascading.operation
Interface Assertion is the base interface for all stream assertions.
ASSERTION_LEVEL - Static variable in class cascading.flow.FlowConnectorProps
 
AssertionException - Exception in cascading.operation
Class AssertionException is the exception that must be thrown when an Assertion fails.
AssertionException() - Constructor for exception cascading.operation.AssertionException
 
AssertionException(String) - Constructor for exception cascading.operation.AssertionException
 
AssertionException(String, Throwable) - Constructor for exception cascading.operation.AssertionException
 
AssertionException(Throwable) - Constructor for exception cascading.operation.AssertionException
 
assertionLevel - Variable in class cascading.flow.FlowDef
 
AssertionLevel - Enum in cascading.operation
Enum AssertionLevel designates the level of a given Assertion instance.
AssertMatches - Class in cascading.operation.assertion
Class AssertMatches matches the given regular expression patternString against the whole argument Tuple by joining each individual element of the Tuple with a tab character (\t) unless otherwise specified.
AssertMatches(String) - Constructor for class cascading.operation.assertion.AssertMatches
Constructor AssertMatches creates a new AssertMatches instance.
AssertMatches(String, String) - Constructor for class cascading.operation.assertion.AssertMatches
Constructor AssertMatches creates a new AssertMatches instance.
AssertMatches(String, boolean) - Constructor for class cascading.operation.assertion.AssertMatches
Constructor AssertMatches creates a new AssertMatches instance.
AssertMatches(String, boolean, String) - Constructor for class cascading.operation.assertion.AssertMatches
Constructor AssertMatches creates a new AssertMatches instance.
AssertMatchesAll - Class in cascading.operation.assertion
Class AssertMatchesAll matches the given regular expression patternString against each argument Tuple element individually.
AssertMatchesAll(String) - Constructor for class cascading.operation.assertion.AssertMatchesAll
Constructor AssertMatchesAll creates a new AssertMatchesAll instance.
AssertMatchesAll(String, boolean) - Constructor for class cascading.operation.assertion.AssertMatchesAll
Constructor AssertMatchesAll creates a new AssertMatchesAll instance.
AssertNotEquals - Class in cascading.operation.assertion
Class AssertNotEquals asserts the number of constructor values is equal to the number of argument values Tuple and each constructor value is not .equals() to its corresponding argument value.
AssertNotEquals(Object...) - Constructor for class cascading.operation.assertion.AssertNotEquals
Constructor AssertEquals creates a new AssertEquals instance.
AssertNotNull - Class in cascading.operation.assertion
Class AssertNotNull asserts that every value in the argument values Tuple is not a null value.
AssertNotNull() - Constructor for class cascading.operation.assertion.AssertNotNull
Constructor AssertNotNull creates a new AssertNotNull instance.
AssertNull - Class in cascading.operation.assertion
Class AssertNull asserts that every value in the argument values Tuple is a null value.
AssertNull() - Constructor for class cascading.operation.assertion.AssertNull
Constructor AssertNull creates a new AssertNull instance.
AssertSizeEquals - Class in cascading.operation.assertion
Class AssertSizeEquals asserts that the current Tuple in the stream is exactly the given size.
AssertSizeEquals(int) - Constructor for class cascading.operation.assertion.AssertSizeEquals
Constructor AssertSizeEquals creates a new AssertSizeEquals instance.
AssertSizeLessThan - Class in cascading.operation.assertion
Class AssertSizeLessThan asserts that the current Tuple in the stream has a size less than (<) the given size.
AssertSizeLessThan(int) - Constructor for class cascading.operation.assertion.AssertSizeLessThan
Constructor AssertSizeLessThan creates a new AssertSizeLessThan instance.
AssertSizeMoreThan - Class in cascading.operation.assertion
Class AssertSizeMoreThan asserts that the current Tuple in the stream has a size more than (>) the given size.
AssertSizeMoreThan(int) - Constructor for class cascading.operation.assertion.AssertSizeMoreThan
Constructor AssertSizeMoreThan creates a new AssertSizeMoreThan instance.
asSet(Flow, Tap) - Static method in class cascading.CascadingTestCase
 
asSet(Flow, Tap, Fields) - Static method in class cascading.CascadingTestCase
 
asSubGraph(ElementGraph, ElementGraph, Set<FlowElement>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
asSubGraphOf(ElementGraph, ElementGraph) - Method in class cascading.flow.planner.iso.transformer.SubGraphTransformer
 
asType(String) - Static method in class cascading.tuple.coerce.Coercions
Method asType is a convenience method for looking up a type name (like "int" or "java.lang.String" to its corresponding Class or instance of CoercibleType.
asUnmodifiable(T) - Static method in class cascading.tuple.Tuples
Method asUnmodifiable marks the given Tuple instance as unmodifiable.
Average - Class in cascading.operation.aggregator
Class Average is an Aggregator that returns the average of all numeric values in the current group.
Average() - Constructor for class cascading.operation.aggregator.Average
Constructs a new instance that returns the average of the values encountered in the field name "average".
Average(Fields) - Constructor for class cascading.operation.aggregator.Average
Constructs a new instance that returns the average of the values encountered in the given fieldDeclaration field name.
Average.Context - Class in cascading.operation.aggregator
Class Context is used to hold intermediate values.
Average.Context(CoercibleType) - Constructor for class cascading.operation.aggregator.Average.Context
 
AverageBy - Class in cascading.pipe.assembly
Class AverageBy is used to average values associated with duplicate keys in a tuple stream.
AverageBy(Fields, Fields) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Fields, Fields, AverageBy.Include) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe, Fields, Fields, Fields, AverageBy.Include) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe, Fields, Fields, Fields, AverageBy.Include, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe, Fields, Fields, Fields, AverageBy.Include) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe, Fields, Fields, Fields, AverageBy.Include, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe[], Fields, Fields, Fields, AverageBy.Include) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(Pipe[], Fields, Fields, Fields, AverageBy.Include, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe[], Fields, Fields, Fields, AverageBy.Include) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy(String, Pipe[], Fields, Fields, Fields, AverageBy.Include, int) - Constructor for class cascading.pipe.assembly.AverageBy
Constructor AverageBy creates a new AverageBy instance.
AverageBy.AverageFinal - Class in cascading.pipe.assembly
Class AverageFinal is used to finalize the average operation on the Reduce side of the process.
AverageBy.AverageFinal(Fields) - Constructor for class cascading.pipe.assembly.AverageBy.AverageFinal
Constructs a new instance that returns the average of the values encountered in the given fieldDeclaration field name.
AverageBy.AverageFinal.Context - Class in cascading.pipe.assembly
Class Context is used to hold intermediate values.
AverageBy.AverageFinal.Context(Fields) - Constructor for class cascading.pipe.assembly.AverageBy.AverageFinal.Context
 
AverageBy.AveragePartials - Class in cascading.pipe.assembly
Class AveragePartials is a AggregateBy.Functor that is used to count and sum observed duplicates from the tuple stream.
AverageBy.AveragePartials(Fields) - Constructor for class cascading.pipe.assembly.AverageBy.AveragePartials
Constructor AveragePartials creates a new AveragePartials instance.
AverageBy.AveragePartials(Fields, AverageBy.Include) - Constructor for class cascading.pipe.assembly.AverageBy.AveragePartials
 
AverageBy.Include - Enum in cascading.pipe.assembly
 

B

BaseAnnotatedElementGraph - Class in cascading.flow.planner.graph
 
BaseAnnotatedElementGraph() - Constructor for class cascading.flow.planner.graph.BaseAnnotatedElementGraph
 
BaseAssertion<C> - Class in cascading.operation.assertion
Class BaseAssertion is a convenience class for Assertion implementations.
BaseAssertion() - Constructor for class cascading.operation.assertion.BaseAssertion
 
BaseAssertion(String) - Constructor for class cascading.operation.assertion.BaseAssertion
 
BaseAssertion(int) - Constructor for class cascading.operation.assertion.BaseAssertion
 
BaseAssertion(int, String) - Constructor for class cascading.operation.assertion.BaseAssertion
 
BaseCachedNodeStats<Config,JobStatus,Counters> - Class in cascading.stats
 
BaseCachedNodeStats(FlowNode, ClientState) - Constructor for class cascading.stats.BaseCachedNodeStats
Constructor BaseHadoopNodeStats creates a new BaseHadoopNodeStats instance.
BaseCachedStepStats<Configuration,JobStatusClient,Counters> - Class in cascading.stats
 
BaseCachedStepStats(FlowStep, ClientState) - Constructor for class cascading.stats.BaseCachedStepStats
 
BaseCacheFactory<Key,Value,Config> - Class in cascading.util.cache
Base class for all CacheFactories for creating CascadingCache instances.
BaseCacheFactory() - Constructor for class cascading.util.cache.BaseCacheFactory
 
BaseCascade - Class in cascading.cascade
 
BaseCascade() - Constructor for class cascading.cascade.BaseCascade
for testing
BaseCascade.CascadeJob - Class in cascading.cascade
Class CascadeJob manages Flow execution in the current Cascade instance.
BaseCascade.CascadeJob(Flow) - Constructor for class cascading.cascade.BaseCascade.CascadeJob
 
BaseElementGraph - Class in cascading.flow.planner.graph
 
BaseElementGraph() - Constructor for class cascading.flow.planner.graph.BaseElementGraph
 
BaseElementGraph(DirectedGraph<FlowElement, Scope>) - Constructor for class cascading.flow.planner.graph.BaseElementGraph
 
BaseFlow<Config> - Class in cascading.flow
 
BaseFlow() - Constructor for class cascading.flow.BaseFlow
Used for testing.
BaseFlow(PlatformInfo, String) - Constructor for class cascading.flow.BaseFlow
Does not initialize stats
BaseFlow(PlatformInfo, Map<Object, Object>, Config, String, Map<String, String>) - Constructor for class cascading.flow.BaseFlow
 
BaseFlow(PlatformInfo, Map<Object, Object>, Config, FlowDef) - Constructor for class cascading.flow.BaseFlow
 
BaseFlow.FlowHolder - Class in cascading.flow
Class FlowHolder is a helper class for wrapping Flow instances.
BaseFlow.FlowHolder() - Constructor for class cascading.flow.BaseFlow.FlowHolder
 
BaseFlow.FlowHolder(Flow) - Constructor for class cascading.flow.BaseFlow.FlowHolder
 
BaseFlowNode - Class in cascading.flow.planner
 
BaseFlowNode(String, int) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(String, int, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(ElementGraph) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(ElementGraph, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(ElementGraph, List<? extends ElementGraph>) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(FlowElementGraph, ElementGraph, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(FlowElementGraph, ElementGraph, List<? extends ElementGraph>) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNode(FlowElementGraph, ElementGraph, List<? extends ElementGraph>, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowNode
 
BaseFlowNodeFactory - Class in cascading.flow.planner
 
BaseFlowNodeFactory() - Constructor for class cascading.flow.planner.BaseFlowNodeFactory
 
BaseFlowStep<Config> - Class in cascading.flow.planner
Class FlowStep is an internal representation of a given Job to be executed on a remote cluster.
BaseFlowStep(String, int) - Constructor for class cascading.flow.planner.BaseFlowStep
 
BaseFlowStep(String, int, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowStep
 
BaseFlowStep(String, int, FlowNodeGraph, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowStep
 
BaseFlowStep(ElementGraph, FlowNodeGraph) - Constructor for class cascading.flow.planner.BaseFlowStep
 
BaseFlowStep(ElementGraph, FlowNodeGraph, Map<String, String>) - Constructor for class cascading.flow.planner.BaseFlowStep
 
BaseFlowStepFactory<Config> - Class in cascading.flow.planner
 
BaseFlowStepFactory() - Constructor for class cascading.flow.planner.BaseFlowStepFactory
 
BaseFlowStepFactory(FlowNodeFactory) - Constructor for class cascading.flow.planner.BaseFlowStepFactory
 
BaseJoiner - Class in cascading.pipe.joiner
 
BaseJoiner() - Constructor for class cascading.pipe.joiner.BaseJoiner
 
BaseJoiner(Fields) - Constructor for class cascading.pipe.joiner.BaseJoiner
 
BaseOperation<Context> - Class in cascading.operation
Class BaseOperation is the base class of predicate types that are applied to Tuple streams via the Each or Every Pipe.
BaseOperation() - Constructor for class cascading.operation.BaseOperation
Constructs a new instance that returns an Fields.UNKNOWN Tuple and accepts any number of arguments.
BaseOperation(Fields) - Constructor for class cascading.operation.BaseOperation
Constructs a new instance that returns the fields declared in fieldDeclaration and accepts any number of arguments.
BaseOperation(int) - Constructor for class cascading.operation.BaseOperation
Constructs a new instance that returns an unknown field set and accepts the given numArgs number of arguments.
BaseOperation(int, Fields) - Constructor for class cascading.operation.BaseOperation
Constructs a new instance that returns the fields declared in fieldDeclaration and accepts numArgs number of arguments.
BasePartitionTap<Config,Input,Output> - Class in cascading.tap.partition
 
BasePartitionTap(Tap, Partition, int) - Constructor for class cascading.tap.partition.BasePartitionTap
 
BasePartitionTap(Tap, Partition, SinkMode) - Constructor for class cascading.tap.partition.BasePartitionTap
 
BasePartitionTap(Tap, Partition, SinkMode, boolean, int) - Constructor for class cascading.tap.partition.BasePartitionTap
 
BasePartitionTap.Counters - Enum in cascading.tap.partition
 
BasePartitionTap.PartitionCollector - Class in cascading.tap.partition
 
BasePartitionTap.PartitionCollector(FlowProcess<? extends Config>) - Constructor for class cascading.tap.partition.BasePartitionTap.PartitionCollector
 
BasePartitionTap.PartitionScheme<Config,Input,Output> - Class in cascading.tap.partition
 
BasePartitionTap.PartitionScheme(Scheme) - Constructor for class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
BasePartitionTap.PartitionScheme(Scheme, Fields) - Constructor for class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
BaseProcessGraph<Process extends ProcessModel> - Class in cascading.flow.planner.process
 
BaseProcessGraph() - Constructor for class cascading.flow.planner.process.BaseProcessGraph
 
BaseState - Class in cascading.management.state
 
BaseState() - Constructor for class cascading.management.state.BaseState
 
BIG_DECIMAL - Static variable in class cascading.tuple.coerce.Coercions
 
BigDecimalCoerce - Class in cascading.tuple.coerce
 
BigDecimalCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.BigDecimalCoerce
 
bind(StreamGraph) - Method in class cascading.flow.stream.duct.Duct
 
bind(StreamGraph) - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
bind(StreamGraph) - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
bind(StreamGraph) - Method in class cascading.flow.stream.element.MemorySpliceGate
 
bind(StreamGraph) - Method in class cascading.flow.stream.element.MergeStage
 
bind(StreamGraph) - Method in class cascading.flow.stream.element.SinkStage
 
bind() - Method in class cascading.flow.stream.graph.StreamGraph
 
bindEdges() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
bindHeadAndTail(ElementGraph, ElementGraph) - Method in class cascading.flow.planner.graph.BoundedElementMultiGraph
 
binResult(RuleResult) - Method in class cascading.flow.planner.rule.RuleSetExec
 
blockForCompletedChildDetailDuration - Variable in class cascading.flow.planner.FlowStepJob
Field waitTillCompletedChildStatsDuration
BLOCKING - Static variable in class cascading.flow.planner.iso.expression.PathScopeExpression
 
BlockingHashJoinAnnotator - Class in cascading.flow.planner.rule.annotator
 
BlockingHashJoinAnnotator() - Constructor for class cascading.flow.planner.rule.annotator.BlockingHashJoinAnnotator
 
BlockingMode - Enum in cascading.flow.stream.annotations
 
blockOnJob() - Method in class cascading.flow.planner.FlowStepJob
 
blockOnPredecessors() - Method in class cascading.flow.planner.FlowStepJob
 
blockTillCompleteOrStopped() - Method in class cascading.flow.planner.FlowStepJob
 
BOOLEAN - Static variable in class cascading.tuple.coerce.Coercions
 
BOOLEAN_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
BooleanCoerce - Class in cascading.tuple.coerce
 
BooleanCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.BooleanCoerce
 
BooleanObjectCoerce - Class in cascading.tuple.coerce
 
BooleanObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.BooleanObjectCoerce
 
BoundariesElementExpression - Class in cascading.flow.planner.rule.elementexpression
 
BoundariesElementExpression() - Constructor for class cascading.flow.planner.rule.elementexpression.BoundariesElementExpression
 
BoundariesElementExpression(ElementCapture) - Constructor for class cascading.flow.planner.rule.elementexpression.BoundariesElementExpression
 
BoundariesElementExpression(TypeExpression.Topo) - Constructor for class cascading.flow.planner.rule.elementexpression.BoundariesElementExpression
 
BoundariesElementExpression(ElementCapture, TypeExpression.Topo) - Constructor for class cascading.flow.planner.rule.elementexpression.BoundariesElementExpression
 
boundary - Variable in class cascading.flow.stream.element.BoundaryStage
 
Boundary - Class in cascading.pipe
The Boundary class is only used internally by the planner to mark the boundaries between partitions within the element graph.
Boundary() - Constructor for class cascading.pipe.Boundary
Intentionally does not provide a chaining constructor, as Boundary should not be inserted into an assembly by a user.
BOUNDARY_PIPE - Static variable in class cascading.flow.planner.rule.transformer.BoundaryElementFactory
 
BoundaryElementFactory - Class in cascading.flow.planner.rule.transformer
 
BoundaryElementFactory() - Constructor for class cascading.flow.planner.rule.transformer.BoundaryElementFactory
 
BoundaryStage<Incoming,Outgoing> - Class in cascading.flow.stream.element
 
BoundaryStage(FlowProcess, Boundary) - Constructor for class cascading.flow.stream.element.BoundaryStage
 
BoundaryStage(FlowProcess, Boundary, IORole) - Constructor for class cascading.flow.stream.element.BoundaryStage
 
BoundedElementMultiGraph - Class in cascading.flow.planner.graph
 
BoundedElementMultiGraph(ElementGraph, ElementGraph, EnumMultiMap) - Constructor for class cascading.flow.planner.graph.BoundedElementMultiGraph
 
branchNames - Variable in class cascading.flow.stream.element.ElementStage
 
Buffer<Context> - Interface in cascading.operation
A Buffer is similar to an Aggregator by the fact that it operates on unique groups of values.
BufferAfterEveryAssert - Class in cascading.flow.planner.rule.assertion
 
BufferAfterEveryAssert() - Constructor for class cascading.flow.planner.rule.assertion.BufferAfterEveryAssert
 
BufferAfterEveryExpression - Class in cascading.flow.planner.rule.expression
 
BufferAfterEveryExpression() - Constructor for class cascading.flow.planner.rule.expression.BufferAfterEveryExpression
 
BufferCall<C> - Interface in cascading.operation
Interface BufferCall provides access to the current Buffer invocation arguments.
BufferEveryWindow - Class in cascading.flow.stream.element
 
BufferEveryWindow(FlowProcess, Every) - Constructor for class cascading.flow.stream.element.BufferEveryWindow
 
BufferJoin - Class in cascading.pipe.joiner
Class BufferJoiner notifies the Cascading planner that the next Buffer instance will implement a custom join strategy.
BufferJoin() - Constructor for class cascading.pipe.joiner.BufferJoin
 
buildFlow(FlowDef, RuleRegistrySet) - Method in class cascading.flow.planner.FlowPlanner
 
buildGraph(FlowNodeFactory, FlowElementGraph, List<? extends ElementGraph>, Map<ElementGraph, List<? extends ElementGraph>>) - Method in class cascading.flow.planner.process.FlowNodeGraph
 
buildGraph(FlowStepFactory, FlowElementGraph, Map<ElementGraph, List<? extends ElementGraph>>, Map<ElementGraph, List<? extends ElementGraph>>) - Method in class cascading.flow.planner.process.FlowStepGraph
 
buildProperties() - Method in class cascading.property.Props
Method buildProperties returns a new Properties instance with all property values for this type.
buildProperties(Map<Object, Object>) - Method in class cascading.property.Props
Method buildProperties returns a new Properties instance with all property values for this type using the given Map of property values as defaults.
buildProperties(Iterable<Map.Entry<String, String>>) - Method in class cascading.property.Props
Method buildProperties returns a new Properties instance with all property values for this type using the given Iterable> of property values as defaults.
buildProperties(Properties) - Method in class cascading.property.Props
Method buildProperties returns a new Properties instance with all property values for this type using the given Properties instance of property values as defaults.

C

cachedCounters(boolean) - Method in class cascading.stats.BaseCachedNodeStats
 
cachedCounters(boolean) - Method in class cascading.stats.BaseCachedStepStats
 
cachedCounters() - Method in class cascading.stats.CounterCache
 
cachedCounters(boolean) - Method in class cascading.stats.CounterCache
 
CacheEvictionCallback<Key,Value> - Interface in cascading.util.cache
CacheEvictionCallBack is an interface to be used in conjunction with CascadingCache instances.
call() - Method in class cascading.cascade.BaseCascade.CascadeJob
 
call() - Method in class cascading.flow.planner.FlowStepJob
 
call() - Method in class cascading.flow.stream.element.SourceStage
 
canonical(Object) - Method in class cascading.tuple.coerce.Coercions.Coerce
 
canonical(Object) - Method in interface cascading.tuple.type.CoercibleType
 
canonical(Object) - Method in class cascading.tuple.type.DateType
 
canonicalHash(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
canonicalHash(Graph<FlowElement, Scope>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
captureChildDetailInternal() - Method in class cascading.stats.BaseCachedNodeStats
Returns true if was able to capture/refresh the internal child stats cache.
captureDebugTrace(Object) - Static method in class cascading.util.TraceUtil
 
captureDetail(CascadingStats.Type) - Method in class cascading.stats.BaseCachedNodeStats
 
captureDetail(CascadingStats.Type) - Method in class cascading.stats.CascadeStats
 
captureDetail() - Method in class cascading.stats.CascadingStats
Method captureDetail will recursively capture details about nested systems.
captureDetail(CascadingStats.Type) - Method in class cascading.stats.CascadingStats
 
captureDetail(CascadingStats.Type) - Method in class cascading.stats.FlowStats
 
captureDetail() - Method in class cascading.stats.process.ProcessStepStats
 
captureDetail(CascadingStats.Type) - Method in class cascading.stats.process.ProcessStepStats
 
captureMap - Variable in class cascading.flow.planner.iso.finder.Match
 
Cascade - Interface in cascading.cascade
A Cascade is an assembly of Flow instances that share or depend on equivalent Tap instances and are executed as a single group.
CascadeConnector - Class in cascading.cascade
Class CascadeConnector is used to construct a new Cascade instance from a collection of Flow instance.
CascadeConnector() - Constructor for class cascading.cascade.CascadeConnector
Constructor CascadeConnector creates a new CascadeConnector instance.
CascadeConnector(Map<Object, Object>) - Constructor for class cascading.cascade.CascadeConnector
Constructor CascadeConnector creates a new CascadeConnector instance.
CascadeDef - Class in cascading.cascade
Class CascadeDef is a fluent interface for defining a Cascade.
CascadeDef() - Constructor for class cascading.cascade.CascadeDef
Constructor CascadeDef creates a new CascadeDef instance.
cascadeDef() - Static method in class cascading.cascade.CascadeDef
Creates a new instance of a CascadeDef.
CascadeException - Exception in cascading.cascade
Class CascadeException is thrown by the Cascade class.
CascadeException() - Constructor for exception cascading.cascade.CascadeException
Constructor CascadeException creates a new CascadeException instance.
CascadeException(String) - Constructor for exception cascading.cascade.CascadeException
Constructor CascadeException creates a new CascadeException instance.
CascadeException(String, Throwable) - Constructor for exception cascading.cascade.CascadeException
Constructor CascadeException creates a new CascadeException instance.
CascadeException(Throwable) - Constructor for exception cascading.cascade.CascadeException
Constructor CascadeException creates a new CascadeException instance.
CascadeListener - Interface in cascading.cascade
Interface CascadeListener provides hooks for receiving events on various stages of a Cascade execution.
CascadeProps - Class in cascading.cascade
Class CascadeProps is a fluent helper class for setting various Cascade level properties passed through a CascadeConnector.
CascadeProps() - Constructor for class cascading.cascade.CascadeProps
 
cascadeProps() - Static method in class cascading.cascade.CascadeProps
Creates a new CascadeProps instance.
Cascades - Class in cascading.cascade
Class Cascades provides useful utilities for use in constructing Cascade and Flow instances via the CascadeConnector and FlowConnector, respectively.
Cascades() - Constructor for class cascading.cascade.Cascades
 
CascadeStats - Class in cascading.stats
Class CascadeStats collects Cascade specific statistics.
CascadeStats(Cascade, ClientState) - Constructor for class cascading.stats.CascadeStats
 
cascading - package cascading
 
CASCADING - Static variable in class cascading.util.Version
 
cascading.cascade - package cascading.cascade
 
cascading.cascade.planner - package cascading.cascade.planner
 
cascading.flow - package cascading.flow
 
cascading.flow.planner - package cascading.flow.planner
 
cascading.flow.planner.graph - package cascading.flow.planner.graph
 
cascading.flow.planner.iso - package cascading.flow.planner.iso
 
cascading.flow.planner.iso.assertion - package cascading.flow.planner.iso.assertion
 
cascading.flow.planner.iso.expression - package cascading.flow.planner.iso.expression
 
cascading.flow.planner.iso.finder - package cascading.flow.planner.iso.finder
 
cascading.flow.planner.iso.subgraph - package cascading.flow.planner.iso.subgraph
 
cascading.flow.planner.iso.subgraph.iterator - package cascading.flow.planner.iso.subgraph.iterator
 
cascading.flow.planner.iso.subgraph.partitioner - package cascading.flow.planner.iso.subgraph.partitioner
 
cascading.flow.planner.iso.transformer - package cascading.flow.planner.iso.transformer
 
cascading.flow.planner.process - package cascading.flow.planner.process
 
cascading.flow.planner.rule - package cascading.flow.planner.rule
 
cascading.flow.planner.rule.annotator - package cascading.flow.planner.rule.annotator
 
cascading.flow.planner.rule.assertion - package cascading.flow.planner.rule.assertion
 
cascading.flow.planner.rule.elementexpression - package cascading.flow.planner.rule.elementexpression
 
cascading.flow.planner.rule.expression - package cascading.flow.planner.rule.expression
 
cascading.flow.planner.rule.expressiongraph - package cascading.flow.planner.rule.expressiongraph
 
cascading.flow.planner.rule.partitioner - package cascading.flow.planner.rule.partitioner
 
cascading.flow.planner.rule.transformer - package cascading.flow.planner.rule.transformer
 
cascading.flow.planner.rule.util - package cascading.flow.planner.rule.util
 
cascading.flow.process - package cascading.flow.process
 
cascading.flow.stream - package cascading.flow.stream
 
cascading.flow.stream.annotations - package cascading.flow.stream.annotations
 
cascading.flow.stream.duct - package cascading.flow.stream.duct
 
cascading.flow.stream.element - package cascading.flow.stream.element
 
cascading.flow.stream.graph - package cascading.flow.stream.graph
 
cascading.flow.stream.util - package cascading.flow.stream.util
 
cascading.management - package cascading.management
 
cascading.management.annotation - package cascading.management.annotation
 
cascading.management.state - package cascading.management.state
 
cascading.operation - package cascading.operation
 
cascading.operation.aggregator - package cascading.operation.aggregator
 
cascading.operation.assertion - package cascading.operation.assertion
 
cascading.operation.buffer - package cascading.operation.buffer
 
cascading.operation.filter - package cascading.operation.filter
 
cascading.operation.function - package cascading.operation.function
 
cascading.operation.regex - package cascading.operation.regex
 
cascading.operation.state - package cascading.operation.state
 
cascading.operation.text - package cascading.operation.text
 
cascading.pipe - package cascading.pipe
 
cascading.pipe.assembly - package cascading.pipe.assembly
 
cascading.pipe.joiner - package cascading.pipe.joiner
 
cascading.property - package cascading.property
 
cascading.provider - package cascading.provider
 
cascading.scheme - package cascading.scheme
 
cascading.scheme.util - package cascading.scheme.util
 
cascading.stats - package cascading.stats
 
cascading.stats.process - package cascading.stats.process
 
cascading.tap - package cascading.tap
 
cascading.tap.partition - package cascading.tap.partition
 
cascading.tap.type - package cascading.tap.type
 
cascading.tuple - package cascading.tuple
 
cascading.tuple.coerce - package cascading.tuple.coerce
 
cascading.tuple.collect - package cascading.tuple.collect
 
cascading.tuple.io - package cascading.tuple.io
 
cascading.tuple.type - package cascading.tuple.type
 
cascading.tuple.util - package cascading.tuple.util
 
cascading.util - package cascading.util
 
cascading.util.cache - package cascading.util.cache
 
cascading.util.jgrapht - package cascading.util.jgrapht
 
CASCADING_BUILD_NUMBER - Static variable in class cascading.util.Version
 
CASCADING_FLOW_ID - Static variable in interface cascading.flow.Flow
 
CASCADING_FLOW_NODE - Static variable in interface cascading.flow.FlowNode
 
CASCADING_FLOW_STEP_ID - Static variable in interface cascading.flow.FlowStep
 
CASCADING_RELEASE_MAJOR - Static variable in class cascading.util.Version
 
CASCADING_RELEASE_MINOR - Static variable in class cascading.util.Version
 
CASCADING_SERVICES - Static variable in class cascading.management.CascadingServices
 
CASCADING_SERVICES_JAR - Static variable in class cascading.management.CascadingServices
 
CASCADING_SERVICES_JAR_DISABLE - Static variable in class cascading.management.CascadingServices
 
CascadingCache<Key,Value> - Interface in cascading.util.cache
Interface that defines a Cache.
CascadingException - Exception in cascading
Class CascadingException is the base class of all Cascading exceptions.
CascadingException() - Constructor for exception cascading.CascadingException
Constructor CascadingException creates a new CascadingException instance.
CascadingException(String) - Constructor for exception cascading.CascadingException
Constructor CascadingException creates a new CascadingException instance.
CascadingException(String, Throwable) - Constructor for exception cascading.CascadingException
Constructor CascadingException creates a new CascadingException instance.
CascadingException(Throwable) - Constructor for exception cascading.CascadingException
Constructor CascadingException creates a new CascadingException instance.
CascadingFactory<Config,Instance> - Interface in cascading.provider
Interface CascadingFactory defines a pluggable "factory" class that can be loaded by the FactoryLoader utility.
CascadingService - Interface in cascading.provider
Interface CascadingService defines a pluggable "service" class that can be loaded by the ServiceLoader utility.
cascadingServices - Variable in class cascading.flow.FlowSession
 
CascadingServices - Class in cascading.management
Class CascadingServices is the root class for pluggable services Cascading can call out to for distributed monitoring and management systems.
CascadingServices(Map<Object, Object>) - Constructor for class cascading.management.CascadingServices
 
CascadingServices.NullDocumentService - Class in cascading.management
Class NullDocumentService provides a null implementation.
CascadingServices.NullDocumentService() - Constructor for class cascading.management.CascadingServices.NullDocumentService
 
CascadingServices.NullMetricsService - Class in cascading.management
Class NullMetricsService provides a null implementation.
CascadingServices.NullMetricsService() - Constructor for class cascading.management.CascadingServices.NullMetricsService
 
CascadingStats<Child> - Class in cascading.stats
Class CascadingStats is the base class for all Cascading statistics gathering.
CascadingStats(String, ClientState) - Constructor for class cascading.stats.CascadingStats
 
CascadingStats.Status - Enum in cascading.stats
 
CascadingStats.Type - Enum in cascading.stats
 
CascadingTestCase - Class in cascading
Class CascadingTestCase is the base class for all Cascading tests.
CascadingTestCase() - Constructor for class cascading.CascadingTestCase
 
CascadingTestCase(String) - Constructor for class cascading.CascadingTestCase
 
CHARACTER - Static variable in class cascading.tuple.coerce.Coercions
 
CHARACTER_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
CharacterCoerce - Class in cascading.tuple.coerce
 
CharacterCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.CharacterCoerce
 
CharacterObjectCoerce - Class in cascading.tuple.coerce
 
CharacterObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.CharacterObjectCoerce
 
checkForUpdate(PlatformInfo) - Static method in class cascading.util.Update
 
checkForUpdate() - Method in class cascading.util.Update
 
Checkpoint - Class in cascading.pipe
The Checkpoint pipe, if supported by the current planner, will force data to be persisted at the point in the tuple stream an instance of Checkpoint is inserted into the pipe assembly.
Checkpoint(Pipe) - Constructor for class cascading.pipe.Checkpoint
Constructor Checkpoint creates a new Checkpoint pipe which inherits the name of its previous pipe.
Checkpoint(String, Pipe) - Constructor for class cascading.pipe.Checkpoint
Constructor Checkpoint creates a new Checkpoint pipe with the given name.
CHECKPOINT_TAP_DECORATOR_CLASS - Static variable in class cascading.flow.FlowConnectorProps
 
checkpoints - Variable in class cascading.flow.FlowDef
 
checkpoints - Variable in class cascading.flow.planner.graph.FlowElementGraph
Field checkpoints
checkpointTapRootPath - Variable in class cascading.flow.planner.FlowPlanner
 
classPath - Variable in class cascading.flow.FlowDef
 
clean() - Method in class cascading.flow.planner.BaseFlowStep
 
clean(Config) - Method in class cascading.flow.planner.BaseFlowStep
 
clean(Object) - Method in class cascading.flow.process.ProcessFlowStep
 
cleanField(int, String, Type) - Method in interface cascading.scheme.util.FieldTypeResolver
 
cleanFields(Object[]) - Method in class cascading.scheme.util.DelimitedParser
 
cleanParsedLine(Object[]) - Method in class cascading.scheme.util.DelimitedParser
 
cleanPattern - Variable in class cascading.scheme.util.DelimitedParser
Field cleanPattern
cleansePathName(String) - Static method in class cascading.util.Util
 
cleanSplit(Object[], Pattern, Pattern, String) - Method in class cascading.scheme.util.DelimitedParser
Method cleanSplit will return a quote free array of String values, the given split array will be updated in place.
cleanup() - Method in class cascading.cascade.BaseCascade
 
cleanup() - Method in class cascading.flow.BaseFlow
 
cleanup() - Method in interface cascading.flow.Flow
 
cleanup() - Method in class cascading.flow.process.ProcessFlow
 
cleanup() - Method in class cascading.flow.stream.duct.Duct
 
cleanup() - Method in class cascading.flow.stream.element.ElementStage
 
cleanup() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
cleanup() - Method in class cascading.flow.stream.element.OperatorStage
 
cleanup() - Method in class cascading.flow.stream.element.SinkStage
 
cleanup() - Method in class cascading.flow.stream.graph.StreamGraph
Calls cleanup starting at the head and working forwards
cleanup() - Method in interface cascading.management.UnitOfWork
 
cleanup(FlowProcess, OperationCall<Context>) - Method in class cascading.operation.BaseOperation
Method cleanup does nothing, and may safely be overridden.
cleanup(FlowProcess, OperationCall<Long>) - Method in class cascading.operation.Debug
 
cleanup(FlowProcess, OperationCall) - Method in class cascading.operation.filter.Logic
 
cleanup(FlowProcess, OperationCall) - Method in class cascading.operation.filter.Not
 
cleanup(FlowProcess, OperationCall) - Method in class cascading.operation.function.SetValue
 
cleanup(FlowProcess, OperationCall<Context>) - Method in interface cascading.operation.Operation
The cleanup method is called immediately after the current Operation instance is taken out of play processing Tuples.
cleanup(FlowProcess, OperationCall<AggregateBy.CompositeFunction.Context>) - Method in class cascading.pipe.assembly.AggregateBy.CompositeFunction
 
cleanup(FlowProcess, OperationCall<CascadingCache<Tuple, Object>>) - Method in class cascading.pipe.assembly.Unique.FilterPartialDuplicates
 
cleanup() - Method in class cascading.stats.CascadingStats
Method cleanup destroys any resources allocated by this instance.
clear() - Method in class cascading.tuple.collect.SpillableTupleList
 
clear() - Method in class cascading.tuple.Tuple
Method clear empties this Tuple instance.
clear() - Method in class cascading.tuple.TupleListCollector
Method clear clears all Tuple instances from this instance.
clear() - Method in class cascading.util.cache.DirectMappedCache
 
clear() - Method in class cascading.util.cache.LRUHashMapCache
 
clear() - Method in class cascading.util.cache.OrderedHashMapCache
 
clear() - Method in class cascading.util.jgrapht.IntegerNameProvider
 
ClientState - Class in cascading.management.state
 
ClientState() - Constructor for class cascading.management.state.ClientState
 
clientState - Variable in class cascading.stats.CascadingStats
 
close() - Method in class cascading.tap.partition.BasePartitionTap.PartitionCollector
 
close() - Method in class cascading.tuple.io.TupleInputStream
 
close() - Method in interface cascading.tuple.io.TupleInputStream.ElementReader
 
close() - Method in class cascading.tuple.io.TupleOutputStream
 
close() - Method in interface cascading.tuple.io.TupleOutputStream.ElementWriter
 
close() - Method in class cascading.tuple.TupleChainIterator
Method close closes all underlying resources.
close() - Method in class cascading.tuple.TupleEntryChainIterator
Method close closes all underlying resources.
close() - Method in class cascading.tuple.TupleEntryCollector
Method close closes the underlying resource being written to.
close() - Method in class cascading.tuple.TupleEntryIterableChainIterator
Method close closes all underlying resources.
close() - Method in class cascading.tuple.TupleEntrySchemeCollector
 
close() - Method in class cascading.tuple.TupleEntrySchemeIterator
 
close() - Method in class cascading.util.SingleCloseableInputIterator
 
close() - Method in class cascading.util.SingleValueCloseableIterator
 
CloseableIterator<V> - Interface in cascading.util
Interface CloseableIterator is a helper interface granting an Iterator a close method.
closeCollector(String) - Method in class cascading.tap.partition.BasePartitionTap.PartitionCollector
 
closeCurrent() - Method in class cascading.tuple.TupleChainIterator
 
closeCurrent() - Method in class cascading.tuple.TupleEntryChainIterator
 
closeCurrent() - Method in class cascading.tuple.TupleEntryIterableChainIterator
 
CloseReducingDuct<Group,Incoming,Outgoing> - Class in cascading.flow.stream.duct
 
CloseReducingDuct(Duct<Outgoing, ?>) - Constructor for class cascading.flow.stream.duct.CloseReducingDuct
 
closeTrapCollectors() - Method in class cascading.flow.FlowProcess
 
closeTrapCollectors() - Method in class cascading.flow.FlowProcessWrapper
 
CloseWindow - Interface in cascading.flow.stream.duct
 
closure - Variable in class cascading.flow.stream.element.MemorySpliceGate
 
Coerce - Class in cascading.pipe.assembly
Class Coerce is a SubAssembly that will coerce all incoming Tuple values to the given types.
Coerce(Pipe, Class...) - Constructor for class cascading.pipe.assembly.Coerce
Constructor Coerce creates a new Coerce instance that will coerce all input Tuple values.
Coerce(Pipe, Fields, Class...) - Constructor for class cascading.pipe.assembly.Coerce
Constructor Coerce creates a new Coerce instance that will only coerce the given coerceFields Tuple values.
Coerce(Pipe, Fields) - Constructor for class cascading.pipe.assembly.Coerce
Constructor Coerce creates a new Coerce instance that will only coerce the given coerceFields Tuple values.
coerce(Object) - Method in class cascading.tuple.coerce.BigDecimalCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.BooleanCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.BooleanObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.CharacterCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.CharacterObjectCoerce
 
coerce(Object, Type) - Static method in class cascading.tuple.coerce.Coercions
Method coerce will coerce the given value to the given type using any CoercibleType mapping available.
coerce(CoercibleType, Object, Type) - Static method in class cascading.tuple.coerce.Coercions
Method coerce will coerce the given value to the given type using the given CoercibleType.
coerce(Object, Type) - Method in class cascading.tuple.coerce.Coercions.Coerce
 
coerce(Object) - Method in class cascading.tuple.coerce.Coercions.Coerce
 
coerce(Object) - Method in class cascading.tuple.coerce.DoubleCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.DoubleObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.FloatCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.FloatObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.IntegerCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.IntegerObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.LongCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.LongObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.ObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.ShortCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.ShortObjectCoerce
 
coerce(Object) - Method in class cascading.tuple.coerce.StringCoerce
 
coerce(Object, Type) - Method in interface cascading.tuple.type.CoercibleType
 
coerce(Object, Type) - Method in class cascading.tuple.type.DateType
 
coerceParsedLine(String, Object[]) - Method in class cascading.scheme.util.DelimitedParser
 
coercibleArray(Fields) - Static method in class cascading.tuple.coerce.Coercions
Method coercibleArray will return an array of CoercibleType instances based on the given field type information.
coercibleArray(int, Type[]) - Static method in class cascading.tuple.coerce.Coercions
Method coercibleArray will return an array of CoercibleType instances based on the given type array.
coercibles - Variable in class cascading.scheme.util.DelimitedParser
Fields coercibles
CoercibleType<Canonical> - Interface in cascading.tuple.type
Interface CoercibleType allows Fields instances to be extended with custom type information.
coercibleTypeFor(Type) - Static method in class cascading.tuple.coerce.Coercions
Method coercibleTypeFor returns the CoercibleType for the given Type instance.
Coercions - Class in cascading.tuple.coerce
Coercions class is a helper class for managing primitive value coercions.
Coercions() - Constructor for class cascading.tuple.coerce.Coercions
 
coercions - Static variable in class cascading.tuple.coerce.Coercions
 
Coercions.Coerce<T> - Class in cascading.tuple.coerce
 
Coercions.Coerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.Coercions.Coerce
 
CoGroup - Class in cascading.pipe
The CoGroup pipe allows for two or more tuple streams to join into a single stream via an optional Joiner.
CoGroup(Pipe, Fields, Pipe, Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, Pipe, Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, Pipe, Fields, Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, Pipe, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, Pipe, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe...) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe[], Fields[]) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe[], Fields[], Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe[], Fields[], Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe[], Fields[]) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe[], Fields[], Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe[], Fields[], Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe[], Fields[], Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe[], Fields[], Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, Pipe, Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, Pipe, Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, Pipe, Fields, Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, Pipe, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, Pipe, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe...) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, int, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(Pipe, Fields, int, Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, int, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(Pipe, Fields, int, Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(Pipe, Fields, int, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(Pipe, Fields, int) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(String, Pipe, Fields, int, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(String, Pipe, Fields, int, Fields, Fields) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, int, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(String, Pipe, Fields, int, Fields, Fields, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance.
CoGroup(String, Pipe, Fields, int, Joiner) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
CoGroup(String, Pipe, Fields, int) - Constructor for class cascading.pipe.CoGroup
Constructor CoGroup creates a new CoGroup instance that performs numSelfJoins number of self joins on the given Pipe instance.
Collapsing - Interface in cascading.flow.stream.duct
Collapsing marks a Duct as collapsing start/complete events from multiple incoming paths
collect(TupleEntry) - Method in class cascading.tap.partition.BasePartitionTap.PartitionCollector
 
collect(TupleEntry) - Method in class cascading.tuple.TupleEntryCollector
 
collect(TupleEntry) - Method in class cascading.tuple.TupleEntrySchemeCollector
 
collect(TupleEntry) - Method in class cascading.tuple.TupleListCollector
 
COMBINE_SPLITS - Static variable in class cascading.flow.FlowRuntimeProps
 
commitResource(Config) - Method in class cascading.tap.DecoratorTap
 
commitResource(Config) - Method in class cascading.tap.MultiSinkTap
 
commitResource(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
commitResource(Config) - Method in class cascading.tap.SourceTap
 
commitResource(Config) - Method in class cascading.tap.Tap
Method commitResource allows the underlying resource to be notified when all write processing is successful so that any additional cleanup or processing may be completed.
commitSinks() - Method in class cascading.flow.planner.BaseFlowStep
 
compare(FlowNode, FlowNode) - Method in class cascading.flow.planner.process.FlowNodeGraph.FlowNodeComparator
 
compare(Tuple, Tuple) - Method in class cascading.flow.stream.util.SparseTupleComparator
 
compare(Comparable, Comparable) - Method in class cascading.operation.aggregator.ExtremaValueBase
Allows subclasses to provide own comparison method.
compare(Comparable, Comparable) - Method in class cascading.operation.aggregator.MaxValue
 
compare(Comparable, Comparable) - Method in class cascading.operation.aggregator.MinValue
 
compare(Tuple, Tuple) - Method in class cascading.tuple.Fields
 
compare(T, T) - Method in interface cascading.tuple.StreamComparator
 
compare(Comparable, Comparable) - Method in class cascading.util.NullNotEquivalentComparator
 
compareSet(String[], String, String) - Method in class cascading.management.CascadingServices.NullMetricsService
 
compareSet(String[], int, int) - Method in class cascading.management.CascadingServices.NullMetricsService
 
compareSet(String[], long, long) - Method in class cascading.management.CascadingServices.NullMetricsService
 
compareSet(String[], String, String) - Method in interface cascading.management.MetricsService
 
compareSet(String[], int, int) - Method in interface cascading.management.MetricsService
 
compareSet(String[], long, long) - Method in interface cascading.management.MetricsService
 
compareTo(PlatformInfo) - Method in class cascading.flow.planner.PlatformInfo
 
compareTo(Object) - Method in class cascading.flow.stream.element.GroupingSpliceGate.DelegatedTuple
 
compareTo(Fields) - Method in class cascading.tuple.Fields
Method compareTo compares this instance to the given Fields instance.
compareTo(Object) - Method in class cascading.tuple.Fields
Method compareTo implements Comparable.compareTo(Object).
compareTo(Object) - Method in class cascading.tuple.io.IndexTuple
 
compareTo(IndexTuple) - Method in class cascading.tuple.io.IndexTuple
 
compareTo(Object) - Method in class cascading.tuple.io.TuplePair
 
compareTo(Tuple) - Method in class cascading.tuple.io.TuplePair
 
compareTo(TuplePair) - Method in class cascading.tuple.io.TuplePair
Method compareTo compares this instance to the given TuplePair.
compareTo(Tuple) - Method in class cascading.tuple.Tuple
Method compareTo compares this Tuple to the given Tuple instance.
compareTo(Comparator[], Tuple) - Method in class cascading.tuple.Tuple
 
compareTo(Object) - Method in class cascading.tuple.Tuple
Method compareTo implements the Comparable.compareTo(Object) method.
Comparison<T> - Interface in cascading.tuple
The Comparison interface allows specific underlying type mechanisms to additionally return relevant Comparator implementations when required internally.
complete() - Method in class cascading.cascade.BaseCascade
 
complete() - Method in interface cascading.cascade.Cascade
Method complete begins the current Cascade process if method Cascade.start() was not previously called.
complete() - Method in class cascading.flow.BaseFlow
 
complete() - Method in interface cascading.flow.Flow
Method complete starts the current Flow instance if it has not be previously started, then block until completion.
complete() - Method in class cascading.flow.process.ProcessFlow
 
complete(Duct) - Method in class cascading.flow.stream.duct.Duct
 
complete(Duct) - Method in class cascading.flow.stream.duct.Fork
 
complete(Duct) - Method in class cascading.flow.stream.duct.OpenDuct
 
complete(Duct) - Method in class cascading.flow.stream.element.MemoryCoGroupGate
 
complete(Duct) - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
complete(Duct) - Method in class cascading.flow.stream.element.MergeStage
 
complete(Duct) - Method in class cascading.flow.stream.element.OperatorStage
 
complete(Duct) - Method in class cascading.flow.stream.element.SinkStage
 
complete() - Method in interface cascading.management.UnitOfWork
 
complete(UnitOfWork, int, TimeUnit) - Method in class cascading.management.UnitOfWorkExecutorStrategy
 
complete(UnitOfWork, int, TimeUnit) - Method in interface cascading.management.UnitOfWorkSpawnStrategy
 
complete(FlowProcess, AggregatorCall<Average.Context>) - Method in class cascading.operation.aggregator.Average
 
complete(FlowProcess, AggregatorCall<Context>) - Method in interface cascading.operation.Aggregator
Method complete will be issued last after every TupleEntry has been passed to the Aggregator.aggregate(cascading.flow.FlowProcess, AggregatorCall) method.
complete(FlowProcess, AggregatorCall<Pair<Long[], Tuple>>) - Method in class cascading.operation.aggregator.Count
 
complete(FlowProcess, AggregatorCall<Tuple[]>) - Method in class cascading.operation.aggregator.ExtentBase
 
complete(FlowProcess, AggregatorCall<ExtremaValueBase.Context>) - Method in class cascading.operation.aggregator.ExtremaValueBase
 
complete(FlowProcess, AggregatorCall<Tuple[]>) - Method in class cascading.operation.aggregator.First
 
complete(FlowProcess, AggregatorCall<Pair<Double[], Tuple>>) - Method in class cascading.operation.aggregator.Sum
 
complete(FlowProcess, Tuple) - Method in interface cascading.pipe.assembly.AggregateBy.Functor
Method complete allows the final aggregate computation to be performed before the return value is collected.
complete(FlowProcess, AggregatorCall<AverageBy.AverageFinal.Context>) - Method in class cascading.pipe.assembly.AverageBy.AverageFinal
 
complete(FlowProcess, Tuple) - Method in class cascading.pipe.assembly.AverageBy.AveragePartials
 
complete(FlowProcess, Tuple) - Method in class cascading.pipe.assembly.CountBy.CountPartials
 
complete(FlowProcess, Tuple) - Method in class cascading.pipe.assembly.FirstBy.FirstPartials
 
complete(FlowProcess, Tuple) - Method in class cascading.pipe.assembly.MaxBy.MaxPartials
 
complete(FlowProcess, Tuple) - Method in class cascading.pipe.assembly.MinBy.MinPartials
 
complete(FlowProcess, Tuple) - Method in class cascading.pipe.assembly.SumBy.SumPartials
 
completeCount - Variable in class cascading.flow.stream.element.MergeStage
 
completeGroup(Duct, Outgoing) - Method in class cascading.flow.stream.duct.CloseReducingDuct
 
completeGroup(Duct, Result) - Method in interface cascading.flow.stream.duct.Reducing
 
completeGroup(Duct, TupleEntry) - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
completeGroup(Duct, TupleEntry) - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
ComponentAttributeProvider<T> - Interface in cascading.util.jgrapht
 
CompositeTap<Child extends Tap> - Interface in cascading.tap
Interface CompositeTap marks Tap classes as having child Tap instances.
ConcreteCall<C> - Class in cascading.operation
Class OperationCall is the common base class for FunctionCall, FilterCall, AggregatorCall, ValueAssertionCall, and GroupAssertionCall.
ConcreteCall() - Constructor for class cascading.operation.ConcreteCall
Constructor OperationCall creates a new OperationCall instance.
ConcreteCall(Fields) - Constructor for class cascading.operation.ConcreteCall
Constructor ConcreteCall creates a new ConcreteCall instance.
ConcreteCall(Fields, Fields) - Constructor for class cascading.operation.ConcreteCall
Constructor ConcreteCall creates a new ConcreteCall instance.
ConcreteCall(TupleEntry, TupleEntryCollector) - Constructor for class cascading.operation.ConcreteCall
Constructor OperationCall creates a new OperationCall instance.
ConcreteCall(ConcreteCall<C>) - Constructor for class cascading.operation.ConcreteCall
 
ConcreteCall<Context,IO> - Class in cascading.scheme
The concrete base class for SourceCall and SinkCall.
ConcreteCall() - Constructor for class cascading.scheme.ConcreteCall
 
config - Variable in class cascading.property.ConfigDef
 
configDef - Variable in class cascading.pipe.Pipe
 
ConfigDef - Class in cascading.property
The ConfigDef class allows for the creation of a configuration properties template to be applied to an existing properties configuration set.
ConfigDef() - Constructor for class cascading.property.ConfigDef
 
ConfigDef.Getter - Interface in cascading.property
 
ConfigDef.Mode - Enum in cascading.property
 
ConfigDef.Setter - Interface in cascading.property
 
configRuleRegistryDefaults(RuleRegistry) - Method in class cascading.flow.planner.FlowPlanner
 
configuration - Variable in class cascading.stats.CounterCache
 
configure() - Method in class cascading.flow.planner.BaseFlowStep
 
connect(Collection<Flow>) - Method in class cascading.cascade.CascadeConnector
Given any number of Flow objects, it will connect them and return a new Cascade instance.
connect(String, Collection<Flow>) - Method in class cascading.cascade.CascadeConnector
Given any number of Flow objects, it will connect them and return a new Cascade instance.
connect(Flow...) - Method in class cascading.cascade.CascadeConnector
Given any number of Flow objects, it will connect them and return a new Cascade instance.
connect(String, Flow...) - Method in class cascading.cascade.CascadeConnector
Given any number of Flow objects, it will connect them and return a new Cascade instance.
connect(CascadeDef) - Method in class cascading.cascade.CascadeConnector
 
connect(Tap, Tap, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the given source and sink Taps to the given pipe assembly.
connect(String, Tap, Tap, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the given source and sink Taps to the given pipe assembly.
connect(String, Tap, Tap, Tap, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the given source, sink, and trap Taps to the given pipe assembly.
connect(Map<String, Tap>, Tap, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the named source Taps and sink Tap to the given pipe assembly.
connect(String, Map<String, Tap>, Tap, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the named source Taps and sink Tap to the given pipe assembly.
connect(String, Map<String, Tap>, Tap, Map<String, Tap>, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the named source and trap Taps and sink Tap to the given pipe assembly.
connect(String, Tap, Tap, Map<String, Tap>, Pipe) - Method in class cascading.flow.FlowConnector
Method connect links the named trap Taps, source and sink Tap to the given pipe assembly.
connect(Tap, Map<String, Tap>, Collection<Pipe>) - Method in class cascading.flow.FlowConnector
Method connect links the named source Taps and sink Tap to the given pipe assembly.
connect(String, Tap, Map<String, Tap>, Collection<Pipe>) - Method in class cascading.flow.FlowConnector
Method connect links the named source Taps and sink Tap to the given pipe assembly.
connect(Tap, Map<String, Tap>, Pipe...) - Method in class cascading.flow.FlowConnector
Method connect links the named source Taps and sink Tap to the given pipe assembly.
connect(String, Tap, Map<String, Tap>, Pipe...) - Method in class cascading.flow.FlowConnector
Method connect links the named source Taps and sink Tap to the given pipe assembly.
connect(Map<String, Tap>, Map<String, Tap>, Pipe...) - Method in class cascading.flow.FlowConnector
Method connect links the named sources and sinks to the given pipe assembly.
connect(String, Map<String, Tap>, Map<String, Tap>, Pipe...) - Method in class cascading.flow.FlowConnector
Method connect links the named sources and sinks to the given pipe assembly.
connect(String, Map<String, Tap>, Map<String, Tap>, Map<String, Tap>, Pipe...) - Method in class cascading.flow.FlowConnector
Method connect links the named sources, sinks and traps to the given pipe assembly.
connect(FlowDef) - Method in class cascading.flow.FlowConnector
 
CONNECTOR - Static variable in class cascading.util.DOTProcessGraphWriter
 
ConsecutiveTapsExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
ConsecutiveTapsExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.ConsecutiveTapsExpressionGraph
 
CONTAINER_ENABLED - Static variable in class cascading.management.CascadingServices
 
CONTAINER_EXCLUDE - Static variable in class cascading.management.CascadingServices
 
contains(Object) - Method in class cascading.tuple.collect.SpillableTupleList
 
contains(Fields) - Method in class cascading.tuple.Fields
Method contains returns true if this instance contains the field names and positions specified in the given fields instance.
contains(Class<T>, Collection) - Static method in class cascading.util.Util
 
contains(Class<T>, Iterator) - Static method in class cascading.util.Util
 
containsAll(Collection<?>) - Method in class cascading.tuple.collect.SpillableTupleList
 
containsEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
containsEdge(Scope) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
containsEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
containsEdge(Scope) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
containsEdge(FlowElement, FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
containsEdge(Scope) - Method in interface cascading.flow.planner.graph.ElementGraph
 
containsEdge(Process, Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
containsEdge(ProcessEdge) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
containsEdge(Process, Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
containsEdge(ProcessEdge) - Method in interface cascading.flow.planner.process.ProcessGraph
 
containsKey(Object) - Method in class cascading.util.cache.DirectMappedCache
 
containsKey(Object) - Method in class cascading.util.cache.LRUHashMapCache
 
containsKey(Object) - Method in class cascading.util.cache.OrderedHashMapCache
 
containsKey(K) - Method in class cascading.util.MultiMap
 
containsNull(Object[]) - Static method in class cascading.util.Util
 
containsPipeNamed(String) - Method in interface cascading.flow.FlowStep
Returns true if this FlowStep contains a pipe/branch with the given name.
containsPipeNamed(String) - Method in class cascading.flow.planner.BaseFlowStep
 
containsValue(Object) - Method in class cascading.util.cache.DirectMappedCache
 
containsValue(Object) - Method in class cascading.util.cache.LRUHashMapCache
 
containsValue(Object) - Method in class cascading.util.cache.OrderedHashMapCache
 
containsVertex(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
containsVertex(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
containsVertex(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
containsVertex(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
containsVertex(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
containsWhitespace(String) - Static method in class cascading.util.Util
 
ContractedGraphTransformer - Class in cascading.flow.planner.iso.transformer
 
ContractedGraphTransformer(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.ContractedGraphTransformer
 
ContractedGraphTransformer(GraphTransformer, ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.ContractedGraphTransformer
 
contractedMatchExpression - Variable in class cascading.flow.planner.rule.RuleExpression
 
ContractedTransformer - Class in cascading.flow.planner.iso.transformer
 
ContractedTransformer(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.ContractedTransformer
 
contractedTransformer - Variable in class cascading.flow.planner.rule.RuleTransformer
 
contractionExpression - Variable in class cascading.flow.planner.rule.RuleExpression
 
contractionGraph - Variable in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
CONVERT_DOT_TO_PDF - Static variable in class cascading.util.Util
On OS X only, and if the graphviz dot binary is installed, when true, dot will be invoked to convert the dot file to a pdf document.
copy(FlowDef, Map<String, Tap>, Map<String, Tap>, Map<String, Tap>, Map<String, Tap>) - Static method in class cascading.flow.Flows
 
copy(T[]) - Static method in class cascading.util.Util
 
copyComparators(Fields, Fields...) - Static method in class cascading.tuple.Fields
 
copyConfig(C) - Method in class cascading.flow.FlowProcess
 
copyConfig(Object) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
copyConfig(C) - Method in class cascading.flow.FlowProcessWrapper
 
copyElementGraph() - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
copyElementGraph() - Method in class cascading.flow.planner.graph.ElementDirectedGraph
 
copyElementGraph() - Method in interface cascading.flow.planner.graph.ElementGraph
 
copyElementGraph() - Method in class cascading.flow.planner.graph.ElementMaskSubGraph
 
copyElementGraph() - Method in class cascading.flow.planner.graph.ElementMultiGraph
 
copyElementGraph() - Method in class cascading.flow.planner.graph.ElementSubGraph
 
copyElementGraph() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
copyFields(Scope) - Method in class cascading.flow.planner.Scope
Method copyFields copies the given Scope instance fields to this instance.
copyFrom(BaseElementGraph) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
copyWith(Config) - Method in class cascading.flow.FlowProcess
 
copyWith(Object) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
copyWith(Config) - Method in class cascading.flow.FlowProcessWrapper
 
count - Variable in class cascading.flow.stream.element.MemorySpliceGate
 
Count - Class in cascading.operation.aggregator
Class Count is an Aggregator that calculates the number of items in the current group.
Count() - Constructor for class cascading.operation.aggregator.Count
Constructor Count creates a new Count instance using the default field declaration of name 'count'.
Count(Fields) - Constructor for class cascading.operation.aggregator.Count
Constructor Count creates a new Count instance and returns a field with the given fieldDeclaration name.
count - Variable in class cascading.operation.filter.Limit.Context
 
countAllEventingPathsTo(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
Returns all free paths to the current duct, usually a GroupGate.
CountBy - Class in cascading.pipe.assembly
Class CountBy is used to count duplicates in a tuple stream, where "duplicates" means all tuples with the same values for the groupingFields fields.
CountBy(Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe, Fields, Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe, Fields, Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(Pipe[], Fields, Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy(String, Pipe[], Fields, Fields, Fields, CountBy.Include, int) - Constructor for class cascading.pipe.assembly.CountBy
Constructor CountBy creates a new CountBy instance.
CountBy.CountPartials - Class in cascading.pipe.assembly
Class CountPartials is a AggregateBy.Functor that is used to count observed duplicates from the tuple stream.
CountBy.CountPartials(Fields) - Constructor for class cascading.pipe.assembly.CountBy.CountPartials
Constructor CountPartials creates a new CountPartials instance.
CountBy.CountPartials(Fields, CountBy.Include) - Constructor for class cascading.pipe.assembly.CountBy.CountPartials
 
CountBy.Include - Enum in cascading.pipe.assembly
 
countDownLatch() - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
Counter - Class in cascading.operation.state
Class Counter is a Filter that increments a given Enum counter by 1 or by the given increment value.
Counter(Enum) - Constructor for class cascading.operation.state.Counter
Constructor Counter creates a new Counter instance.
Counter(Enum, int) - Constructor for class cascading.operation.state.Counter
Constructor Counter creates a new Counter instance.
Counter(String, String) - Constructor for class cascading.operation.state.Counter
 
Counter(String, String, int) - Constructor for class cascading.operation.state.Counter
 
COUNTER_FETCH_RETRIES_PROPERTY - Static variable in class cascading.stats.CounterCache
 
COUNTER_MAX_AGE_PROPERTY - Static variable in class cascading.stats.CounterCache
 
COUNTER_TIMEOUT_PROPERTY - Static variable in class cascading.stats.CounterCache
 
counterCache - Variable in class cascading.stats.BaseCachedNodeStats
 
counterCache - Variable in class cascading.stats.BaseCachedStepStats
 
CounterCache<Config,JobStatus,Counters> - Class in cascading.stats
 
CounterCache(CascadingStats, Config) - Constructor for class cascading.stats.CounterCache
 
create(ElementGraph, FlowElement) - Method in class cascading.flow.planner.FlowPlanner.TempTapElementFactory
 
create(ElementGraph, FlowElement) - Method in interface cascading.flow.planner.iso.transformer.ElementFactory
 
create(FlowProcess<? extends Config>) - Method in interface cascading.provider.CascadingFactory
Method create will return a new instance of the type create by this factory.
create(List<Object>) - Static method in class cascading.tuple.Tuples
 
create(FlowProcess<? extends Config>) - Method in class cascading.util.cache.BaseCacheFactory
 
create(FlowProcess) - Method in class cascading.util.cache.DirectMappedCacheFactory
 
create(FlowProcess) - Method in class cascading.util.cache.LRUHashMapCacheFactory
 
create(FlowProcess) - Method in class cascading.util.cache.OrderedHashMapCacheFactory
 
createArgumentsBuilder(Fields, Fields) - Method in class cascading.flow.stream.element.OperatorStage
 
createBlockingJoinGate(HashJoin) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createBoundaryStage(Boundary, IORole) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createCallable(RuleRegistry) - Method in class cascading.flow.planner.rule.RuleSetExec
 
createCallables() - Method in class cascading.flow.planner.rule.RuleSetExec
 
createCleanPatternFor(String) - Method in class cascading.scheme.util.DelimitedParser
Method createCleanPatternFor creates a regex Pattern for removing quote characters from a String.
createClientState(FlowProcess) - Method in class cascading.flow.planner.BaseFlowStep
 
createClientState(String) - Method in class cascading.management.CascadingServices
 
createCoGroupGate(CoGroup, IORole) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createCollection() - Method in class cascading.util.EnumMultiMap
 
createCollection() - Method in class cascading.util.MultiMap
 
createCollection() - Method in class cascading.util.SetMultiMap
 
createCollection() - Method in class cascading.util.SortedListMultiMap
 
createComposite(Tuple...) - Static method in class cascading.tuple.util.TupleViews
 
createComposite(Fields...) - Static method in class cascading.tuple.util.TupleViews
 
createComposite(Fields[], Tuple[]) - Static method in class cascading.tuple.util.TupleViews
 
createConfig(Map<Object, Object>, Config) - Method in class cascading.flow.BaseFlow
 
createDefaultNarrowBuilder(Fields, Fields) - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
createDefaultNarrowBuilder(Fields, Fields) - Method in class cascading.flow.stream.element.MemorySpliceGate
 
createDefaultRuleRegistrySet() - Method in class cascading.flow.FlowConnector
 
createDirectedSpecifics() - Method in class cascading.flow.planner.graph.ElementMultiGraph.DirectedMultiGraph
 
createDocumentService() - Method in class cascading.management.CascadingServices
 
createEscapePatternFor(String) - Method in class cascading.scheme.util.DelimitedParser
Method createEscapePatternFor creates a regex Pattern cleaning quote escapes from a String.
createExpressionGraphPartitioner(ExpressionGraph, ExpressionGraph, ElementAnnotation[]) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
createExpressionGraphPartitioner(ExpressionGraph, ExpressionGraph, ElementAnnotation[]) - Method in class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
createFlow(FlowDef) - Method in class cascading.flow.planner.FlowPlanner
 
createFlowCanonicalHash(FlowElementGraph) - Method in class cascading.flow.BaseFlow
 
createFlowElementGraph(FlowDef, Pipe[]) - Method in class cascading.flow.planner.FlowPlanner
 
createFlowNode(FlowElementGraph, ElementGraph, List<? extends ElementGraph>) - Method in class cascading.flow.planner.BaseFlowNodeFactory
 
createFlowNode(FlowElementGraph, ElementGraph, List<? extends ElementGraph>) - Method in interface cascading.flow.planner.process.FlowNodeFactory
 
createFlowNodeGraph(FlowStepFactory, FlowElementGraph, Map<ElementGraph, List<? extends ElementGraph>>, List<? extends ElementGraph>) - Method in class cascading.flow.planner.process.FlowStepGraph
 
createFlowPlanner() - Method in class cascading.flow.FlowConnector
 
createFlowStats() - Method in class cascading.flow.BaseFlow
 
createFlowStep(ElementGraph, FlowNodeGraph) - Method in interface cascading.flow.planner.process.FlowStepFactory
 
createFlowStepJob(ClientState, FlowProcess<Config>, Config) - Method in class cascading.flow.planner.BaseFlowStep
 
createFlowStepJob(ClientState, FlowProcess, Object) - Method in class cascading.flow.process.ProcessFlowStep
 
createFlowThread(String) - Method in class cascading.flow.BaseFlow
 
createFork(Duct[]) - Method in class cascading.flow.stream.graph.StreamGraph
 
createGroupByGate(GroupBy, IORole) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createHashJoinGate(HashJoin) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createHashMap() - Static method in class cascading.util.Util
 
createID(String) - Static method in class cascading.util.Util
 
createID(byte[]) - Static method in class cascading.util.Util
Method CreateID returns a HEX hash of the given bytes with length 32 characters long.
createIdentitySet() - Static method in class cascading.util.Util
 
createIdentitySet(Collection<V>) - Static method in class cascading.util.Util
 
createInitializedConfig(FlowProcess<Config>, Config) - Method in class cascading.flow.planner.BaseFlowStep
Public for testing.
createInitializedConfig(FlowProcess, Object) - Method in class cascading.flow.process.ProcessFlowStep
 
createKeySet() - Method in class cascading.flow.stream.element.MemorySpliceGate
 
createKeyValuesArray() - Method in class cascading.flow.stream.element.MemorySpliceGate
This lets us just replace an old map and let the gc cleanup, vs clearing each map
createMap() - Method in class cascading.util.EnumMultiMap
 
createMap() - Method in class cascading.util.MultiMap
 
createMap() - Method in class cascading.util.SetMultiMap
 
createMap() - Method in class cascading.util.SortedListMultiMap
 
createMergeStage(Merge, IORole) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createMetricsService() - Method in class cascading.management.CascadingServices
 
createNarrow(int[]) - Static method in class cascading.tuple.util.TupleViews
 
createNarrow(int[], Tuple) - Static method in class cascading.tuple.util.TupleViews
 
createNarrowBuilder(Fields, Fields) - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
createNextFor(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
createNonBlockingJoinGate(HashJoin) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createNulledBuilder(Fields, Fields) - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
createObjectArray() - Static method in class cascading.tuple.util.TupleViews
 
createObjectArray(Object...) - Static method in class cascading.tuple.util.TupleViews
 
createOpenReducingWindow(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
createOpenWindow(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
createOutgoingBuilder(Operator, Fields, Fields, Fields, Fields, Fields) - Method in class cascading.flow.stream.element.OperatorStage
 
createOverride(Fields, Fields) - Static method in class cascading.tuple.util.TupleViews
 
createOverride(Fields, Tuple, Fields, Tuple) - Static method in class cascading.tuple.util.TupleViews
 
createOverride(int[], Tuple, int[], Tuple) - Static method in class cascading.tuple.util.TupleViews
 
createPrepareFlowStats() - Method in class cascading.flow.BaseFlow
 
createProperties(Iterable<Map.Entry<String, String>>) - Static method in class cascading.property.PropertyUtil
 
createProperties(Map<Object, Object>, Properties) - Static method in class cascading.property.PropertyUtil
 
createProtectedObject(Class, Object[], Class[]) - Static method in class cascading.util.Util
 
createProvider(String) - Method in class cascading.provider.ProviderLoader
 
createResource(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
createResource(Config) - Method in class cascading.tap.DecoratorTap
 
createResource(Config) - Method in class cascading.tap.MultiSinkTap
 
createResource(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
createResource(Config) - Method in class cascading.tap.SourceTap
 
createResource(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method createResource creates the underlying resource.
createResource(Config) - Method in class cascading.tap.Tap
Method createResource creates the underlying resource.
createSinkStage(Tap) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
createSplit(String, Pattern, int) - Method in class cascading.scheme.util.DelimitedParser
Method createSplit will split the given value with the given splitPattern.
createSplitPatternFor(String, String) - Method in class cascading.scheme.util.DelimitedParser
Method createSplitPatternFor creates a regex Pattern for splitting a line of text into its component parts using the given delimiter and quote Strings.
createStepStats(ClientState) - Method in class cascading.flow.planner.FlowStepJob
 
createTupleCollection(Tuple) - Method in class cascading.tuple.collect.SpillableTupleMap
 
createTupleEntrySchemeCollector(FlowProcess<? extends Config>, Tap, String, long) - Method in class cascading.tap.partition.BasePartitionTap
 
createTupleEntrySchemeIterator(FlowProcess<? extends Config>, Tap, String, Input) - Method in class cascading.tap.partition.BasePartitionTap
 
createTupleInputStream(File) - Method in class cascading.tuple.collect.SpillableTupleList
 
createTupleMap() - Method in class cascading.flow.stream.element.MemorySpliceGate
 
createTupleOutputStream(File) - Method in class cascading.tuple.collect.SpillableTupleList
 
createUniqueID() - Static method in class cascading.util.Util
 
createUniqueIDWhichStartsWithAChar() - Static method in class cascading.util.Util
 

D

dateFormatString - Variable in class cascading.tuple.type.DateType
Field dateFormatString
DateFormatter - Class in cascading.operation.text
Class DateFormatter is used to convert a date timestamp to a formatted string, where a timestamp is the number of milliseconds since January 1, 1970, 00:00:00 GMT, using the SimpleDateFormat syntax.
DateFormatter(String) - Constructor for class cascading.operation.text.DateFormatter
Constructor DateParser creates a new DateParser instance that creates a simple long time stamp of the parsed date.
DateFormatter(Fields, String) - Constructor for class cascading.operation.text.DateFormatter
Constructor DateParser creates a new DateParser instance.
DateFormatter(Fields, String, TimeZone) - Constructor for class cascading.operation.text.DateFormatter
Constructor DateFormatter creates a new DateFormatter instance.
DateFormatter(Fields, String, TimeZone, Locale) - Constructor for class cascading.operation.text.DateFormatter
Constructor DateFormatter creates a new DateFormatter instance.
DateOperation - Class in cascading.operation.text
Class DateOperation is the base class for DateFormatter and DateParser.
DateOperation(int, Fields, String) - Constructor for class cascading.operation.text.DateOperation
Constructor DateOperation creates a new DateOperation instance.
DateOperation(int, Fields, String, TimeZone, Locale) - Constructor for class cascading.operation.text.DateOperation
Constructor DateOperation creates a new DateOperation instance.
DateParser - Class in cascading.operation.text
Class DateParser is used to convert a text date string to a timestamp, the number of milliseconds since January 1, 1970, 00:00:00 GMT, using the SimpleDateFormat syntax.
DateParser(String) - Constructor for class cascading.operation.text.DateParser
Constructor DateParser creates a new DateParser instance that creates a simple long time stamp of the parsed date.
DateParser(Fields, String) - Constructor for class cascading.operation.text.DateParser
Constructor DateParser creates a new DateParser instance.
DateParser(Fields, int[], String) - Constructor for class cascading.operation.text.DateParser
Constructor DateParser creates a new DateParser instance, where calendarFields is an int[] of Calendar field values.
DateParser(Fields, TimeZone, Locale, String) - Constructor for class cascading.operation.text.DateParser
Constructor DateParser creates a new DateParser instance, where zone and locale are passed to the internal SimpleDateFormat instance.
DateParser(Fields, int[], TimeZone, Locale, String) - Constructor for class cascading.operation.text.DateParser
Constructor DateParser creates a new DateParser instance, where calendarFields is an int[] of Calendar field values.
DateType - Class in cascading.tuple.type
Class DateCoercibleType is an implementation of CoercibleType.
DateType(String, TimeZone, Locale) - Constructor for class cascading.tuple.type.DateType
Create a new DateType instance.
DateType(String, TimeZone) - Constructor for class cascading.tuple.type.DateType
 
DateType(String) - Constructor for class cascading.tuple.type.DateType
Create a new DateType instance.
Debug - Class in cascading.operation
Class Debug is a Filter that will never remove an item from a stream, but will print the Tuple to either stdout or stderr.
Debug() - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to stderr by default, and does not print the Tuple instance field names.
Debug(String) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to stderr by default, and does not print the Tuple instance field names.
Debug(String, boolean) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to stderr and will print the current Tuple instance field names if printFields is true.
Debug(boolean) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to stderr and will print the current Tuple instance field names if printFields is true.
Debug(Debug.Output) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to the declared stream and does not print the Tuple field names.
Debug(Debug.Output, String) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to the declared stream and does not print the Tuple field names.
Debug(Debug.Output, String, boolean) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to the declared stream and will print the Tuple instances field names if printFields is true.
Debug(Debug.Output, boolean) - Constructor for class cascading.operation.Debug
Constructor Debug creates a new Debug instance that prints to the declared stream and will print the Tuple instances field names if printFields is true.
Debug.Output - Enum in cascading.operation
 
DEBUG_LEVEL - Static variable in class cascading.flow.FlowConnectorProps
 
debugLevel - Variable in class cascading.flow.FlowDef
 
DebugLevel - Enum in cascading.operation
Enum DebugLevel designates the level of a given Debug instance.
declaredFields - Variable in class cascading.pipe.Splice
Field declaredFields
DeclaresResults - Interface in cascading.flow.planner
 
DecoratedElementGraph - Class in cascading.flow.planner.graph
 
DecoratedElementGraph(ElementGraph) - Constructor for class cascading.flow.planner.graph.DecoratedElementGraph
 
DecoratorTap<MetaInfo,Config,Input,Output> - Class in cascading.tap
Class DecoratorTap wraps a given Tap instance, delegating all calls to the original.
DecoratorTap(MetaInfo, Tap<Config, Input, Output>) - Constructor for class cascading.tap.DecoratorTap
Creates a new Tap instance, wrapping the given Tap, and associates the given MetaInfo type with the wrapped Tap instance.
DecoratorTap(Tap<Config, Input, Output>) - Constructor for class cascading.tap.DecoratorTap
Creates a new Tap instance, wrapping the given Tap, and associates the given MetaInfo type with the wrapped Tap instance.
DEFAULT_CACHE_FACTORY_CLASS - Static variable in class cascading.pipe.assembly.AggregateByProps
default factory class for creating caches.
DEFAULT_CACHE_FACTORY_CLASS - Static variable in class cascading.pipe.assembly.UniqueProps
default factory class for creating caches.
DEFAULT_CACHED_AGE_MAX - Static variable in class cascading.stats.CounterCache
 
DEFAULT_CAPACITY - Static variable in class cascading.util.cache.BaseCacheFactory
default capacity for all caches.
DEFAULT_DELIM - Static variable in class cascading.operation.regex.RegexMatcher
 
DEFAULT_ELEMENT_COMPARATOR - Static variable in class cascading.flow.FlowProps
 
DEFAULT_FETCH_RETRIES - Static variable in class cascading.stats.CounterCache
 
DEFAULT_NODE_CACHED_AGE_MAX - Static variable in class cascading.stats.CounterCache
 
DEFAULT_PLAN_COMPARATOR - Static variable in class cascading.flow.planner.rule.RuleSetExec
 
DEFAULT_PROPERTIES - Static variable in class cascading.management.CascadingServices
 
DEFAULT_THRESHOLD - Static variable in class cascading.pipe.assembly.MaxBy
Deprecated.
DEFAULT_TIMEOUT - Static variable in class cascading.flow.planner.rule.RuleSetExec
 
DEFAULT_TIMEOUT_TIMEOUT_SEC - Static variable in class cascading.stats.CounterCache
 
DEFAULT_TRANSFORM_RECURSION_DEPTH_MAX - Static variable in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
defaultAssertionLevel - Variable in class cascading.flow.planner.FlowPlanner
Field assertionLevel
defaultDebugLevel - Variable in class cascading.flow.planner.FlowPlanner
Field debugLevel
defaultListThreshold - Static variable in class cascading.tuple.collect.SpillableProps
 
defaultMapInitialCapacity - Static variable in class cascading.tuple.collect.SpillableProps
 
defaultMapLoadFactor - Static variable in class cascading.tuple.collect.SpillableProps
 
defaultMapThreshold - Static variable in class cascading.tuple.collect.SpillableProps
 
defaultProperties - Variable in class cascading.flow.planner.FlowPlanner
Field properties
deleteCheckpointsIfNotUpdate() - Method in class cascading.flow.BaseFlow
 
deleteCheckpointsIfReplace() - Method in class cascading.flow.BaseFlow
 
deleteResource(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
deleteResource(Config) - Method in class cascading.tap.DecoratorTap
 
deleteResource(Config) - Method in class cascading.tap.MultiSinkTap
 
deleteResource(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
deleteResource(Config) - Method in class cascading.tap.SourceTap
 
deleteResource(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method deleteResource deletes the resource represented by this instance.
deleteResource(Config) - Method in class cascading.tap.Tap
Method deleteResource deletes the resource represented by this instance.
deleteSinks() - Method in class cascading.flow.BaseFlow
Method deleteSinks deletes all sinks, whether or not they are configured for SinkMode.UPDATE.
deleteSinksIfNotUpdate() - Method in class cascading.flow.BaseFlow
Method deleteSinksIfNotUpdate deletes all sinks if they are not configured with the SinkMode.UPDATE flag.
deleteSinksIfReplace() - Method in class cascading.flow.BaseFlow
 
deleteTrapsIfNotUpdate() - Method in class cascading.flow.BaseFlow
 
deleteTrapsIfReplace() - Method in class cascading.flow.BaseFlow
 
DelimitedParser - Class in cascading.scheme.util
Class DelimitedParser is a base class for parsing text delimited files.
DelimitedParser(String, String, Class[]) - Constructor for class cascading.scheme.util.DelimitedParser
 
DelimitedParser(String, String, Class[], boolean, boolean) - Constructor for class cascading.scheme.util.DelimitedParser
 
DelimitedParser(String, String, FieldTypeResolver) - Constructor for class cascading.scheme.util.DelimitedParser
 
DelimitedParser(String, String, Class[], boolean, boolean, FieldTypeResolver) - Constructor for class cascading.scheme.util.DelimitedParser
 
DelimitedParser(String, String, Class[], boolean, boolean, Fields, Fields) - Constructor for class cascading.scheme.util.DelimitedParser
 
DelimitedParser(String, String, Class[], boolean, boolean, Fields, Fields, FieldTypeResolver) - Constructor for class cascading.scheme.util.DelimitedParser
 
DelimitedPartition - Class in cascading.tap.partition
DelimitedPartition is an implementation of the Partition interface that allows for simple text delimited paths as partitions.
DelimitedPartition(Fields, String) - Constructor for class cascading.tap.partition.DelimitedPartition
 
DelimitedPartition(Fields) - Constructor for class cascading.tap.partition.DelimitedPartition
 
delimiter - Variable in class cascading.operation.regex.RegexMatcher
 
delimiter - Variable in class cascading.scheme.util.DelimitedParser
Field delimiter *
deregisterShutdownHook() - Static method in class cascading.util.ShutdownUtil
 
DESCRIPTION - Static variable in interface cascading.flow.FlowDescriptors
Briefly describes the current Flow *
DESCRIPTION - Static variable in interface cascading.flow.FlowNodeDescriptors
Briefly describes the current FlowStep *
DESCRIPTION - Static variable in interface cascading.flow.FlowStepDescriptors
Briefly describes the current FlowStep *
diffConfigIntoMap(C, C) - Method in class cascading.flow.FlowProcess
 
diffConfigIntoMap(Object, Object) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
diffConfigIntoMap(C, C) - Method in class cascading.flow.FlowProcessWrapper
 
differenceIdentity(Set<T>, Set<T>) - Static method in class cascading.util.Util
 
directed(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
DirectMappedCache<Key,Value> - Class in cascading.util.cache
DirectMappedCache is an implementation of the CascadingCache interface following the semantics of http://en.wikipedia.org/wiki/CPU_cache#Direct-mapped_cache.
DirectMappedCache() - Constructor for class cascading.util.cache.DirectMappedCache
 
DirectMappedCacheFactory - Class in cascading.util.cache
Concrete sub-class of BaseCacheFactory for creating DirectMappedCache instances.
DirectMappedCacheFactory() - Constructor for class cascading.util.cache.DirectMappedCacheFactory
 
Discard - Class in cascading.pipe.assembly
Class Discard is a SubAssembly that will retain all incoming fields except those given on the constructor.
Discard(Pipe, Fields) - Constructor for class cascading.pipe.assembly.Discard
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertEquals
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertEqualsAll
 
doAssert(FlowProcess, GroupAssertionCall<AssertGroupBase.Context>) - Method in class cascading.operation.assertion.AssertGroupBase
 
doAssert(FlowProcess, ValueAssertionCall<Matcher>) - Method in class cascading.operation.assertion.AssertMatches
 
doAssert(FlowProcess, ValueAssertionCall<Matcher>) - Method in class cascading.operation.assertion.AssertMatchesAll
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertNotEquals
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertNotNull
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertNull
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertSizeEquals
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertSizeLessThan
 
doAssert(FlowProcess, ValueAssertionCall) - Method in class cascading.operation.assertion.AssertSizeMoreThan
 
doAssert(FlowProcess, GroupAssertionCall<C>) - Method in interface cascading.operation.GroupAssertion
Method doAssert performs the assertion.
doAssert(FlowProcess, ValueAssertionCall<C>) - Method in interface cascading.operation.ValueAssertion
Method doAssert performs the assertion.
DOCUMENT_SERVICE_CLASS_PROPERTY - Static variable in interface cascading.management.DocumentService
 
DocumentService - Interface in cascading.management
Interface DocumentService provides coarse grained hooks for managing various statistics.
DocumentServiceException - Exception in cascading.management
Exception DocumentServiceException is thrown from within a DocumentService instance.
DocumentServiceException() - Constructor for exception cascading.management.DocumentServiceException
 
DocumentServiceException(String) - Constructor for exception cascading.management.DocumentServiceException
 
DocumentServiceException(String, Throwable) - Constructor for exception cascading.management.DocumentServiceException
 
DocumentServiceException(Throwable) - Constructor for exception cascading.management.DocumentServiceException
 
doSpill(Spillable, int) - Method in interface cascading.tuple.collect.Spillable.SpillStrategy
 
DOT_FILE_PATH - Static variable in class cascading.flow.stream.graph.StreamGraph
Property denoting the path to write all stream graph dot files.
DOTExporter<V,E> - Class in cascading.util.jgrapht
 
DOTExporter() - Constructor for class cascading.util.jgrapht.DOTExporter
Constructs a new DOTExporter object with an integer name provider for the vertex IDs and null providers for the vertex and edge labels.
DOTExporter(VertexNameProvider<V>, VertexNameProvider<V>, EdgeNameProvider<E>) - Constructor for class cascading.util.jgrapht.DOTExporter
Constructs a new DOTExporter object with the given ID and label providers.
DOTExporter(VertexNameProvider<V>, VertexNameProvider<V>, EdgeNameProvider<E>, ComponentAttributeProvider<V>, ComponentAttributeProvider<E>) - Constructor for class cascading.util.jgrapht.DOTExporter
Constructs a new DOTExporter object with the given ID, label, and attribute providers.
DOTProcessGraphWriter - Class in cascading.util
This class is a derivative of the JGraphT DOTExporter, with numerous enhancements but with retained compatibility.
DOTProcessGraphWriter(VertexNameProvider<Pair<ElementGraph, FlowElement>>, VertexNameProvider<FlowElement>, EdgeNameProvider<Scope>, ComponentAttributeProvider<FlowElement>, ComponentAttributeProvider<Scope>, VertexNameProvider<ProcessModel>, VertexNameProvider<ProcessModel>) - Constructor for class cascading.util.DOTProcessGraphWriter
 
DOUBLE - Static variable in class cascading.tuple.coerce.Coercions
 
DOUBLE_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
DoubleCoerce - Class in cascading.tuple.coerce
 
DoubleCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.DoubleCoerce
 
DoubleObjectCoerce - Class in cascading.tuple.coerce
 
DoubleObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.DoubleObjectCoerce
 
DualStreamedAccumulatedExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
DualStreamedAccumulatedExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.DualStreamedAccumulatedExpressionGraph
 
Duct<Incoming,Outgoing> - Class in cascading.flow.stream.duct
 
DuctException - Exception in cascading.flow.stream.duct
 
DuctException(Throwable) - Constructor for exception cascading.flow.stream.duct.DuctException
 
DuctException(String, Throwable) - Constructor for exception cascading.flow.stream.duct.DuctException
 
DuctGraph - Class in cascading.flow.stream.duct
 
DuctGraph() - Constructor for class cascading.flow.stream.duct.DuctGraph
 
DuctGraph.Ordinal - Class in cascading.flow.stream.duct
 
DuctGraph.Ordinal(int, int) - Constructor for class cascading.flow.stream.duct.DuctGraph.Ordinal
 
dumpDebugInfo() - Method in class cascading.flow.planner.FlowStepJob
 

E

EACH - Static variable in class cascading.flow.planner.iso.expression.ScopeExpression
 
Each - Class in cascading.pipe
The Each operator applies either a Function or a Filter to each entry in the Tuple stream.
Each(String, Function) - Constructor for class cascading.pipe.Each
Pass all fields to the given function, only return fields declared by the function.
Each(String, Fields, Function) - Constructor for class cascading.pipe.Each
Only pass argumentFields to the given function, only return fields declared by the function.
Each(String, Fields, Function, Fields) - Constructor for class cascading.pipe.Each
Only pass argumentFields to the given function, only return fields selected by the outputSelector.
Each(String, Function, Fields) - Constructor for class cascading.pipe.Each
Only return fields selected by the outputSelector.
Each(Pipe, Function) - Constructor for class cascading.pipe.Each
Pass all fields to the given function, only return fields declared by the function.
Each(Pipe, Fields, Function) - Constructor for class cascading.pipe.Each
Only pass argumentFields to the given function, only return fields declared by the function.
Each(Pipe, Fields, Function, Fields) - Constructor for class cascading.pipe.Each
Only pass argumentFields to the given function, only return fields selected by the outputSelector.
Each(Pipe, Function, Fields) - Constructor for class cascading.pipe.Each
Only pass argumentFields to the given function, only return fields selected by the outputSelector.
Each(String, Filter) - Constructor for class cascading.pipe.Each
Constructor Each creates a new Each instance.
Each(String, Fields, Filter) - Constructor for class cascading.pipe.Each
Constructor Each creates a new Each instance.
Each(Pipe, Filter) - Constructor for class cascading.pipe.Each
Constructor Each creates a new Each instance.
Each(Pipe, Fields, Filter) - Constructor for class cascading.pipe.Each
Constructor Each creates a new Each instance.
Each(String, AssertionLevel, Assertion) - Constructor for class cascading.pipe.Each
Constructor Each creates a new Each instance.
Each(String, Fields, AssertionLevel, Assertion) - Constructor for class cascading.pipe.Each
 
Each(Pipe, AssertionLevel, Assertion) - Constructor for class cascading.pipe.Each
 
Each(Pipe, Fields, AssertionLevel, Assertion) - Constructor for class cascading.pipe.Each
 
Each(String, Fields, DebugLevel, Debug) - Constructor for class cascading.pipe.Each
 
Each(Pipe, DebugLevel, Debug) - Constructor for class cascading.pipe.Each
 
Each(Pipe, Fields, DebugLevel, Debug) - Constructor for class cascading.pipe.Each
 
EachStage - Class in cascading.flow.stream.element
 
EachStage(FlowProcess, Each) - Constructor for class cascading.flow.stream.element.EachStage
 
EdgeNameProvider<E> - Interface in cascading.util.jgrapht
 
edgeSet() - Method in class cascading.flow.planner.graph.BaseElementGraph
 
edgeSet() - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
edgeSet() - Method in interface cascading.flow.planner.graph.ElementGraph
 
edgeSet() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
edgeSet() - Method in interface cascading.flow.planner.process.ProcessGraph
 
edgesOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
edgesOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
edgesOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
edgesOf(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
edgesOf(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
ElementAnnotation - Class in cascading.flow.planner.iso
 
ElementAnnotation(ElementCapture, Enum) - Constructor for class cascading.flow.planner.iso.ElementAnnotation
 
ElementCapture - Enum in cascading.flow.planner.iso.expression
 
ElementDirectedGraph - Class in cascading.flow.planner.graph
 
ElementDirectedGraph() - Constructor for class cascading.flow.planner.graph.ElementDirectedGraph
 
ElementDirectedGraph(ElementGraph) - Constructor for class cascading.flow.planner.graph.ElementDirectedGraph
 
ElementDirectedGraph(ElementGraph, EnumMultiMap) - Constructor for class cascading.flow.planner.graph.ElementDirectedGraph
 
ElementDuct - Interface in cascading.flow.stream.element
 
ElementExpression - Class in cascading.flow.planner.iso.expression
 
ElementExpression() - Constructor for class cascading.flow.planner.iso.expression.ElementExpression
 
ElementExpression(ElementCapture) - Constructor for class cascading.flow.planner.iso.expression.ElementExpression
 
ElementFactory - Interface in cascading.flow.planner.iso.transformer
 
ElementFlowProcess - Class in cascading.flow.stream.element
 
ElementFlowProcess(FlowProcess, ConfigDef) - Constructor for class cascading.flow.stream.element.ElementFlowProcess
 
ElementGraph - Interface in cascading.flow.planner.graph
Interface ElementGraph holds a directed acyclic graph of FlowElement instances.
elementGraph - Variable in class cascading.flow.planner.iso.finder.Match
 
elementGraph - Variable in class cascading.flow.stream.graph.NodeStreamGraph
 
ElementGraphException - Exception in cascading.flow.planner
Class ElementGraphException is thrown during rendering of a pipe assembly to the Cascading internal "graph" representation.
ElementGraphException() - Constructor for exception cascading.flow.planner.ElementGraphException
Constructor ElementGraphException creates a new ElementGraphException instance.
ElementGraphException(Pipe, String) - Constructor for exception cascading.flow.planner.ElementGraphException
 
ElementGraphException(Tap, String) - Constructor for exception cascading.flow.planner.ElementGraphException
 
ElementGraphException(FlowElement, String) - Constructor for exception cascading.flow.planner.ElementGraphException
Constructor ElementGraphException creates a new ElementGraphException instance.
ElementGraphException(FlowElement, String, Throwable) - Constructor for exception cascading.flow.planner.ElementGraphException
Constructor ElementGraphException creates a new ElementGraphException instance.
ElementGraphException(String) - Constructor for exception cascading.flow.planner.ElementGraphException
Constructor ElementGraphException creates a new ElementGraphException instance.
ElementGraphException(String, Throwable) - Constructor for exception cascading.flow.planner.ElementGraphException
Constructor ElementGraphException creates a new ElementGraphException instance.
ElementGraphException(Throwable) - Constructor for exception cascading.flow.planner.ElementGraphException
Constructor ElementGraphException creates a new ElementGraphException instance.
ElementGraphs - Class in cascading.flow.planner.graph
Class ElementGraphs maintains a collection of operations that can be performed on an ElementGraph.
ElementMaskSubGraph - Class in cascading.flow.planner.graph
 
ElementMaskSubGraph(ElementGraph, FlowElement...) - Constructor for class cascading.flow.planner.graph.ElementMaskSubGraph
 
ElementMaskSubGraph(ElementGraph, Collection<FlowElement>) - Constructor for class cascading.flow.planner.graph.ElementMaskSubGraph
 
ElementMaskSubGraph(ElementGraph, Collection<FlowElement>, Collection<Scope>) - Constructor for class cascading.flow.planner.graph.ElementMaskSubGraph
 
ElementMaskSubGraph(ElementMaskSubGraph) - Constructor for class cascading.flow.planner.graph.ElementMaskSubGraph
 
ElementMaskSubGraph(ElementGraph, ElementMaskSubGraph.FlowElementMaskFunctor) - Constructor for class cascading.flow.planner.graph.ElementMaskSubGraph
 
ElementMultiGraph - Class in cascading.flow.planner.graph
 
ElementMultiGraph() - Constructor for class cascading.flow.planner.graph.ElementMultiGraph
 
ElementMultiGraph(ElementGraph) - Constructor for class cascading.flow.planner.graph.ElementMultiGraph
 
ElementMultiGraph.DirectedMultiGraph - Class in cascading.flow.planner.graph
 
ElementMultiGraph.DirectedMultiGraph() - Constructor for class cascading.flow.planner.graph.ElementMultiGraph.DirectedMultiGraph
 
ElementMultiGraph.DirectedMultiGraph(DirectedGraph<FlowElement, Scope>) - Constructor for class cascading.flow.planner.graph.ElementMultiGraph.DirectedMultiGraph
 
elementReader - Variable in class cascading.tuple.io.TupleInputStream
Field elementReader
elements - Variable in class cascading.tuple.Tuple
Field elements
elements(Tuple) - Static method in class cascading.tuple.Tuple
Returns a reference to the private elements of the given Tuple.
ElementStage<Incoming,Outgoing> - Class in cascading.flow.stream.element
 
ElementStage(FlowProcess, FlowElement) - Constructor for class cascading.flow.stream.element.ElementStage
 
ElementSubGraph - Class in cascading.flow.planner.graph
 
ElementSubGraph(ElementGraph, Collection<FlowElement>) - Constructor for class cascading.flow.planner.graph.ElementSubGraph
 
ElementSubGraph(ElementGraph, Collection<FlowElement>, Collection<Scope>) - Constructor for class cascading.flow.planner.graph.ElementSubGraph
 
ElementSubGraph(ElementSubGraph) - Constructor for class cascading.flow.planner.graph.ElementSubGraph
 
EMPTY - Static variable in class cascading.util.SingleValueIterator
 
emptyCollection() - Method in class cascading.util.MultiMap
 
emptyCollection() - Method in class cascading.util.SetMultiMap
 
emptyCollection() - Method in class cascading.util.SortedListMultiMap
 
enableDebugLogging() - Method in class cascading.flow.planner.rule.RuleRegistry
Method enableDebugLogging forces log4j to emit DEBUG level stats for the planner classes.
enabledResolveElements() - Method in class cascading.flow.planner.rule.RuleRegistry
 
enforceStrict - Variable in class cascading.scheme.util.DelimitedParser
Field enforceStrict
entryIterator() - Method in class cascading.tuple.TupleListCollector
Method entryIterator return a TupleEntry iterator for this collection.
entrySet() - Method in class cascading.util.cache.DirectMappedCache
 
entrySet() - Method in class cascading.util.cache.LRUHashMapCache
 
entrySet() - Method in class cascading.util.cache.OrderedHashMapCache
 
EnumMultiMap<V> - Class in cascading.util
 
EnumMultiMap() - Constructor for class cascading.util.EnumMultiMap
 
EnumMultiMap(EnumMultiMap) - Constructor for class cascading.util.EnumMultiMap
 
equals(Object) - Method in class cascading.flow.planner.BaseFlowNode
 
equals(Object) - Method in class cascading.flow.planner.BaseFlowStep
 
equals(Object) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
equals(Object) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
equals(ElementGraph, ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
equals(Object) - Method in class cascading.flow.planner.graph.IgnoresAnnotationsElementGraph
 
equals(Object) - Method in class cascading.flow.planner.PlannerInfo
 
equals(Object) - Method in class cascading.flow.planner.PlatformInfo
 
equals(Object) - Method in class cascading.flow.planner.rule.RuleRegistry
 
equals(Object) - Method in class cascading.flow.planner.rule.util.ResultTree.Delegate
 
equals(Object) - Method in class cascading.flow.stream.duct.DuctGraph.Ordinal
 
equals(Object) - Method in class cascading.flow.stream.element.ElementStage
 
equals(Object) - Method in class cascading.flow.stream.element.GroupingSpliceGate.DelegatedTuple
 
equals(Object) - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
equals(Object) - Method in class cascading.operation.aggregator.ExtentBase
 
equals(Object) - Method in class cascading.operation.aggregator.ExtremaValueBase
 
equals(Object) - Method in class cascading.operation.aggregator.Sum
 
equals(Object) - Method in class cascading.operation.assertion.AssertEquals
 
equals(Object) - Method in class cascading.operation.assertion.AssertEqualsAll
 
equals(Object) - Method in class cascading.operation.assertion.AssertGroupBase
 
equals(Object) - Method in class cascading.operation.assertion.AssertNotEquals
 
equals(Object) - Method in class cascading.operation.assertion.AssertSizeEquals
 
equals(Object) - Method in class cascading.operation.assertion.AssertSizeLessThan
 
equals(Object) - Method in class cascading.operation.assertion.AssertSizeMoreThan
 
equals(Object) - Method in class cascading.operation.assertion.BaseAssertion
 
equals(Object) - Method in class cascading.operation.BaseOperation
 
equals(Object) - Method in class cascading.operation.Debug
 
equals(Object) - Method in class cascading.operation.filter.Limit
 
equals(Object) - Method in class cascading.operation.filter.Logic
 
equals(Object) - Method in class cascading.operation.filter.Not
 
equals(Object) - Method in class cascading.operation.filter.Sample
 
equals(Object) - Method in class cascading.operation.function.SetValue
 
equals(Object) - Method in class cascading.operation.function.UnGroup
 
equals(Object) - Method in class cascading.operation.Identity
 
equals(Object) - Method in class cascading.operation.Insert
 
equals(Object) - Method in class cascading.operation.regex.RegexFilter
 
equals(Object) - Method in class cascading.operation.regex.RegexMatcher
 
equals(Object) - Method in class cascading.operation.regex.RegexOperation
 
equals(Object) - Method in class cascading.operation.regex.RegexParser
 
equals(Object) - Method in class cascading.operation.regex.RegexReplace
 
equals(Object) - Method in class cascading.operation.state.Counter
 
equals(Object) - Method in class cascading.operation.state.Status
 
equals(Object) - Method in class cascading.operation.text.DateOperation
 
equals(Object) - Method in class cascading.operation.text.DateParser
 
equals(Object) - Method in class cascading.operation.text.FieldFormatter
 
equals(Object) - Method in class cascading.operation.text.FieldJoiner
 
equals(Object) - Method in class cascading.pipe.assembly.AggregateBy.CompositeFunction
 
equals(Object) - Method in class cascading.pipe.assembly.Unique.FilterPartialDuplicates
 
equals(Object) - Method in class cascading.pipe.Operator
 
equals(Object) - Method in class cascading.pipe.Pipe
 
equals(Object) - Method in class cascading.pipe.Splice
 
equals(Object) - Method in class cascading.scheme.Scheme
 
equals(Object) - Method in class cascading.stats.FlowStats
 
equals(Object) - Method in class cascading.tap.MultiSinkTap
 
equals(Object) - Method in class cascading.tap.MultiSourceTap
 
equals(Object) - Method in class cascading.tap.partition.BasePartitionTap
 
equals(Object) - Method in class cascading.tap.Tap
 
equals(Object) - Method in class cascading.tuple.coerce.Coercions.Coerce
 
equals(Object) - Method in class cascading.tuple.Fields
 
equals(Object) - Method in class cascading.tuple.io.IndexTuple
 
equals(Object) - Method in class cascading.tuple.io.TuplePair
 
equals(Object) - Method in class cascading.tuple.Tuple
 
equals(Object) - Method in class cascading.tuple.TupleEntry
 
equals(Object) - Method in class cascading.util.MultiMap
 
equals(Object) - Method in class cascading.util.Pair
 
equalsFields(Fields) - Method in class cascading.tuple.Fields
Method equalsFields compares only the internal field names and postions only between this and the given Fields instance.
equalsIgnoreAnnotations(ElementGraph, ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
equalsIgnoreAnnotations(Graph<V, E>, Graph<V, E>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
ERROR_DOT_FILE_NAME - Static variable in class cascading.flow.stream.graph.StreamGraph
Property denoting the path and filename to write the failed stream graph dot file.
escapePattern - Variable in class cascading.scheme.util.DelimitedParser
Field escapePattern
Every - Class in cascading.pipe
The Every operator applies an Aggregator or Buffer to every grouping.
Every(Pipe, Aggregator) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Fields, Aggregator) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Fields, Aggregator, Fields) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Aggregator, Fields) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Buffer) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Fields, Buffer) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Fields, Buffer, Fields) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Buffer, Fields) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, AssertionLevel, GroupAssertion) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
Every(Pipe, Fields, AssertionLevel, GroupAssertion) - Constructor for class cascading.pipe.Every
Constructor Every creates a new Every instance.
EveryAfterBufferAssert - Class in cascading.flow.planner.rule.assertion
 
EveryAfterBufferAssert() - Constructor for class cascading.flow.planner.rule.assertion.EveryAfterBufferAssert
 
EveryAfterBufferExpression - Class in cascading.flow.planner.rule.expression
 
EveryAfterBufferExpression() - Constructor for class cascading.flow.planner.rule.expression.EveryAfterBufferExpression
 
EveryStage<Incoming> - Class in cascading.flow.stream.element
 
EveryStage(FlowProcess, Every) - Constructor for class cascading.flow.stream.element.EveryStage
 
evict(Map.Entry<Key, Value>) - Method in interface cascading.util.cache.CacheEvictionCallback
Method will be called by the CascadingCache implementation whenever a key is evicted.
exec(PlannerContext, FlowElementGraph) - Method in class cascading.flow.planner.rule.RuleExec
 
exec() - Method in class cascading.flow.planner.rule.RuleSetExec
 
ExecAction - Enum in cascading.flow.planner.rule
 
execPlannerFor(RuleRegistry) - Method in class cascading.flow.planner.rule.RuleSetExec
 
execProcess(File, String...) - Static method in class cascading.util.Util
 
execute() - Method in class cascading.util.ShutdownUtil.Hook
 
executeRulePhase(PlanPhase, PlannerContext, RuleResult) - Method in class cascading.flow.planner.rule.RuleExec
 
export(Writer, Graph<V, E>) - Method in class cascading.util.jgrapht.DOTExporter
Exports a graph into a plain text file in DOT format.
Expression<Type> - Interface in cascading.flow.planner.iso.expression
 
ExpressionGraph - Class in cascading.flow.planner.iso.expression
 
ExpressionGraph() - Constructor for class cascading.flow.planner.iso.expression.ExpressionGraph
 
ExpressionGraph(boolean) - Constructor for class cascading.flow.planner.iso.expression.ExpressionGraph
 
ExpressionGraph(ElementExpression...) - Constructor for class cascading.flow.planner.iso.expression.ExpressionGraph
 
ExpressionGraph(SearchOrder, ElementExpression...) - Constructor for class cascading.flow.planner.iso.expression.ExpressionGraph
 
ExpressionGraph(SearchOrder) - Constructor for class cascading.flow.planner.iso.expression.ExpressionGraph
 
ExpressionGraph(SearchOrder, boolean) - Constructor for class cascading.flow.planner.iso.expression.ExpressionGraph
 
expressionGraph - Variable in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
ExpressionGraphPartitioner - Class in cascading.flow.planner.iso.subgraph.partitioner
 
ExpressionGraphPartitioner(ExpressionGraph, ExpressionGraph, ElementAnnotation...) - Constructor for class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
ExpressionRulePartitioner - Class in cascading.flow.planner.rule.partitioner
Class ExpressionRulePartitioner relies on a RuleExpression to identify sub-graphs as partitions.
ExpressionRulePartitioner(PlanPhase, RuleExpression) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase, RuleExpression, ElementAnnotation...) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase, RuleExpression, Enum...) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase, RulePartitioner.PartitionSource, RuleExpression) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase, RulePartitioner.PartitionSource, RuleExpression, ElementAnnotation...) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase, RulePartitioner.PartitionSource, RuleExpression, Enum...) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase, GraphPartitioner) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner(PlanPhase) - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionRulePartitioner() - Constructor for class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
ExpressionSubGraphIterator - Class in cascading.flow.planner.iso.subgraph.iterator
 
ExpressionSubGraphIterator(ExpressionGraph, ElementGraph) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
ExpressionSubGraphIterator(PlannerContext, ExpressionGraph, ElementGraph) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
ExpressionSubGraphIterator(PlannerContext, ExpressionGraph, ExpressionGraph, ElementGraph) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
ExpressionSubGraphIterator(PlannerContext, ExpressionGraph, ExpressionGraph, ElementGraph, Collection<FlowElement>) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
ExpressionSubGraphIterator(PlannerContext, ExpressionGraph, ExpressionGraph, boolean, ElementGraph) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
ExpressionSubGraphIterator(PlannerContext, ExpressionGraph, ExpressionGraph, boolean, ElementGraph, Collection<FlowElement>) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
Extent - Enum in cascading.flow.planner.graph
Enum Extent provides simple markers for the head and tail of an ElementGraph FlowElement graph.
ExtentBase - Class in cascading.operation.aggregator
Class ExtentBase is the base class for First and Last.
ExtentBase(Fields) - Constructor for class cascading.operation.aggregator.ExtentBase
 
ExtentBase(int, Fields) - Constructor for class cascading.operation.aggregator.ExtentBase
 
ExtentBase(Fields, Tuple...) - Constructor for class cascading.operation.aggregator.ExtentBase
 
EXTERNAL_ID - Static variable in interface cascading.flow.FlowNodeDescriptors
Id of the FlowStep in an external system *
EXTERNAL_ID - Static variable in interface cascading.flow.FlowStepDescriptors
Id of the FlowStep in an external system *
EXTERNAL_NAME - Static variable in interface cascading.flow.FlowNodeDescriptors
Name of the FlowStep in an external system *
EXTERNAL_NAME - Static variable in interface cascading.flow.FlowStepDescriptors
Name of the FlowStep in an external system *
EXTERNAL_URL - Static variable in interface cascading.flow.FlowNodeDescriptors
URL of the FlowStep in an external system *
EXTERNAL_URL - Static variable in interface cascading.flow.FlowStepDescriptors
URL of the FlowStep in an external system *
extract(TupleEntry, Fields) - Static method in class cascading.tuple.Tuples
Method extract creates a new Tuple from the given selector, but sets the values in the current tuple to null.
extractTuple(TupleEntry, Fields) - Static method in class cascading.tuple.Tuples
Method extractTuple returns a new Tuple based on the given selector.
ExtremaValueBase - Class in cascading.operation.aggregator
Class ExtremaValueBase is the base class for MaxValue and MinValue where the values are expected to by Comparable types and the Comparable.compareTo(Object) result is use for max/min comparison.
ExtremaValueBase(Fields) - Constructor for class cascading.operation.aggregator.ExtremaValueBase
 
ExtremaValueBase(int, Fields) - Constructor for class cascading.operation.aggregator.ExtremaValueBase
 
ExtremaValueBase(Fields, Object...) - Constructor for class cascading.operation.aggregator.ExtremaValueBase
 
ExtremaValueBase.Context - Class in cascading.operation.aggregator
 
ExtremaValueBase.Context() - Constructor for class cascading.operation.aggregator.ExtremaValueBase.Context
 

F

FactoryLoader - Class in cascading.provider
Class FactoryLoader is an implementation of a ProviderLoader and is used to load CascadingFactory instances used by internal frameworks.
FactoryLoader() - Constructor for class cascading.provider.FactoryLoader
 
fail() - Method in class cascading.operation.assertion.BaseAssertion
 
fail(Object...) - Method in class cascading.operation.assertion.BaseAssertion
 
FAIL_ON_CLOSE - Static variable in class cascading.tap.partition.PartitionTapProps
 
FAILURE_MODE_PASS_THROUGH - Static variable in class cascading.management.annotation.URISanitizer
System property to allow values to pass through a parse exception.
fetchAttempts - Variable in class cascading.stats.CounterCache
 
FIELD_NAME - Static variable in class cascading.operation.aggregator.Average
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.aggregator.Count
Field COUNT
FIELD_NAME - Static variable in class cascading.operation.aggregator.MaxValue
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.aggregator.MinValue
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.aggregator.Sum
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.text.DateFormatter
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.text.DateParser
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.text.FieldFormatter
Field FIELD_NAME
FIELD_NAME - Static variable in class cascading.operation.text.FieldJoiner
Field FIELD_NAME
fieldDeclaration - Variable in class cascading.operation.BaseOperation
Field fieldDeclaration
FieldFormatter - Class in cascading.operation.text
Class FieldFormatter formats the values in a Tuple with a given format and stuffs the result into a new field.
FieldFormatter(String) - Constructor for class cascading.operation.text.FieldFormatter
Constructor FieldJoiner creates a new FieldFormatter instance using the default field name "formatted".
FieldFormatter(Fields, String) - Constructor for class cascading.operation.text.FieldFormatter
Constructor FieldJoiner creates a new FieldFormatter instance.
FieldJoiner - Class in cascading.operation.text
Class FieldJoiner joins the values in a Tuple with a given delimiter and stuffs the result into a new field.
FieldJoiner(String) - Constructor for class cascading.operation.text.FieldJoiner
Constructor FieldJoiner creates a new FieldJoiner instance.
FieldJoiner(Fields) - Constructor for class cascading.operation.text.FieldJoiner
Constructor FieldJoiner creates a new FieldJoiner instance.
FieldJoiner(Fields, String) - Constructor for class cascading.operation.text.FieldJoiner
Constructor FieldJoiner creates a new FieldJoiner instance.
Fields - Class in cascading.tuple
Class Fields represents the field names in a Tuple.
Fields(Fields.Kind) - Constructor for class cascading.tuple.Fields
Constructor Fields creates a new Fields instance.
Fields() - Constructor for class cascading.tuple.Fields
 
Fields(Comparable...) - Constructor for class cascading.tuple.Fields
Constructor Fields creates a new Fields instance.
Fields(Comparable, Type) - Constructor for class cascading.tuple.Fields
 
Fields(Comparable[], Type[]) - Constructor for class cascading.tuple.Fields
 
Fields(Type...) - Constructor for class cascading.tuple.Fields
 
fields(Fields...) - Static method in class cascading.tuple.Fields
Method fields is a convenience method to create an array of Fields instances.
FieldsResolverException - Exception in cascading.tuple
Class FieldsResolverException is thrown when selectorFields cannot select from the sourceFields.
FieldsResolverException(Fields, Fields) - Constructor for exception cascading.tuple.FieldsResolverException
Constructor FieldsResolverException creates a new FieldsResolverException instance.
fieldTypeResolver - Variable in class cascading.scheme.util.DelimitedParser
fieldTypeResolver
FieldTypeResolver - Interface in cascading.scheme.util
 
FileType<Config> - Interface in cascading.tap.type
Interface FileType marks specific platform Tap classes as representing a file like interface.
Filter<Context> - Interface in cascading.operation
Interface Filter marks a given Operation as a filter, as opposed to being a Function.
FilterCall<C> - Interface in cascading.operation
Interface FilterCall provides access to the current Filter invocation arguments.
FilterEachStage - Class in cascading.flow.stream.element
 
FilterEachStage(FlowProcess, Each) - Constructor for class cascading.flow.stream.element.FilterEachStage
 
FilterNotNull - Class in cascading.operation.filter
Class FilterNotNull verifies that every value in the argument values Tuple is a null value.
FilterNotNull() - Constructor for class cascading.operation.filter.FilterNotNull
 
FilterNull - Class in cascading.operation.filter
Class FilterNull verifies that every value in the argument values Tuple is not a null value.
FilterNull() - Constructor for class cascading.operation.filter.FilterNull
 
filters - Variable in class cascading.operation.filter.Logic
Field filters
finalizeNodeSliceCapture() - Method in class cascading.flow.planner.FlowStepJob
 
find(String, String[]) - Method in class cascading.management.CascadingServices.NullDocumentService
 
find(String, String[]) - Method in interface cascading.management.DocumentService
 
findAllGroups(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findAllMatches(ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findAllMatches(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findAllMatches(PlannerContext, ElementGraph, Set<FlowElement>) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findAllMatchesOnPrimary(ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findAllMatchesOnPrimary(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findAllMatchesOnPrimary(PlannerContext, ElementGraph, Set<FlowElement>) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findAllNextFor(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
findAllPreviousFor(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
findClosureViaFloydWarshall(DirectedGraph<V, E>, DirectedGraph<V, E>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findClosureViaFloydWarshall(DirectedGraph<V, E>, DirectedGraph<V, E>, Set<V>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findContainingJar(Class<?>) - Static method in class cascading.util.Util
 
findExisting(Duct) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
findFirstMatch(ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findFirstMatch(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findFirstMatch(PlannerContext, ElementGraph, Set<FlowElement>) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findFirstMatch(FinderContext, PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findFirstPipeNamed(ElementGraph, String) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findFlows(String) - Method in class cascading.cascade.BaseCascade
 
findFlows(String) - Method in interface cascading.cascade.Cascade
Method findFlows returns a List of flows whose names match the given regex pattern.
findFlowsSinkingTo(String) - Method in class cascading.cascade.BaseCascade
 
findFlowsSinkingTo(String) - Method in interface cascading.cascade.Cascade
Method findFlowsSinkingTo returns all Flow instances that writes to a sink with the given identifier.
findFlowsSourcingFrom(String) - Method in class cascading.cascade.BaseCascade
 
findFlowsSourcingFrom(String) - Method in interface cascading.cascade.Cascade
Method findFlowsSourcingFrom returns all Flow instances that reads from a source with the given identifier.
findLastPipeNamed(ElementGraph, String) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findMainClass(Class, String) - Static method in class cascading.util.Util
 
findMapping(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findMapping(FinderContext, PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findMatchesOnPrimary(PlannerContext, ElementGraph, boolean, Set<FlowElement>) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findMatchesOnPrimary(FinderContext, PlannerContext, ElementGraph, boolean) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
findName(String) - Static method in class cascading.util.Util
 
findOrdinal(Pipe, Pipe) - Static method in class cascading.flow.FlowElements
 
findRegistryWith(String) - Method in class cascading.flow.planner.rule.RuleRegistrySet
 
findSinks(ElementGraph, Class<F>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findSinks(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findSources(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findSources(ElementGraph, Class<F>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
findVersion(String) - Static method in class cascading.util.Util
 
finishedTime - Variable in class cascading.stats.CascadingStats
Field finishedTime
fireListeners(CascadingStats.Status, CascadingStats.Status) - Method in class cascading.stats.CascadingStats
 
fireOnCompleted() - Method in class cascading.flow.BaseFlow
 
fireOnCompleted(Flow) - Static method in class cascading.flow.Flows
 
fireOnCompleted() - Method in class cascading.flow.planner.BaseFlowStep
 
fireOnRunning() - Method in class cascading.flow.planner.BaseFlowStep
 
fireOnStarting() - Method in class cascading.cascade.BaseCascade
 
fireOnStarting() - Method in class cascading.flow.BaseFlow
 
fireOnStarting() - Method in class cascading.flow.planner.BaseFlowStep
 
fireOnStopping() - Method in class cascading.cascade.BaseCascade
 
fireOnStopping() - Method in class cascading.flow.BaseFlow
 
fireOnStopping() - Method in class cascading.flow.planner.BaseFlowStep
 
fireOnThrowable(Throwable) - Method in class cascading.flow.BaseFlow
 
fireOnThrowable() - Method in class cascading.flow.BaseFlow
 
fireOnThrowable(Throwable) - Method in class cascading.flow.planner.BaseFlowStep
 
First - Class in cascading.operation.aggregator
Class First is an Aggregator that returns the first Tuple encountered in a grouping.
First() - Constructor for class cascading.operation.aggregator.First
Selects and returns the first argument Tuple encountered.
First(int) - Constructor for class cascading.operation.aggregator.First
Selects and returns the first N argument Tuples encountered.
First(Fields) - Constructor for class cascading.operation.aggregator.First
Selects and returns the first argument Tuple encountered.
First(Fields, int) - Constructor for class cascading.operation.aggregator.First
Selects and returns the first N argument Tuples encountered.
First(Fields, Tuple...) - Constructor for class cascading.operation.aggregator.First
Selects and returns the first argument Tuple encountered, unless the Tuple is a member of the set ignoreTuples.
FIRST - Static variable in class cascading.tuple.Fields
Field FIRST represents the first field position, 0
FirstBy - Class in cascading.pipe.assembly
Class FirstBy is used to return the first encountered Tuple in a tuple stream grouping.
FirstBy(Fields) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(Fields, Fields) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(Pipe, Fields, Fields) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(Pipe, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(String, Pipe, Fields, Fields) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(String, Pipe, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(Pipe[], Fields, Fields) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(Pipe[], Fields, Fields, int) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(String, Pipe[], Fields, Fields) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy(String, Pipe[], Fields, Fields, int) - Constructor for class cascading.pipe.assembly.FirstBy
Constructor FirstBy creates a new FirstBy instance.
FirstBy.FirstPartials - Class in cascading.pipe.assembly
Class CountPartials is a AggregateBy.Functor that is used to count observed duplicates from the tuple stream.
FirstBy.FirstPartials(Fields) - Constructor for class cascading.pipe.assembly.FirstBy.FirstPartials
Constructor FirstPartials creates a new FirstPartials instance.
firstEntry() - Method in class cascading.util.SortedListMultiMap
 
FirstNBuffer - Class in cascading.operation.buffer
Class FirstNBuffer will return the first N tuples seen in a given grouping.
FirstNBuffer() - Constructor for class cascading.operation.buffer.FirstNBuffer
Selects and returns the first argument Tuple encountered.
FirstNBuffer(int) - Constructor for class cascading.operation.buffer.FirstNBuffer
Selects and returns the first N argument Tuples encountered.
FirstNBuffer(Fields) - Constructor for class cascading.operation.buffer.FirstNBuffer
Selects and returns the first argument Tuple encountered.
FirstNBuffer(Fields, int) - Constructor for class cascading.operation.buffer.FirstNBuffer
Selects and returns the first N argument Tuples encountered.
FLOAT - Static variable in class cascading.tuple.coerce.Coercions
 
FLOAT_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
FloatCoerce - Class in cascading.tuple.coerce
 
FloatCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.FloatCoerce
 
FloatObjectCoerce - Class in cascading.tuple.coerce
 
FloatObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.FloatObjectCoerce
 
flow - Variable in class cascading.flow.BaseFlow.FlowHolder
Field flow
Flow<Config> - Interface in cascading.flow
A Flow is a logical unit of work declared by an assembly of Pipe instances connected to source and sink Tap instances.
FLOW_NODE_COMPARATOR - Static variable in class cascading.flow.planner.process.FlowNodeGraph
 
flowCanonicalHash - Variable in class cascading.flow.BaseFlow
Field flowCanonicalHash
flowConfInit(Flow<Config>) - Method in class cascading.tap.DecoratorTap
 
flowConfInit(Flow<Config>) - Method in class cascading.tap.Tap
Method flowInit allows this Tap instance to initialize itself in context of the given Flow instance.
FlowConnector - Class in cascading.flow
Class FlowConnector is the base class for all platform planners.
FlowConnector() - Constructor for class cascading.flow.FlowConnector
 
FlowConnector(RuleRegistrySet) - Constructor for class cascading.flow.FlowConnector
 
FlowConnector(Map<Object, Object>) - Constructor for class cascading.flow.FlowConnector
 
FlowConnector(Map<Object, Object>, RuleRegistrySet) - Constructor for class cascading.flow.FlowConnector
 
FlowConnectorProps - Class in cascading.flow
The class FlowConnectorProps is a fluent helper class for setting FlowConnector specific properties through the FlowConnector constructor.
FlowConnectorProps() - Constructor for class cascading.flow.FlowConnectorProps
 
flowConnectorProps() - Static method in class cascading.flow.FlowConnectorProps
Creates a new FlowConnectorProps instance.
FlowDef - Class in cascading.flow
Class FlowDef is a fluent interface for defining a Flow.
FlowDef() - Constructor for class cascading.flow.FlowDef
Constructor FlowDef creates a new FlowDef instance.
FlowDef(FlowDef, Map<String, Tap>, Map<String, Tap>, Map<String, Tap>, Map<String, Tap>) - Constructor for class cascading.flow.FlowDef
 
flowDef() - Static method in class cascading.flow.FlowDef
Creates a new instance of a FlowDef.
flowDescriptor - Variable in class cascading.flow.BaseFlow
 
flowDescriptor - Variable in class cascading.flow.FlowDef
 
FlowDescriptors - Interface in cascading.flow
Constants to be used as key in Flow.getFlowDescriptor().
FlowElement - Interface in cascading.flow
Interface FlowElement is a utility interface used internally to simplify DAG management.
flowElement - Variable in class cascading.flow.stream.element.ElementStage
 
FlowElementExpression - Class in cascading.flow.planner.iso.expression
 
FlowElementExpression(ElementCapture, boolean, Class<? extends FlowElement>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(ElementCapture, Class<? extends FlowElement>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(boolean, Class<? extends FlowElement>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(Class<? extends FlowElement>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(ElementCapture, boolean, Class<? extends FlowElement>) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(ElementCapture, Class<? extends FlowElement>) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(boolean, Class<? extends FlowElement>) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
FlowElementExpression(Class<? extends FlowElement>) - Constructor for class cascading.flow.planner.iso.expression.FlowElementExpression
 
flowElementGraph - Variable in class cascading.flow.BaseFlow
Field flowElementGraph
FlowElementGraph - Class in cascading.flow.planner.graph
Class ElementGraph represents the executable FlowElement graph.
FlowElementGraph() - Constructor for class cascading.flow.planner.graph.FlowElementGraph
 
FlowElementGraph(FlowElementGraph) - Constructor for class cascading.flow.planner.graph.FlowElementGraph
 
FlowElementGraph(Pipe[], Map<String, Tap>, Map<String, Tap>) - Constructor for class cascading.flow.planner.graph.FlowElementGraph
 
FlowElementGraph(PlatformInfo, Pipe[], Map<String, Tap>, Map<String, Tap>, Map<String, Tap>, Map<String, Tap>, boolean) - Constructor for class cascading.flow.planner.graph.FlowElementGraph
Constructor ElementGraph creates a new ElementGraph instance.
FlowElements - Class in cascading.flow
 
FlowElements() - Constructor for class cascading.flow.FlowElements
 
FlowException - Exception in cascading.flow
FlowException instances are thrown on errors when executing a Flow.
FlowException() - Constructor for exception cascading.flow.FlowException
Constructor FlowException creates a new FlowException instance.
FlowException(String) - Constructor for exception cascading.flow.FlowException
Constructor FlowException creates a new FlowException instance.
FlowException(String, Throwable) - Constructor for exception cascading.flow.FlowException
Constructor FlowException creates a new FlowException instance.
FlowException(String, String, Throwable) - Constructor for exception cascading.flow.FlowException
Constructor FlowException creates a new FlowException instance.
FlowException(String, String) - Constructor for exception cascading.flow.FlowException
Constructor FlowException creates a new FlowException instance.
FlowException(Throwable) - Constructor for exception cascading.flow.FlowException
Constructor FlowException creates a new FlowException instance.
FlowGraph - Class in cascading.cascade.planner
 
FlowGraph(IdentifierGraph) - Constructor for class cascading.cascade.planner.FlowGraph
 
FlowListener - Interface in cascading.flow
Interface FlowListener provides hooks for receiving events on various stages of a Flow execution.
FlowNode - Interface in cascading.flow
Class FlowNode represents the smallest parallelizable unit of work.
FlowNodeDescriptors - Interface in cascading.flow
Constants to be used as key in FlowStep.getFlowStepDescriptor().
FlowNodeFactory - Interface in cascading.flow.planner.process
 
FlowNodeGraph - Class in cascading.flow.planner.process
 
FlowNodeGraph() - Constructor for class cascading.flow.planner.process.FlowNodeGraph
 
FlowNodeGraph(FlowElementGraph, List<? extends ElementGraph>) - Constructor for class cascading.flow.planner.process.FlowNodeGraph
 
FlowNodeGraph(FlowNodeFactory, List<? extends ElementGraph>) - Constructor for class cascading.flow.planner.process.FlowNodeGraph
 
FlowNodeGraph(FlowNodeFactory, FlowElementGraph, List<? extends ElementGraph>) - Constructor for class cascading.flow.planner.process.FlowNodeGraph
 
FlowNodeGraph(FlowNodeFactory, FlowElementGraph, List<? extends ElementGraph>, Map<ElementGraph, List<? extends ElementGraph>>) - Constructor for class cascading.flow.planner.process.FlowNodeGraph
 
FlowNodeGraph.FlowNodeComparator - Class in cascading.flow.planner.process
Class FlowNodeComparator provides a consistent tie breaker when ordering nodes topologically.
FlowNodeGraph.FlowNodeComparator() - Constructor for class cascading.flow.planner.process.FlowNodeGraph.FlowNodeComparator
 
flowNodeStats - Variable in class cascading.flow.planner.BaseFlowNode
 
FlowNodeStats - Class in cascading.stats
Class FlowNodeStats collects FlowNode specific statistics.
FlowNodeStats(FlowNode, ClientState) - Constructor for class cascading.stats.FlowNodeStats
 
FlowPlanner<F extends BaseFlow,Config> - Class in cascading.flow.planner
Class FlowPlanner is the base class for all planner implementations.
FlowPlanner() - Constructor for class cascading.flow.planner.FlowPlanner
 
FlowPlanner.TempTapElementFactory - Class in cascading.flow.planner
 
FlowPlanner.TempTapElementFactory() - Constructor for class cascading.flow.planner.FlowPlanner.TempTapElementFactory
 
FlowProcess<Config> - Class in cascading.flow
FlowProcess implementations provide a call-back interface into the current computing system.
FlowProcess() - Constructor for class cascading.flow.FlowProcess
 
FlowProcess(FlowSession) - Constructor for class cascading.flow.FlowProcess
 
FlowProcess(FlowProcess<Config>) - Constructor for class cascading.flow.FlowProcess
Copy constructor.
flowProcess - Variable in class cascading.flow.stream.element.BoundaryStage
 
flowProcess - Variable in class cascading.flow.stream.element.ElementStage
 
flowProcess - Variable in class cascading.flow.stream.element.SpliceGate
 
flowProcess - Variable in class cascading.flow.stream.graph.NodeStreamGraph
 
flowProcess - Variable in class cascading.pipe.joiner.JoinerClosure
 
FlowProcess.NullFlowProcess - Class in cascading.flow
 
FlowProcess.NullFlowProcess() - Constructor for class cascading.flow.FlowProcess.NullFlowProcess
 
FlowProcessWrapper<Config> - Class in cascading.flow
 
FlowProcessWrapper(FlowProcess) - Constructor for class cascading.flow.FlowProcessWrapper
 
FlowProps - Class in cascading.flow
Class FlowProps is a fluent helper class for setting Flow specific properties through a FlowConnector.
FlowProps() - Constructor for class cascading.flow.FlowProps
 
flowProps() - Static method in class cascading.flow.FlowProps
Creates a new FlowProps instance.
FlowRuntimeProps - Class in cascading.flow
Class FlowRuntimeProps is a fluent helper class for setting Flow specific runtime properties through a FlowConnector.
FlowRuntimeProps() - Constructor for class cascading.flow.FlowRuntimeProps
 
flowRuntimeProps() - Static method in class cascading.flow.FlowRuntimeProps
 
Flows - Class in cascading.flow
Flows is a utility helper class.
FlowSession - Class in cascading.flow
FlowSession implementations provide a call-back interface into the current flow management system, if any.
FlowSession() - Constructor for class cascading.flow.FlowSession
 
FlowSession(CascadingServices) - Constructor for class cascading.flow.FlowSession
 
FlowSkipIfSinkExists - Class in cascading.flow
Class FlowSkipIfSinkExists is a FlowSkipStrategy implementation that returns true if the Flow sink exists, regardless if it is stale or not.
FlowSkipIfSinkExists() - Constructor for class cascading.flow.FlowSkipIfSinkExists
 
FlowSkipIfSinkNotStale - Class in cascading.flow
Class FlowSkipIfSinkNotStale is a FlowSkipStrategy implementation that returns true if the Flow sink exists and is not stale in relation to the Flow sources.
FlowSkipIfSinkNotStale() - Constructor for class cascading.flow.FlowSkipIfSinkNotStale
 
FlowSkipStrategy - Interface in cascading.flow
Interface FlowSkipStrategy is used to create new strategies that decide when a Flow should be skipped when executed in a Cascade.
FlowSliceStats<K extends Enum> - Class in cascading.stats
Typically CascadingStats objects have an internal state model with timings, the FlowSliceStats is a simplified Stats object and only reports what the underlying platform reports, not the client side observations.
FlowSliceStats() - Constructor for class cascading.stats.FlowSliceStats
 
FlowSliceStats.FlowSliceAttempt - Class in cascading.stats
 
FlowSliceStats.FlowSliceAttempt() - Constructor for class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
flowStats - Variable in class cascading.flow.BaseFlow
Field flowStats
FlowStats - Class in cascading.stats
Class FlowStats collects Flow specific statistics.
FlowStats(Flow, ClientState) - Constructor for class cascading.stats.FlowStats
 
FlowStep<Config> - Interface in cascading.flow
Class FlowStep is an internal representation of a given "job" possibly to be executed on a remote cluster.
flowStep - Variable in class cascading.flow.planner.FlowStepJob
Field flowStep
FlowStepDescriptors - Interface in cascading.flow
Constants to be used as key in FlowStep.getFlowStepDescriptor().
FlowStepFactory<Config> - Interface in cascading.flow.planner.process
 
flowStepGraph - Variable in class cascading.flow.BaseFlow
Field stepGraph
FlowStepGraph - Class in cascading.flow.planner.process
 
FlowStepGraph() - Constructor for class cascading.flow.planner.process.FlowStepGraph
 
FlowStepGraph(FlowStepFactory, FlowElementGraph, Map<ElementGraph, List<? extends ElementGraph>>) - Constructor for class cascading.flow.planner.process.FlowStepGraph
 
FlowStepGraph(FlowStepFactory, FlowElementGraph, Map<ElementGraph, List<? extends ElementGraph>>, Map<ElementGraph, List<? extends ElementGraph>>) - Constructor for class cascading.flow.planner.process.FlowStepGraph
 
FlowStepJob<Config> - Class in cascading.flow.planner
 
FlowStepJob(ClientState, Config, BaseFlowStep<Config>, long, long, long) - Constructor for class cascading.flow.planner.FlowStepJob
 
FlowStepListener - Interface in cascading.flow
Interface FlowStepListener provides hooks for receiving events on various stages of a FlowStep execution.
flowStepStats - Variable in class cascading.flow.planner.BaseFlowStep
 
flowStepStats - Variable in class cascading.flow.planner.FlowStepJob
Field stepStats
FlowStepStats - Class in cascading.stats
Class FlowStepStats collects FlowStep specific statistics.
FlowStepStats(FlowStep, ClientState) - Constructor for class cascading.stats.FlowStepStats
 
FlowStepStrategy<Config> - Interface in cascading.flow
The FlowStepStrategy interface allows for on the fly customization of FlowStep configuration values before they are submitted to the underlying platform.
flush(FlowProcess, OperationCall<Context>) - Method in class cascading.operation.BaseOperation
 
flush(FlowProcess, OperationCall<Context>) - Method in interface cascading.operation.Operation
The flush method is called when an Operation that is caching values must empty the cache.
flush(FlowProcess, OperationCall<AggregateBy.CompositeFunction.Context>) - Method in class cascading.pipe.assembly.AggregateBy.CompositeFunction
 
fmix(int, int) - Static method in class cascading.util.Murmur3
 
ForeverValueIterator<Value> - Class in cascading.util
The ForeverValueIterator class will iterate over a single value forever.
ForeverValueIterator(Value) - Constructor for class cascading.util.ForeverValueIterator
 
Fork<Incoming,Outgoing> - Class in cascading.flow.stream.duct
 
Fork(Duct[]) - Constructor for class cascading.flow.stream.duct.Fork
 
format(String) - Method in class cascading.tuple.Tuple
Method format uses the Formatter class for formatting this tuples values into a new string.
formatDurationDHMSms(long) - Static method in class cascading.util.Util
 
formatDurationFromMillis(long) - Static method in class cascading.util.Util
 
formatDurationHMSms(long) - Static method in class cascading.util.Util
 
formatDurationMSms(long) - Static method in class cascading.util.Util
 
formatRawTrace(Pipe, String) - Static method in class cascading.util.TraceUtil
Method formatRawTrace does not include the pipe name
formatTrace(Scheme, String) - Static method in class cascading.util.TraceUtil
 
formatTrace(FlowElement, String) - Static method in class cascading.util.TraceUtil
 
formatTrace(Pipe, String) - Static method in class cascading.util.TraceUtil
 
formatTrace(Tap, String) - Static method in class cascading.util.TraceUtil
 
formatTrace(Operation, String) - Static method in class cascading.util.TraceUtil
 
foundElements - Variable in class cascading.flow.planner.iso.finder.Match
 
foundMatch() - Method in class cascading.flow.planner.iso.finder.Match
 
foundScopes - Variable in class cascading.flow.planner.iso.finder.Match
 
frameworks - Variable in class cascading.property.AppProps
 
frequency(Tuple, Object) - Static method in class cascading.tuple.Tuples
Method frequency behaves the same as Collections.frequency(java.util.Collection, Object).
frequency(TupleEntry, Object) - Static method in class cascading.tuple.Tuples
Method frequency behaves the same as Collections.frequency(java.util.Collection, Object).
Function<Context> - Interface in cascading.operation
Interface Function marks a given Operation as a function, as opposed to being a Filter.
FunctionCall<C> - Interface in cascading.operation
Interface FunctionCall provides access to the current Function invocation arguments.
FunctionEachStage - Class in cascading.flow.stream.element
 
FunctionEachStage(FlowProcess, Each) - Constructor for class cascading.flow.stream.element.FunctionEachStage
 

G

Gate<Incoming,Outgoing> - Class in cascading.flow.stream.duct
Denotes there will be multiple input paths into this duct
Gate() - Constructor for class cascading.flow.stream.duct.Gate
 
GATHER_PARTITIONS - Static variable in class cascading.flow.FlowRuntimeProps
 
get(String, String) - Method in class cascading.management.CascadingServices.NullDocumentService
 
get(String, String) - Method in interface cascading.management.DocumentService
 
get(String) - Method in interface cascading.property.ConfigDef.Getter
 
get(String) - Method in interface cascading.property.ConfigDef.Setter
 
get(Object) - Method in class cascading.tuple.collect.SpillableTupleMap
 
get(int) - Method in class cascading.tuple.Fields
Method get returns the field name or position at the given index i.
get(int[]) - Method in class cascading.tuple.Tuple
Method get will return a new Tuple instance populated with element values from the given array of positions.
get(Fields, Fields) - Method in class cascading.tuple.Tuple
Method get returns a new Tuple populated with only those values whose field names are specified in the given selector.
get(Object) - Method in class cascading.util.cache.DirectMappedCache
 
get(Object) - Method in class cascading.util.cache.LRUHashMapCache
 
get(Object) - Method in class cascading.util.cache.OrderedHashMapCache
 
get(K, int) - Method in class cascading.util.SortedListMultiMap
 
getAction() - Method in enum cascading.flow.planner.rule.PlanPhase
 
getAggregator() - Method in class cascading.pipe.Every
 
getAggregators() - Method in class cascading.pipe.assembly.AggregateBy
 
getAllAccumulatedSources() - Method in class cascading.flow.planner.BaseFlowStep
 
getAllDucts() - Method in class cascading.flow.stream.graph.StreamGraph
 
getAllEdges(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
getAllEdges(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
getAllEdges(FlowElement, FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
getAllEdges(PlannerContext, ElementGraph, Map<ElementExpression, FlowElement>) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
getAllEdges(Process, Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getAllEdges(Process, Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getAllKeys() - Method in class cascading.property.ConfigDef
 
getAllOperations() - Method in class cascading.flow.planner.BaseFlowStep
 
getAllShortestPathsBetween(ElementGraph, FlowElement, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
getAllShortestPathsBetween(DirectedGraph<V, E>, V, V) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
getAllSinkElements() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getAllSinkElements() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getAllSourceElements() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getAllSourceElements() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getAllTaps() - Method in class cascading.cascade.BaseCascade
 
getAllTaps() - Method in interface cascading.cascade.Cascade
Method getAllTaps returns all source, sink, and checkpoint Tap instances associated with the managed Flow instances in this Cascade instance.
getAllValues(K...) - Method in class cascading.util.MultiMap
 
getAnchors() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getAnnotatedSubGraphs() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
getAnnotation() - Method in class cascading.flow.planner.iso.ElementAnnotation
 
getAnnotationExcludes() - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
getAnnotationExcludes() - Method in class cascading.flow.planner.rule.partitioner.WholeGraphRulePartitioner
 
getAnnotationExcludes() - Method in class cascading.flow.planner.rule.RulePartitioner
 
getAnnotationMap(ElementAnnotation[]) - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
getAnnotationMap(ElementAnnotation[]) - Method in class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
getAnnotationMap(ElementAnnotation[]) - Method in class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
getAnnotationMap(ElementAnnotation[]) - Method in interface cascading.flow.planner.iso.subgraph.SubGraphIterator
 
getAnnotations() - Method in class cascading.flow.planner.BaseFlowStep
 
getAnnotations() - Method in class cascading.flow.planner.graph.AnnotatedDecoratedElementGraph
 
getAnnotations() - Method in interface cascading.flow.planner.graph.AnnotatedGraph
 
getAnnotations() - Method in class cascading.flow.planner.graph.BaseAnnotatedElementGraph
 
getAnnotations() - Method in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
getAnnotations() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getAnnotations() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getAppID() - Method in class cascading.stats.FlowStats
 
getApplicationFrameworks(Map<Object, Object>) - Static method in class cascading.property.AppProps
 
getApplicationID(Map<Object, Object>) - Static method in class cascading.property.AppProps
 
getApplicationID() - Static method in class cascading.property.AppProps
 
getApplicationJarClass(Map<Object, Object>) - Static method in class cascading.property.AppProps
Method getApplicationJarClass returns the Class set by the setApplicationJarClass method.
getApplicationJarPath(Map<Object, Object>) - Static method in class cascading.property.AppProps
Method getApplicationJarPath return the path set by the setApplicationJarPath method.
getApplicationName(Map<Object, Object>) - Static method in class cascading.property.AppProps
 
getApplicationTags(Map<Object, Object>) - Static method in class cascading.property.AppProps
 
getApplicationVersion(Map<Object, Object>) - Static method in class cascading.property.AppProps
 
getApplies() - Method in class cascading.flow.planner.iso.expression.ScopeExpression
 
getAppName() - Method in class cascading.stats.FlowStats
 
getArgumentFields() - Method in class cascading.operation.ConcreteCall
 
getArgumentFields() - Method in interface cascading.operation.OperationCall
Returns the Fields of the expected arguments TupleEntry.
getArgumentFields() - Method in class cascading.pipe.assembly.AggregateBy
 
getArguments() - Method in interface cascading.operation.AggregatorCall
Returns TupleEntry of argument values.
getArguments() - Method in class cascading.operation.ConcreteCall
 
getArguments() - Method in interface cascading.operation.FilterCall
Returns TupleEntry of argument values.
getArguments() - Method in interface cascading.operation.FunctionCall
Returns TupleEntry of argument values.
getArguments() - Method in interface cascading.operation.GroupAssertionCall
Returns TupleEntry of argument values.
getArguments() - Method in interface cascading.operation.ValueAssertionCall
Returns TupleEntry of argument values.
getArgumentsDeclarator() - Method in class cascading.flow.planner.Scope
Method getArguments returns the arguments of this Scope object.
getArgumentSelector() - Method in class cascading.pipe.Operator
Method getArgumentSelector returns the argumentSelector of this Operator object.
getArgumentSelector() - Method in exception cascading.pipe.OperatorException
Method getArgumentSelector returns the argumentSelector of this OperatorException object.
getArgumentSelectors() - Method in class cascading.operation.filter.Logic
 
getArgumentsIterator() - Method in interface cascading.operation.BufferCall
Returns an Iterator of TupleEntry instances representing the arguments for the called Buffer.operate(cascading.flow.FlowProcess, BufferCall) method.
getArgumentsIterator() - Method in class cascading.operation.ConcreteCall
 
getArgumentsSelector() - Method in class cascading.flow.planner.Scope
Method getArgumentSelector returns the argumentSelector of this Scope object.
getAssemblyGraph() - Method in class cascading.flow.planner.rule.RuleResult
 
getAssemblyPlanners() - Method in class cascading.flow.FlowDef
Method getAssemblyPlanners returns the current registered AssemblyPlanners.
getAssemblyToStepGraphMap() - Method in class cascading.flow.planner.rule.RuleResult
 
getAssertionLevel() - Method in class cascading.flow.FlowConnectorProps
 
getAssertionLevel() - Method in class cascading.flow.FlowDef
 
getAssertionLevel(FlowDef) - Method in class cascading.flow.planner.FlowPlanner
 
getAssertionType() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getAttempts() - Method in class cascading.stats.FlowSliceStats
 
getBeginGraph() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getBeginGraph() - Method in class cascading.flow.planner.iso.GraphResult
 
getBeginGraph() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
getBeginGraph() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getBoolean(int) - Method in class cascading.tuple.Tuple
Method getBoolean returns the element at the given position as a boolean.
getBoolean(Comparable) - Method in class cascading.tuple.TupleEntry
Method getBoolean returns the element for the given field name or position as a boolean.
getBooleanProperty(String) - Method in class cascading.flow.FlowProcess
Method getBooleanProperty should be used to return configuration parameters from the underlying system.
getBooleanProperty(String, boolean) - Method in class cascading.flow.FlowProcess
Method getBooleanProperty should be used to return configuration parameters from the underlying system.
getBoundary() - Method in class cascading.flow.stream.element.BoundaryStage
 
getBranchNames() - Method in class cascading.flow.stream.element.BoundaryStage
 
getBranchNames() - Method in interface cascading.flow.stream.element.ElementDuct
 
getBranchNames() - Method in class cascading.flow.stream.element.ElementStage
 
getBranchNames() - Method in class cascading.flow.stream.element.SpliceGate
 
getBuffer() - Method in class cascading.pipe.Every
 
getCacheFactoryClassName() - Method in class cascading.pipe.assembly.AggregateByProps
Returns the name of the cache factory.
getCacheFactoryClassName() - Method in class cascading.pipe.assembly.UniqueProps
Returns the name of the cache factory.
getCalendar() - Method in class cascading.operation.text.DateOperation
 
getCalendar() - Method in class cascading.tuple.type.DateType
 
getCanonicalType() - Method in class cascading.tuple.coerce.BigDecimalCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.BooleanCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.BooleanObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.CharacterCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.CharacterObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.DoubleCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.DoubleObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.FloatCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.FloatObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.IntegerCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.IntegerObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.LongCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.LongObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.ObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.ShortCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.ShortObjectCoerce
 
getCanonicalType() - Method in class cascading.tuple.coerce.StringCoerce
 
getCanonicalType() - Method in interface cascading.tuple.type.CoercibleType
 
getCanonicalType() - Method in class cascading.tuple.type.DateType
 
getCanonicalTypes(Type[]) - Static method in class cascading.tuple.coerce.Coercions
 
getCapacity() - Method in class cascading.pipe.assembly.AggregateBy
 
getCapacity() - Method in class cascading.pipe.assembly.AggregateByProps
Returns the capacity.
getCapacity() - Method in class cascading.pipe.assembly.UniqueProps
Returns the capacity.
getCapacity() - Method in interface cascading.util.cache.CascadingCache
Returns the capacity of this cache.
getCapacity() - Method in class cascading.util.cache.DirectMappedCache
 
getCapacity() - Method in class cascading.util.cache.LRUHashMapCache
 
getCapacity() - Method in class cascading.util.cache.OrderedHashMapCache
 
getCapture() - Method in class cascading.flow.planner.iso.ElementAnnotation
 
getCapture() - Method in class cascading.flow.planner.iso.expression.ElementExpression
 
getCapture() - Method in class cascading.flow.planner.iso.expression.NotElementExpression
 
getCapturedElements(ElementCapture...) - Method in class cascading.flow.planner.iso.finder.Match
 
getCaptureMap() - Method in class cascading.flow.planner.iso.finder.Match
 
getCascade() - Method in class cascading.stats.CascadeStats
 
getCascadeID() - Method in class cascading.flow.BaseFlow
 
getCascadeID() - Method in interface cascading.flow.Flow
Returns the parent Cascade ID that owns this Flow instance.
getCascadeStats() - Method in class cascading.cascade.BaseCascade
 
getCascadeStats() - Method in interface cascading.cascade.Cascade
Method getCascadeStats returns the cascadeStats of this Cascade object.
getCascadingServices() - Method in class cascading.flow.BaseFlow
 
getCascadingServices() - Method in class cascading.flow.FlowSession
 
getChar(int) - Method in class cascading.tuple.Tuple
Method getChar returns the element at the given position as a char.
getCheckpointNames() - Method in class cascading.flow.BaseFlow
 
getCheckpointNames() - Method in interface cascading.flow.Flow
 
getCheckpoints() - Method in class cascading.flow.BaseFlow
 
getCheckpoints() - Method in interface cascading.flow.Flow
Method getCheckpoints returns the checkpoint taps of this Flow object.
getCheckpoints() - Method in class cascading.flow.FlowDef
Method getCheckpoints returns the checkpoint taps of this FlowDef object.
getCheckpointsCollection() - Method in class cascading.flow.BaseFlow
 
getCheckpointsCollection() - Method in interface cascading.flow.Flow
Method getCheckpointsCollection returns a Collection of checkpoint Taps for this Flow object.
getCheckpointsCopy() - Method in class cascading.flow.FlowDef
Method getCheckpointsCopy returns a copy of the checkpoint tap Map.
getCheckpointsMap() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getCheckpointsTaps() - Method in class cascading.cascade.BaseCascade
 
getCheckpointsTaps() - Method in interface cascading.cascade.Cascade
Method getCheckpointTaps returns all checkpoint Tap instances from all the Flow instances in this Cascade instance.
getCheckpointTapDecoratorClassName() - Method in class cascading.flow.FlowConnectorProps
 
getChildIdentifiers(FlowProcess<? extends Config>) - Method in interface cascading.tap.type.FileType
Method getChildIdentifiers returns an array of child identifiers if this resource is a directory.
getChildIdentifiers(Config) - Method in interface cascading.tap.type.FileType
Method getChildIdentifiers returns an array of child identifiers if this resource is a directory.
getChildIdentifiers(FlowProcess<? extends Config>, int, boolean) - Method in interface cascading.tap.type.FileType
 
getChildIdentifiers(Config, int, boolean) - Method in interface cascading.tap.type.FileType
 
getChildPartitionIdentifiers(FlowProcess<? extends Config>, boolean) - Method in class cascading.tap.partition.BasePartitionTap
Method getChildPartitionIdentifiers returns an array of all identifiers for all available partitions.
getChildren(ElementGraph) - Method in class cascading.flow.planner.rule.util.ResultTree
 
getChildren() - Method in class cascading.stats.BaseCachedNodeStats
 
getChildren() - Method in class cascading.stats.CascadeStats
 
getChildren() - Method in class cascading.stats.CascadingStats
Method getChildren returns any relevant child statistics instances.
getChildren() - Method in class cascading.stats.FlowStats
 
getChildren() - Method in class cascading.stats.FlowStepStats
 
getChildren() - Method in class cascading.stats.process.ProcessFlowStats
 
getChildren() - Method in class cascading.stats.process.ProcessStepStats
 
getChildTaps() - Method in interface cascading.tap.CompositeTap
 
getChildTaps() - Method in class cascading.tap.MultiSinkTap
 
getChildTaps() - Method in class cascading.tap.MultiSourceTap
 
getChildTransforms() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getChildTransforms() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getChildWith(String) - Method in class cascading.stats.BaseCachedNodeStats
 
getChildWith(String) - Method in class cascading.stats.CascadeStats
 
getChildWith(String) - Method in class cascading.stats.CascadingStats
Method getChildWith returns a child stats instance with the given ID value.
getChildWith(String) - Method in class cascading.stats.FlowStats
 
getChildWith(String) - Method in class cascading.stats.FlowStepStats
 
getClassPath() - Method in class cascading.flow.BaseFlow
 
getClassPath() - Method in class cascading.flow.FlowDef
 
getClientState() - Method in class cascading.flow.BaseFlow
 
getCloseableInput() - Method in class cascading.util.SingleValueCloseableIterator
 
getCodecClass(FlowProcess, String, Class) - Static method in class cascading.tuple.collect.SpillableTupleList
 
getCodecs() - Method in class cascading.tuple.collect.SpillableProps
 
getCoercedTuple(Type[]) - Method in class cascading.tuple.TupleEntry
Method getCoercedTuple is a helper method for copying the current tuple elements into a new Tuple, of the same size, as the requested coerced types.
getCoercedTuple(Type[], Tuple) - Method in class cascading.tuple.TupleEntry
Method getCoercedTuple is a helper method for copying the current tuple elements into the new Tuple, of the same size, as the requested coerced types.
getCombineSplits() - Method in class cascading.flow.FlowRuntimeProps
 
getComparator(Class<T>) - Method in interface cascading.tuple.Comparison
 
getComparator(Comparable) - Method in class cascading.tuple.Fields
 
getComparatorFor(int, DataInputStream) - Method in interface cascading.tuple.io.TupleInputStream.ElementReader
 
getComparatorFor(int) - Method in class cascading.tuple.io.TupleInputStream
 
getComparators() - Method in class cascading.flow.stream.util.SparseTupleComparator
 
getComparators() - Method in class cascading.tuple.Fields
Method getComparators returns the comparators of this Fields object.
getComponentAttributes(T) - Method in interface cascading.util.jgrapht.ComponentAttributeProvider
 
getConfig() - Method in interface cascading.flow.Flow
Method getConfig returns the internal configuration object.
getConfig() - Method in class cascading.flow.FlowProcess
Method getConfig returns the actual instance of the underlying configuration instance.
getConfig() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getConfig() - Method in class cascading.flow.FlowProcessWrapper
 
getConfig() - Method in interface cascading.flow.FlowStep
Method getConfig returns the current initialized configuration.
getConfig() - Method in class cascading.flow.planner.BaseFlowStep
 
getConfig() - Method in class cascading.flow.planner.FlowStepJob
 
getConfig() - Method in class cascading.flow.process.ProcessFlow
 
getConfigAsProperties() - Method in interface cascading.flow.Flow
Method getConfigAsProperties converts the internal configuration object into a Map of key value pairs.
getConfigAsProperties() - Method in interface cascading.flow.FlowStep
Method getConfigAsProperties converts the internal configuration object into a Map of key value pairs.
getConfigAsProperties() - Method in class cascading.flow.planner.BaseFlowStep
 
getConfigAsProperties() - Method in class cascading.flow.process.ProcessFlow
 
getConfigAsProperties() - Method in class cascading.flow.process.ProcessFlowStep
 
getConfigCopy() - Method in interface cascading.flow.Flow
Method getConfigCopy returns a copy of the internal configuration object.
getConfigCopy() - Method in class cascading.flow.FlowProcess
 
getConfigCopy() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getConfigCopy() - Method in class cascading.flow.FlowProcessWrapper
 
getConfigCopy() - Method in class cascading.flow.process.ProcessFlow
 
getConfigDef() - Method in interface cascading.flow.planner.ScopedElement
 
getConfigDef() - Method in class cascading.pipe.Pipe
Returns a ConfigDef instance that allows for local properties to be set and made available via a resulting FlowProcess instance when the pipe is invoked.
getConfigDef() - Method in class cascading.tap.DecoratorTap
 
getConfigDef() - Method in class cascading.tap.Tap
Returns a ConfigDef instance that allows for local properties to be set and made available via a resulting FlowProcess instance when the tap is invoked.
getContext() - Method in class cascading.operation.ConcreteCall
 
getContext() - Method in interface cascading.operation.OperationCall
Returns the user set context object, C.
getContext() - Method in class cascading.scheme.ConcreteCall
 
getContext() - Method in interface cascading.scheme.SinkCall
Method getContext returns the context of this SinkCall object.
getContext() - Method in interface cascading.scheme.SourceCall
Method getContext returns the context of this SourceCall object.
getContractedGraph() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
getContractedMatchExpression() - Method in class cascading.flow.planner.rule.RuleExpression
 
getContractionExpression() - Method in class cascading.flow.planner.rule.RuleExpression
 
getContractionGraph() - Method in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
getCounterEnum() - Method in class cascading.operation.state.Counter
 
getCounterGroups() - Method in class cascading.stats.BaseCachedNodeStats
Method getCounterGroups returns all of the Hadoop counter groups.
getCounterGroups() - Method in class cascading.stats.BaseCachedStepStats
Method getCounterGroups returns all of the Hadoop counter groups.
getCounterGroups() - Method in class cascading.stats.CascadeStats
 
getCounterGroups() - Method in class cascading.stats.CounterCache
 
getCounterGroups() - Method in class cascading.stats.FlowStats
 
getCounterGroups() - Method in class cascading.stats.process.ProcessStepStats
 
getCounterGroups() - Method in interface cascading.stats.ProvidesCounters
Method getCounterGroups returns all the available counter group names.
getCounterGroupsMatching(String) - Method in class cascading.stats.BaseCachedNodeStats
Method getCounterGroupsMatching returns all the Hadoop counter groups that match the give regex pattern.
getCounterGroupsMatching(String) - Method in class cascading.stats.BaseCachedStepStats
Method getCounterGroupsMatching returns all the Hadoop counter groups that match the give regex pattern.
getCounterGroupsMatching(String) - Method in class cascading.stats.CascadeStats
 
getCounterGroupsMatching(String) - Method in class cascading.stats.CascadingStats
Method getCounterGroupsMatching returns all the available counter group names that match the given regular expression.
getCounterGroupsMatching(String) - Method in class cascading.stats.CounterCache
 
getCounterGroupsMatching(String) - Method in class cascading.stats.FlowStats
 
getCounterGroupsMatching(String) - Method in class cascading.stats.process.ProcessStepStats
 
getCounters(JobStatus) - Method in class cascading.stats.CounterCache
 
getCounters() - Method in class cascading.stats.FlowSliceStats
 
getCountersFor(String) - Method in class cascading.stats.BaseCachedNodeStats
Method getCountersFor returns the Hadoop counters for the given group.
getCountersFor(String) - Method in class cascading.stats.BaseCachedStepStats
Method getCountersFor returns the Hadoop counters for the given group.
getCountersFor(String) - Method in class cascading.stats.CascadeStats
 
getCountersFor(Class<? extends Enum>) - Method in class cascading.stats.CascadingStats
 
getCountersFor(Counters, String) - Method in class cascading.stats.CounterCache
 
getCountersFor(String) - Method in class cascading.stats.CounterCache
 
getCountersFor(String) - Method in class cascading.stats.FlowStats
 
getCountersFor(String) - Method in class cascading.stats.process.ProcessStepStats
 
getCountersFor(String) - Method in interface cascading.stats.ProvidesCounters
Method getCountersFor returns all the counter names for the give group name.
getCountersFor(Class<? extends Enum>) - Method in interface cascading.stats.ProvidesCounters
Method getCountersFor returns all the counter names for the counter Enum.
getCounterString() - Method in class cascading.operation.state.Counter
 
getCounterValue(Enum) - Method in class cascading.flow.FlowProcess
Method getCounterValue is used to retrieve a counter value.
getCounterValue(String, String) - Method in class cascading.flow.FlowProcess
Method getCounterValue is used to retrieve a counter value.
getCounterValue(Enum) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getCounterValue(String, String) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getCounterValue(Enum) - Method in class cascading.flow.FlowProcessWrapper
 
getCounterValue(String, String) - Method in class cascading.flow.FlowProcessWrapper
 
getCounterValue(Enum) - Method in class cascading.stats.BaseCachedNodeStats
Method getCounterValue returns the Hadoop counter value for the given counter enum.
getCounterValue(String, String) - Method in class cascading.stats.BaseCachedNodeStats
Method getCounterValue returns the Hadoop counter value for the given group and counter name.
getCounterValue(Enum) - Method in class cascading.stats.BaseCachedStepStats
Method getCounterValue returns the Hadoop counter value for the given counter enum.
getCounterValue(String, String) - Method in class cascading.stats.BaseCachedStepStats
Method getCounterValue returns the Hadoop counter value for the given group and counter name.
getCounterValue(Enum) - Method in class cascading.stats.CascadeStats
 
getCounterValue(String, String) - Method in class cascading.stats.CascadeStats
 
getCounterValue(Counters, Enum) - Method in class cascading.stats.CounterCache
 
getCounterValue(Counters, String, String) - Method in class cascading.stats.CounterCache
 
getCounterValue(Enum) - Method in class cascading.stats.CounterCache
 
getCounterValue(String, String) - Method in class cascading.stats.CounterCache
 
getCounterValue(Enum) - Method in class cascading.stats.FlowStats
 
getCounterValue(String, String) - Method in class cascading.stats.FlowStats
 
getCounterValue(Enum) - Method in class cascading.stats.process.ProcessStepStats
 
getCounterValue(String, String) - Method in class cascading.stats.process.ProcessStepStats
 
getCounterValue(Enum) - Method in interface cascading.stats.ProvidesCounters
Method getCounter returns the current value for the given counter Enum.
getCounterValue(String, String) - Method in interface cascading.stats.ProvidesCounters
Method getCounter returns the current value for the given group and counter.
getCreateFlowStepJob(FlowProcess<Config>, Config) - Method in class cascading.flow.planner.BaseFlowStep
 
getCurrentDuration() - Method in class cascading.stats.CascadingStats
Method getCurrentDuration returns the current duration of the current work whether or not the work is finished.
getCurrentIdentifier(FlowProcess<? extends Config>) - Method in class cascading.tap.partition.BasePartitionTap
 
getCurrentProcess() - Method in class cascading.flow.FlowSession
Method getCurrentProcess returns the currentProcess of this FlowSession object.
getCurrentSession() - Method in class cascading.flow.FlowProcess
Method getCurrentSession returns the currentSession of this FlowProcess object.
getCurrentSession() - Method in class cascading.flow.FlowProcessWrapper
 
getCurrentSliceNum() - Method in class cascading.flow.FlowProcess
Method getCurrentSliceNum returns an integer representing which slice instance currently running.
getCurrentSliceNum() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getCurrentSliceNum() - Method in class cascading.flow.FlowProcessWrapper
 
getDateFormat() - Method in class cascading.operation.text.DateOperation
Method getDateFormat returns the dateFormat of this DateParser object.
getDateFormat() - Method in class cascading.tuple.type.DateType
 
getDateFormatString() - Method in class cascading.operation.text.DateOperation
 
getDebugLevel() - Method in class cascading.flow.FlowConnectorProps
 
getDebugLevel() - Method in class cascading.flow.FlowDef
 
getDebugLevel(FlowDef) - Method in class cascading.flow.planner.FlowPlanner
 
getDeclaredFields() - Method in interface cascading.operation.AggregatorCall
Return the resolved Fields declared by the current Operation.
getDeclaredFields() - Method in interface cascading.operation.BufferCall
Return the resolved Fields declared by the current Operation.
getDeclaredFields() - Method in class cascading.operation.ConcreteCall
 
getDeclaredFields() - Method in interface cascading.operation.FunctionCall
Return the resolved Fields declared by the current Operation.
getDeclaredFields() - Method in interface cascading.pipe.assembly.AggregateBy.Functor
Method getDeclaredFields returns the declaredFields of this Functor object.
getDeclaredFields() - Method in class cascading.pipe.assembly.AverageBy.AveragePartials
 
getDeclaredFields() - Method in class cascading.pipe.assembly.CountBy.CountPartials
 
getDeclaredFields() - Method in class cascading.pipe.assembly.FirstBy.FirstPartials
 
getDeclaredFields() - Method in class cascading.pipe.assembly.MaxBy.MaxPartials
 
getDeclaredFields() - Method in class cascading.pipe.assembly.MinBy.MinPartials
 
getDeclaredFields() - Method in class cascading.pipe.assembly.SumBy.SumPartials
 
getDeclaredFields() - Method in exception cascading.pipe.OperatorException
Method getDeclaredFields returns the declaredFields of this OperatorException object.
getDeclaredFields() - Method in class cascading.pipe.Splice
Method getDeclaredFields returns the declaredFields of this Splice object.
getDecorated() - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
getDefaultConfig() - Method in class cascading.flow.planner.FlowPlanner
 
getDefaultIntermediateSchemeClass() - Method in class cascading.flow.FlowConnector
 
getDefaultProperties() - Method in class cascading.flow.planner.FlowPlanner
 
getDefaultTupleElementComparator() - Method in class cascading.flow.FlowProps
 
getDelegate() - Method in class cascading.flow.FlowProcessWrapper
 
getDelegatedTuple(Tuple) - Method in class cascading.flow.stream.element.GroupingSpliceGate
This allows the tuple to honor the hasher and comparators, if any
getDelimiter() - Method in class cascading.operation.regex.RegexMatcher
 
getDelimiter() - Method in class cascading.operation.text.FieldJoiner
Method getFormat returns the delimiter of this FieldJoiner object.
getDelimiter() - Method in class cascading.scheme.util.DelimitedParser
 
getDepthFirstIterator() - Method in class cascading.flow.planner.graph.FlowElementGraph
Method getDepthFirstIterator returns the depthFirstIterator of this ElementGraph object.
getDiagnostics() - Method in class cascading.stats.FlowSliceStats
 
getDocumentService() - Method in class cascading.management.CascadingServices
 
getDouble(int) - Method in class cascading.tuple.Tuple
Method getDouble returns the element at the given position as a double.
getDouble(Comparable) - Method in class cascading.tuple.TupleEntry
Method getDouble returns the element for the given field name or position as a double.
getDuplicatedElements(ElementGraph) - Method in class cascading.flow.planner.process.BaseProcessGraph
All elements, from the given ElementGraph, that belong to two or more processes, that are not sink or source elements that connect processes.
getDuplicatedElements(ElementGraph) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getDuration() - Method in class cascading.flow.planner.rule.RuleResult
 
getDuration() - Method in class cascading.stats.CascadingStats
Method getDuration returns the duration the work executed before being finished.
getEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
getEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
getEdge(FlowElement, FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
getEdge(Process, Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getEdge(Process, Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getEdge(ElementGraph, ElementGraph) - Method in class cascading.flow.planner.rule.util.ResultTree
 
getEdgeAnnotations() - Method in class cascading.flow.planner.process.ProcessEdge
Returns any edge annotations, or an empty immutable Map.
getEdgeMapping(PlannerContext, ElementGraph, Map<ElementExpression, FlowElement>) - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
getEdgeName(E) - Method in interface cascading.util.jgrapht.EdgeNameProvider
 
getEdgeName(E) - Method in class cascading.util.jgrapht.StringEdgeNameProvider
 
getEdgeSource(Scope) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
getEdgeSource(Scope) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
getEdgeSource(Scope) - Method in interface cascading.flow.planner.graph.ElementGraph
 
getEdgeSource(ProcessEdge) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getEdgeSource(ProcessEdge) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getEdgeTarget(Scope) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
getEdgeTarget(Scope) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
getEdgeTarget(Scope) - Method in interface cascading.flow.planner.graph.ElementGraph
 
getEdgeTarget(ProcessEdge) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getEdgeTarget(ProcessEdge) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getEdgeWeight(ProcessEdge) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getEdgeWeight(ProcessEdge) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getElementFactory(String) - Method in class cascading.flow.planner.rule.RuleRegistry
 
getElementFactoryFor(String) - Method in class cascading.flow.planner.PlannerContext
 
getElementGraph() - Method in class cascading.flow.planner.BaseFlowNode
 
getElementGraph() - Method in class cascading.flow.planner.BaseFlowStep
 
getElementGraph() - Method in class cascading.flow.planner.iso.finder.Match
 
getElementGraph() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
getElementGraph() - Method in class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
getElementGraph() - Method in class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
getElementGraph() - Method in interface cascading.flow.planner.iso.subgraph.SubGraphIterator
 
getElementGraph() - Method in exception cascading.flow.planner.PlannerException
Method getElementGraph returns the elementGraph of this PlannerException object.
getElementGraph() - Method in interface cascading.flow.planner.process.ProcessModel
 
getElementGraphs(FlowElement) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getElementGraphs(Scope) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getElementGraphs(FlowElement) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getElementGraphs(Scope) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getElementProcesses(FlowElement) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getElementProcesses(Scope) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getElementProcesses(FlowElement) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getElementProcesses(Scope) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getElementSinkProcesses(FlowElement) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getElementSinkProcesses(FlowElement) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getElementSourceProcesses(FlowElement) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getElementSourceProcesses(FlowElement) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getEndGraph() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getEndGraph() - Method in class cascading.flow.planner.iso.GraphResult
 
getEndGraph() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
getEndGraph() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getEntries() - Method in class cascading.util.MultiMap
 
getEventId() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getExpressionGraph() - Method in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
getExpressionName() - Method in class cascading.flow.planner.rule.RuleExpression
 
getFieldDeclaration() - Method in interface cascading.flow.planner.DeclaresResults
 
getFieldDeclaration() - Method in class cascading.operation.BaseOperation
 
getFieldDeclaration() - Method in interface cascading.operation.Operation
Returns the fields created by this Operation instance.
getFieldDeclaration() - Method in class cascading.pipe.joiner.BaseJoiner
 
getFieldDeclaration() - Method in class cascading.pipe.Operator
Method getFieldDeclaration returns the fieldDeclaration of this Operator object.
getFieldDeclarations() - Method in class cascading.pipe.assembly.AggregateBy
Method getFieldDeclarations returns an array of Fields where each Field element in the array corresponds to the field declaration of the given Aggregator operations.
getFields() - Method in class cascading.tuple.TupleEntry
Method getFields returns the fields of this TupleEntry object.
getFields() - Method in class cascading.tuple.TupleEntryIterator
Method getFields returns the fields of this TupleEntryIterator object.
getFieldsFor(FlowElementGraph, Tap) - Method in class cascading.flow.BaseFlow
 
getFieldsSize() - Method in class cascading.operation.filter.Logic
 
getFilter() - Method in class cascading.operation.filter.Not
 
getFilter() - Method in class cascading.pipe.Each
 
getFilteredPartitionIdentifiers(FlowProcess<? extends Config>, String[]) - Method in class cascading.tap.partition.BasePartitionTap
 
getFilters() - Method in class cascading.operation.filter.Logic
 
getFinishedTime() - Method in class cascading.stats.CascadingStats
Method getFinishedTime returns the finishedTime of this CascadingStats object.
getFirst(Collection<V>) - Static method in class cascading.util.Util
 
getFirst(Iterator<V>) - Static method in class cascading.util.Util
 
getFirstAnchor() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getFirstN() - Method in class cascading.operation.aggregator.First
 
getFirstN() - Method in class cascading.operation.buffer.FirstNBuffer
 
getFirstValue() - Method in class cascading.operation.function.SetValue
 
getFloat(int) - Method in class cascading.tuple.Tuple
Method getFloat returns the element at the given position as a float.
getFloat(Comparable) - Method in class cascading.tuple.TupleEntry
Method getFloat returns the element for the given field name or position as a float.
getFlow() - Method in interface cascading.flow.AssemblyPlanner.Context
 
getFlow() - Method in interface cascading.flow.FlowStep
 
getFlow() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlow() - Method in class cascading.flow.planner.PlannerContext
 
getFlow() - Method in class cascading.stats.FlowStats
 
getFlowCanonicalHash() - Method in class cascading.flow.BaseFlow
The hash value can be used to determine if two unique Flow instances performed the same work.
getFlowCount() - Method in class cascading.stats.CascadeStats
Method getFlowCount returns the number of Flows executed by the Cascade.
getFlowDef() - Method in interface cascading.flow.AssemblyPlanner.Context
 
getFlowDef() - Method in class cascading.flow.planner.PlannerContext
 
getFlowDescriptor() - Method in interface cascading.flow.AssemblyPlanner
Returns a map of properties giving more details about the Flow object.
getFlowDescriptor() - Method in class cascading.flow.BaseFlow
 
getFlowDescriptor() - Method in interface cascading.flow.Flow
Returns an immutable map of properties giving more details about the Flow object.
getFlowDescriptor() - Method in class cascading.flow.FlowDef
Method getFlowDescriptor returns the flowDescriptor of this FlowDef.
getFlowElement() - Method in exception cascading.flow.planner.ElementGraphException
Method getFlowElement returns the flowElement of this ElementGraphException object.
getFlowElement() - Method in class cascading.flow.planner.process.ProcessEdge
 
getFlowElement() - Method in class cascading.flow.stream.element.BoundaryStage
 
getFlowElement() - Method in interface cascading.flow.stream.element.ElementDuct
 
getFlowElement() - Method in class cascading.flow.stream.element.ElementStage
 
getFlowElement() - Method in class cascading.flow.stream.element.SpliceGate
 
getFlowElementForID(Set<FlowElement>, String) - Static method in class cascading.flow.Flows
 
getFlowElementGraphFrom(Flow) - Static method in class cascading.flow.Flows
 
getFlowElementID() - Method in class cascading.flow.planner.process.ProcessEdge
 
getFlowElementsFor(Enum) - Method in interface cascading.flow.FlowNode
 
getFlowElementsFor(Enum) - Method in class cascading.flow.planner.BaseFlowNode
 
getFlowElementsFor(Enum) - Method in class cascading.flow.planner.process.FlowNodeGraph
 
getFlowGraph() - Method in class cascading.cascade.BaseCascade
 
getFlowGraphFrom(Cascade) - Static method in class cascading.cascade.Cascades
 
getFlowID() - Method in interface cascading.flow.FlowStep
 
getFlowID() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlowLogger() - Method in class cascading.flow.planner.rule.RuleSetExec
 
getFlowName() - Method in exception cascading.flow.FlowException
Method getFlowName returns the name of the parent Flow instance.
getFlowName() - Method in interface cascading.flow.FlowStep
Method getParentFlowName returns the parentFlowName of this FlowStep object.
getFlowName() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlowNode() - Method in class cascading.stats.FlowNodeStats
 
getFlowNodeDescriptor() - Method in interface cascading.flow.FlowNode
Returns an immutable map of properties giving more details about the FlowNode object.
getFlowNodeDescriptor() - Method in class cascading.flow.planner.BaseFlowNode
 
getFlowNodeFactory() - Method in class cascading.flow.planner.BaseFlowStepFactory
 
getFlowNodeFactory() - Method in class cascading.flow.planner.FlowPlanner
 
getFlowNodeFactory() - Method in interface cascading.flow.planner.process.FlowStepFactory
 
getFlowNodeGraph() - Method in interface cascading.flow.FlowStep
 
getFlowNodeGraph() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlowNodeIDs() - Method in class cascading.stats.FlowStepStats
 
getFlowNodeStats() - Method in interface cascading.flow.FlowNode
 
getFlowNodeStats() - Method in class cascading.flow.planner.BaseFlowNode
 
getFlowNodeStats() - Method in class cascading.stats.FlowStepStats
 
getFlowNodeStatsMap() - Method in class cascading.stats.FlowStepStats
 
getFlowPlanner() - Method in class cascading.flow.planner.PlannerContext
 
getFlowProcess() - Method in interface cascading.flow.Flow
 
getFlowProcess() - Method in class cascading.flow.process.ProcessFlow
 
getFlowProcess() - Method in class cascading.pipe.joiner.JoinerClosure
 
getFlowProcess() - Method in class cascading.tuple.TupleEntrySchemeCollector
 
getFlowProcess() - Method in class cascading.tuple.TupleEntrySchemeIterator
 
getFlowProperties() - Method in class cascading.stats.FlowStats
 
getFlows() - Method in class cascading.cascade.BaseCascade
 
getFlows() - Method in interface cascading.cascade.Cascade
Method getFlows returns the flows managed by this Cascade object.
getFlows() - Method in class cascading.cascade.CascadeDef
Method getFlows returns the flows of this CascadeDef object.
getFlowsArray() - Method in class cascading.cascade.CascadeDef
Method getFlowsArray returns the flows as an array of this CascadeDef object.
getFlowSession() - Method in class cascading.flow.BaseFlow
 
getFlowSkipStrategy() - Method in class cascading.cascade.BaseCascade
 
getFlowSkipStrategy() - Method in interface cascading.cascade.Cascade
Method getFlowSkipStrategy returns the current FlowSkipStrategy used by this Flow.
getFlowSkipStrategy() - Method in class cascading.flow.BaseFlow
 
getFlowSkipStrategy() - Method in interface cascading.flow.Flow
Method getFlowSkipStrategy returns the current FlowSkipStrategy used by this Flow.
getFlowStats() - Method in class cascading.flow.BaseFlow
 
getFlowStats() - Method in interface cascading.flow.Flow
Method getFlowStats returns the flowStats of this Flow object.
getFlowStep() - Method in interface cascading.flow.FlowNode
 
getFlowStep() - Method in class cascading.flow.planner.BaseFlowNode
 
getFlowStep() - Method in class cascading.stats.FlowStepStats
 
getFlowStepDescriptor() - Method in interface cascading.flow.FlowStep
Returns an immutable map of properties giving more details about the FlowStep object.
getFlowStepDescriptor() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlowStepFactory() - Method in class cascading.flow.planner.FlowPlanner
 
getFlowStepJob() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlowSteps() - Method in class cascading.flow.BaseFlow
 
getFlowSteps() - Method in interface cascading.flow.Flow
Method getFlowSteps returns the flowSteps of this Flow object.
getFlowStepStats() - Method in interface cascading.flow.FlowStep
 
getFlowStepStats() - Method in class cascading.flow.planner.BaseFlowStep
 
getFlowStepStats() - Method in class cascading.stats.FlowStats
Method getStepStats returns the stepStats owned by this FlowStats.
getFlowStepStats() - Method in class cascading.stats.process.ProcessFlowStats
 
getFlowStepStrategy() - Method in class cascading.flow.BaseFlow
 
getFlowStepStrategy() - Method in interface cascading.flow.Flow
Returns the current FlowStepStrategy instance.
getFormat() - Method in class cascading.operation.text.FieldFormatter
Method getFormat returns the format of this FieldFormatter object.
getFoundElements() - Method in class cascading.flow.planner.iso.finder.Match
 
getFraction() - Method in class cascading.operation.filter.Sample
 
getFrameworks() - Method in class cascading.property.AppProps
Method getFrameworks returns a list of frameworks used to build this App.
getFullIdentifier(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
getFullIdentifier(Config) - Method in class cascading.tap.DecoratorTap
 
getFullIdentifier(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method getFullIdentifier returns a fully qualified resource identifier.
getFullIdentifier(Config) - Method in class cascading.tap.Tap
Method getFullIdentifier returns a fully qualified resource identifier.
getFullTransformTracePath(String) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
getFunction() - Method in class cascading.pipe.Each
 
getFunctors() - Method in class cascading.pipe.assembly.AggregateBy
 
getGatherPartitions() - Method in class cascading.flow.FlowRuntimeProps
Method getGatherPartitions returns the number of gather partitions
getGraph() - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
getGraph() - Method in exception cascading.flow.planner.iso.finder.GraphFinderException
 
getGraphAssert() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getGraphPartitioner() - Method in class cascading.flow.planner.rule.RulePartitioner
 
getGraphTransform() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getGroup() - Method in interface cascading.flow.FlowStep
 
getGroup() - Method in class cascading.flow.planner.BaseFlowStep
 
getGroup() - Method in interface cascading.operation.AggregatorCall
Returns the current grouping TupleEntry.
getGroup() - Method in interface cascading.operation.BufferCall
Returns the current grouping TupleEntry.
getGroup() - Method in class cascading.operation.ConcreteCall
 
getGroup() - Method in interface cascading.operation.GroupAssertionCall
Returns the current grouping TupleEntry.
getGroupAssertion() - Method in class cascading.pipe.Every
 
getGroupBy() - Method in class cascading.pipe.assembly.AggregateBy
Method getGroupBy returns the internal GroupBy instance so that any custom properties can be set on it via Pipe.getStepConfigDef().
getGroupFieldSelector() - Method in class cascading.operation.function.UnGroup
 
getGrouping() - Method in interface cascading.tuple.collect.Spillable
 
getGrouping() - Method in class cascading.tuple.collect.SpillableTupleList
 
getGrouping() - Method in class cascading.tuple.collect.SpillableTupleMap
 
getGroupingFields() - Method in class cascading.pipe.assembly.AggregateBy
Method getGroupingFields returns the Fields this instances will be grouping against.
getGroupingSelector() - Method in exception cascading.pipe.OperatorException
Method getGroupingSelector returns the groupingSelector of this OperatorException object.
getGroupNames(Counters) - Method in class cascading.stats.CounterCache
 
getGroups() - Method in class cascading.flow.planner.BaseFlowNode
 
getGroups() - Method in class cascading.flow.planner.BaseFlowStep
 
getGroups() - Method in interface cascading.flow.planner.process.ProcessModel
 
getGroups() - Method in class cascading.operation.regex.RegexParser
 
getGroupString() - Method in class cascading.operation.state.Counter
 
getGroupTuple(Tuple) - Method in class cascading.flow.stream.element.MemoryCoGroupClosure
 
getGroupTuple(Tuple) - Method in class cascading.pipe.joiner.JoinerClosure
 
getHashFunction() - Method in class cascading.tuple.util.TupleHasher
 
getHeadFlows() - Method in class cascading.cascade.BaseCascade
 
getHeadFlows() - Method in interface cascading.cascade.Cascade
Method getHeadFlows returns all Flow instances that are at the "head" of the flow graph.
getHeads() - Method in class cascading.flow.stream.graph.StreamGraph
 
getHeads() - Method in class cascading.pipe.Pipe
Method getHeads returns the first Pipe instances in this pipe assembly.
getHex(byte[]) - Static method in class cascading.util.Util
 
getHolder() - Method in class cascading.flow.BaseFlow
Used to return a simple wrapper for use as an edge in a graph where there can only be one instance of every edge.
getID() - Method in class cascading.cascade.BaseCascade
Method getID returns the ID of this Cascade object.
getID() - Method in class cascading.flow.BaseFlow
 
getID() - Method in interface cascading.flow.Flow
Method getID returns the ID of this Flow object.
getID() - Method in interface cascading.flow.FlowNode
 
getID() - Method in class cascading.flow.FlowProcess
Method getID() returns the current
getID() - Method in class cascading.flow.FlowProcessWrapper
 
getID() - Method in class cascading.flow.FlowSession
Method getID returns the parent Flow ID value.
getID() - Method in interface cascading.flow.FlowStep
Method getId returns the id of this FlowStep object.
getID() - Method in class cascading.flow.planner.BaseFlowNode
 
getID() - Method in class cascading.flow.planner.BaseFlowStep
 
getID() - Method in class cascading.flow.planner.process.ProcessEdge
 
getID() - Method in interface cascading.flow.planner.process.ProcessModel
 
getID() - Method in class cascading.management.state.BaseState
 
getID() - Method in interface cascading.management.UnitOfWork
 
getID() - Method in class cascading.stats.CascadeStats
 
getID() - Method in class cascading.stats.CascadingStats
Method getID returns the ID of this CascadingStats object.
getID() - Method in class cascading.stats.FlowNodeStats
 
getID() - Method in class cascading.stats.FlowSliceStats
 
getID() - Method in class cascading.stats.FlowStats
 
getID() - Method in class cascading.stats.FlowStepStats
 
getIdentifier() - Method in class cascading.tap.DecoratorTap
 
getIdentifier() - Method in class cascading.tap.MultiSinkTap
 
getIdentifier() - Method in class cascading.tap.MultiSourceTap
 
getIdentifier() - Method in class cascading.tap.partition.BasePartitionTap
 
getIdentifier() - Method in class cascading.tap.Tap
Method getIdentifier returns a String representing the resource this Tap instance represents.
getIdentifierGraph() - Method in class cascading.cascade.BaseCascade
 
getIdentityElementGraphs() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getIdentityElementGraphs() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getIdentityElements(ProcessGraph<? extends ProcessModel>) - Method in class cascading.util.DOTProcessGraphWriter
 
getIdentityProcesses() - Method in class cascading.flow.planner.process.BaseProcessGraph
Returns a set of processes that perform no internal operations.
getIdentityProcesses() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getIgnoreTuples() - Method in class cascading.operation.aggregator.ExtentBase
 
getIgnoreValues() - Method in class cascading.operation.aggregator.ExtremaValueBase
 
getIncludedElements() - Method in class cascading.flow.planner.iso.finder.Match
 
getIncomingAggregatorArgumentFields() - Method in class cascading.flow.planner.Scope
 
getIncomingAggregatorPassThroughFields() - Method in class cascading.flow.planner.Scope
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.BufferEveryWindow
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.FilterEachStage
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.FunctionEachStage
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.OperatorStage
 
getIncomingArgumentsFields() - Method in class cascading.flow.stream.element.ValueAssertionEachStage
 
getIncomingBufferArgumentFields() - Method in class cascading.flow.planner.Scope
 
getIncomingBufferPassThroughFields() - Method in class cascading.flow.planner.Scope
 
getIncomingEdge(ElementGraph) - Method in class cascading.flow.planner.rule.util.ResultTree
 
getIncomingEntry() - Method in class cascading.scheme.ConcreteCall
 
getIncomingEntry() - Method in interface cascading.scheme.SourceCall
Method getIncomingEntry returns a pre-prepared TupleEntry to be populated with the input values from SourceCall.getInput().
getIncomingFields() - Method in exception cascading.pipe.OperatorException
Method getIncomingFields returns the incomingFields of this OperatorException object.
getIncomingFunctionArgumentFields() - Method in class cascading.flow.planner.Scope
 
getIncomingFunctionPassThroughFields() - Method in class cascading.flow.planner.Scope
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.BufferEveryWindow
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.FilterEachStage
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.FunctionEachStage
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.OperatorStage
 
getIncomingPassThroughFields() - Method in class cascading.flow.stream.element.ValueAssertionEachStage
 
getIncomingScopes() - Method in class cascading.flow.stream.element.BoundaryStage
 
getIncomingScopes() - Method in interface cascading.flow.stream.element.ElementDuct
 
getIncomingScopes() - Method in class cascading.flow.stream.element.ElementStage
 
getIncomingScopes() - Method in class cascading.flow.stream.element.SpliceGate
 
getIncomingSpliceFields() - Method in class cascading.flow.planner.Scope
 
getIncomingTapFields() - Method in class cascading.flow.planner.Scope
 
getIncrement() - Method in class cascading.operation.state.Counter
 
getIndex() - Method in class cascading.tuple.io.IndexTuple
 
getInitialAssembly() - Method in class cascading.flow.planner.rule.RuleResult
 
getInitListThreshold() - Method in class cascading.tuple.collect.SpillableTupleMap
 
getInput() - Method in class cascading.scheme.ConcreteCall
 
getInput() - Method in interface cascading.scheme.SourceCall
Method getInput returns the input mechanism for the underlying platform used to retrieve new values (records, lines, etc).
getInputStream() - Method in class cascading.tuple.io.TupleInputStream
 
getInstance() - Static method in class cascading.provider.FactoryLoader
 
getInstance(URL, String[]) - Static method in class cascading.provider.ServiceLoader
 
getInt(String[]) - Method in class cascading.management.CascadingServices.NullMetricsService
 
getInt(String[]) - Method in interface cascading.management.MetricsService
 
getInteger(int) - Method in class cascading.tuple.Tuple
Method getInteger returns the element at the given position as an int.
getInteger(Comparable) - Method in class cascading.tuple.TupleEntry
Method getInteger returns the element for the given field name or position as an int.
getIntegerProperty(String) - Method in class cascading.flow.FlowProcess
Method getIntegerProperty should be used to return configuration parameters from the underlying system.
getIntegerProperty(String, int) - Method in class cascading.flow.FlowProcess
Method getIntegerProperty should be used to return configuration parameters from the underlying system.
getIntermediateFlows() - Method in class cascading.cascade.BaseCascade
 
getIntermediateFlows() - Method in interface cascading.cascade.Cascade
Method getIntermediateFlows returns all Flow instances that are neither at the "tail" or "tail" of the flow graph.
getIntermediateSchemeClass(Map<Object, Object>) - Method in class cascading.flow.FlowConnector
Method getIntermediateSchemeClass is used for debugging.
getIntermediateSchemeClassName() - Method in class cascading.flow.FlowConnectorProps
 
getIntermediateTaps() - Method in class cascading.cascade.BaseCascade
 
getIntermediateTaps() - Method in interface cascading.cascade.Cascade
Method getIntermediateTaps returns all Tap instances that are neither at the source or sink of the flow graph.
getIntProperty(String, int) - Method in class cascading.flow.planner.PlannerContext
 
getIntProperty(Map<Object, Object>, String, int) - Static method in class cascading.property.PropertyUtil
 
getIntProperty(Properties, Map<Object, Object>, String, int) - Static method in class cascading.property.PropertyUtil
 
getIntProperty(String, int) - Method in class cascading.stats.CounterCache
 
getIterator(int) - Method in class cascading.flow.stream.element.MemoryCoGroupClosure
 
getIterator(JoinerClosure) - Method in class cascading.pipe.joiner.BufferJoin
 
getIterator(JoinerClosure) - Method in class cascading.pipe.joiner.InnerJoin
 
getIterator(int) - Method in class cascading.pipe.joiner.InnerJoin.JoinIterator
 
getIterator(JoinerClosure) - Method in interface cascading.pipe.joiner.Joiner
Returns an iterator that joins the given CoGroupClosure co-groups.
getIterator(int) - Method in class cascading.pipe.joiner.JoinerClosure
Returns a Tuple Iterator for the given pipe position.
getIterator(JoinerClosure) - Method in class cascading.pipe.joiner.LeftJoin
 
getIterator(JoinerClosure) - Method in class cascading.pipe.joiner.MixedJoin
 
getIterator(JoinerClosure) - Method in class cascading.pipe.joiner.OuterJoin
 
getIterator(int) - Method in class cascading.pipe.joiner.OuterJoin.JoinIterator
 
getIterator(JoinerClosure) - Method in class cascading.pipe.joiner.RightJoin
 
getJobPollingInterval() - Method in class cascading.flow.FlowProps
 
getJobsMap(Flow) - Static method in class cascading.flow.Flows
 
getJobStatusClient() - Method in class cascading.stats.BaseCachedStepStats
Method getRunningJob returns the Hadoop RunningJob managing this Hadoop job.
getJobStatusClient() - Method in class cascading.stats.CounterCache
 
getJoinDeclaredFields() - Method in class cascading.pipe.Splice
 
getJoiner() - Method in class cascading.pipe.Splice
 
getJoinerClosure() - Method in interface cascading.operation.BufferCall
Returns the current instance of a JoinerClosure, if any.
getJoinerClosure() - Method in class cascading.operation.ConcreteCall
 
getJoinFields() - Method in class cascading.pipe.joiner.JoinerClosure
Returns an array of Fields denoting the join fields or keys uses for each incoming pipe.
getKeyComparator() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
getKeys() - Method in class cascading.util.MultiMap
 
getKeySelectors() - Method in class cascading.flow.planner.Scope
Method getGroupingSelectors returns the groupingSelectors of this Scope object.
getKeySelectors() - Method in interface cascading.pipe.Group
 
getKeySelectors() - Method in class cascading.pipe.Splice
Method getGroupingSelectors returns the groupingSelectors of this Splice object.
getKeysFor(V) - Method in class cascading.util.MultiMap
 
getKind() - Method in class cascading.stats.FlowNodeStats
 
getKind() - Method in class cascading.stats.FlowSliceStats
 
getLast(Iterator<V>) - Static method in class cascading.util.Util
 
getLastMatch() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
getLastSuccessfulCounterFetchTime() - Method in class cascading.stats.BaseCachedNodeStats
 
getLastSuccessfulCounterFetchTime() - Method in class cascading.stats.BaseCachedStepStats
 
getLastSuccessfulCounterFetchTime() - Method in class cascading.stats.CascadeStats
 
getLastSuccessfulCounterFetchTime() - Method in class cascading.stats.FlowStats
 
getLastSuccessfulCounterFetchTime() - Method in class cascading.stats.process.ProcessStepStats
 
getLastSuccessfulCounterFetchTime() - Method in interface cascading.stats.ProvidesCounters
Method getLastSuccessfulCounterFetchTime returns the time, in millis, the last moment counters were successfully retrieved.
getLastSuccessfulFetch() - Method in class cascading.stats.CounterCache
 
getLevel() - Method in enum cascading.flow.planner.rule.PlanPhase
 
getLevelResults(ProcessLevel) - Method in class cascading.flow.planner.rule.RuleResult
 
getLhs() - Method in class cascading.tuple.io.TuplePair
Method getLhs returns the lhs of this TuplePair object.
getLhs() - Method in class cascading.util.Pair
 
getLimit() - Method in class cascading.operation.filter.Limit
 
getListSpillThreshold() - Method in class cascading.tuple.collect.SpillableProps
 
getLogger() - Method in class cascading.flow.planner.PlannerContext
 
getLong(String[]) - Method in class cascading.management.CascadingServices.NullMetricsService
 
getLong(String[]) - Method in interface cascading.management.MetricsService
 
getLong(int) - Method in class cascading.tuple.Tuple
Method getLong returns the element at the given position as an long.
getLong(Comparable) - Method in class cascading.tuple.TupleEntry
Method getLong returns the element for the given field name or position as a long.
getMap() - Method in class cascading.util.MultiMap
 
getMapCapacity(FlowProcess, int) - Static method in class cascading.tuple.collect.SpillableTupleMap
 
getMapInitialCapacity() - Method in class cascading.tuple.collect.SpillableProps
 
getMapLoadFactor() - Method in class cascading.tuple.collect.SpillableProps
 
getMapLoadFactor(FlowProcess, float) - Static method in class cascading.tuple.collect.SpillableTupleMap
 
getMapSpillThreshold() - Method in class cascading.tuple.collect.SpillableProps
 
getMapThreshold(FlowProcess, int) - Static method in class cascading.tuple.collect.SpillableTupleMap
 
getMapThreshold() - Method in class cascading.tuple.collect.SpillableTupleMap
 
getMatched() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getMatchedGraph() - Method in class cascading.flow.planner.iso.finder.Match
 
getMatches() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
getMatchExpression() - Method in class cascading.flow.planner.iso.finder.GraphFinder
 
getMatchExpression() - Method in class cascading.flow.planner.rule.RuleExpression
 
getMatchGraph() - Method in class cascading.flow.planner.iso.finder.Match
 
getMaxConcurrentFlows() - Method in class cascading.cascade.CascadeDef
 
getMaxConcurrentFlows() - Method in class cascading.cascade.CascadeProps
 
getMaxConcurrentSteps() - Method in class cascading.flow.FlowProps
 
getMaxNumParallelSteps() - Method in class cascading.flow.BaseFlow
 
getMaxNumParallelSteps() - Method in class cascading.flow.process.ProcessFlow
 
getMessage() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getMessage() - Method in class cascading.operation.assertion.BaseAssertion
 
getMetaInfo() - Method in class cascading.tap.DecoratorTap
 
getMetricsService() - Method in class cascading.management.CascadingServices
 
getMode() - Method in class cascading.flow.planner.iso.expression.PathScopeExpression
 
getMode() - Method in enum cascading.flow.planner.rule.PlanPhase
 
getMode(ConfigDef.Mode) - Method in class cascading.property.ConfigDef
 
getModeSafe(ConfigDef.Mode) - Method in class cascading.property.ConfigDef
 
getModifiedTime(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
getModifiedTime(Config) - Method in class cascading.tap.DecoratorTap
 
getModifiedTime(Config) - Method in class cascading.tap.MultiSinkTap
 
getModifiedTime(Config) - Method in class cascading.tap.MultiSourceTap
Returns the most current modified time.
getModifiedTime(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
getModifiedTime(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method getModifiedTime returns the date this resource was last modified.
getModifiedTime(Config) - Method in class cascading.tap.Tap
Method getModifiedTime returns the date this resource was last modified.
getMultiValues(K) - Method in class cascading.util.MultiMap
 
getName() - Method in class cascading.cascade.BaseCascade.CascadeJob
 
getName() - Method in class cascading.cascade.BaseCascade
Method getName returns the name of this Cascade object.
getName() - Method in class cascading.flow.BaseFlow
 
getName() - Method in interface cascading.flow.Flow
Method getName returns the name of this Flow object.
getName() - Method in interface cascading.flow.FlowStep
Method getName returns the name of this FlowStep object.
getName() - Method in class cascading.flow.planner.BaseFlowNode
 
getName() - Method in class cascading.flow.planner.BaseFlowStep
 
getName() - Method in interface cascading.flow.planner.process.ProcessModel
 
getName() - Method in class cascading.flow.planner.rule.RuleRegistry
 
getName() - Method in class cascading.flow.planner.Scope
Method getName returns the name of this Scope object.
getName() - Method in interface cascading.management.UnitOfWork
 
getName() - Method in class cascading.pipe.Boundary
 
getName() - Method in interface cascading.pipe.Group
 
getName() - Method in class cascading.pipe.Pipe
Get the name of this pipe.
getName() - Method in class cascading.pipe.Splice
 
getName() - Method in class cascading.pipe.SubAssembly
 
getName() - Method in class cascading.property.UnitOfWorkDef
 
getName() - Method in class cascading.stats.CascadingStats
Method getName returns the name of this CascadingStats object.
getNameOrID(Flow) - Static method in class cascading.flow.Flows
 
getNext() - Method in class cascading.flow.stream.duct.Duct
 
getNext() - Method in class cascading.flow.stream.duct.Fork
 
getNextElement() - Method in class cascading.tuple.io.TupleInputStream
 
getNextFlowElement(Scope) - Method in class cascading.flow.planner.BaseFlowStep
 
getNextFor(StreamGraph) - Method in class cascading.flow.stream.duct.Duct
 
getNextScope(FlowElement) - Method in class cascading.flow.planner.BaseFlowStep
Method getNextScope returns the next Scope instance in the graph.
getNextScopes(FlowElement) - Method in interface cascading.flow.FlowNode
 
getNextScopes(FlowElement) - Method in class cascading.flow.planner.BaseFlowNode
 
getNodeConfigDef() - Method in interface cascading.flow.planner.ScopedElement
 
getNodeConfigDef() - Method in class cascading.pipe.Pipe
Returns a ConfigDef instance that allows for process level properties to be set and made available via a resulting FlowProcess instance when the pipe is invoked.
getNodeConfigDef() - Method in class cascading.tap.DecoratorTap
 
getNodeConfigDef() - Method in class cascading.tap.Tap
Returns a ConfigDef instance that allows for process level properties to be set and made available via a resulting FlowProcess instance when the tap is invoked.
getNodeDisplayName(FlowNode, int) - Method in class cascading.flow.planner.BaseFlowStep
 
getNodeIterator(SearchOrder, Graph) - Static method in enum cascading.flow.planner.iso.finder.SearchOrder
 
getNodesCount() - Method in class cascading.stats.FlowStepStats
 
getNodeToPipelineGraphMap() - Method in class cascading.flow.planner.rule.RuleResult
 
getNumArgs() - Method in class cascading.operation.BaseOperation
 
getNumArgs() - Method in interface cascading.operation.Operation
The minimum number of arguments this Operation expects from the calling Each or Every Operator.
getNumChildTaps() - Method in interface cascading.tap.CompositeTap
 
getNumChildTaps() - Method in class cascading.tap.MultiSinkTap
 
getNumChildTaps() - Method in class cascading.tap.MultiSourceTap
 
getNumDeclaredIncomingBranches() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
getNumElements() - Method in class cascading.tuple.io.TupleInputStream
 
getNumFlowNodes() - Method in interface cascading.flow.FlowStep
 
getNumFlowNodes() - Method in class cascading.flow.planner.BaseFlowStep
 
getNumNodes() - Method in class cascading.flow.planner.rule.RuleResult
 
getNumProcessSlices() - Method in class cascading.flow.FlowProcess
Method getNumProcessSlices returns the number of parallel slices or tasks allocated for this process execution.
getNumProcessSlices() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getNumProcessSlices() - Method in class cascading.flow.FlowProcessWrapper
 
getNumRecursions() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getNumSelfJoins() - Method in class cascading.pipe.Splice
 
getNumSinkParts() - Method in class cascading.scheme.Scheme
Method getNumSinkParts returns the numSinkParts of this Scheme object.
getNumSinkParts() - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
getNumSteps() - Method in class cascading.flow.planner.rule.RuleResult
 
getObject(int) - Method in class cascading.tuple.Tuple
Method get returns the element at the given position.
getObject(int) - Method in class cascading.tuple.TupleEntry
Method getObject returns the value in the given position pos.
getObject(int, Type) - Method in class cascading.tuple.TupleEntry
Method getObject returns the value in the given field or position as the requested type.
getObject(Comparable) - Method in class cascading.tuple.TupleEntry
Method getObject returns the value in the given field or position.
getObject(Comparable, Type) - Method in class cascading.tuple.TupleEntry
Method getObject returns the value in the given field or position as the requested type.
getOpenWritesThreshold() - Method in class cascading.tap.partition.BasePartitionTap
Method getOpenWritesThreshold returns the openTapsThreshold of this PartitionTap object.
getOperation() - Method in class cascading.pipe.Operator
Method getOperation returns the operation managed by this Operator object.
getOperationDeclaredFields() - Method in class cascading.flow.planner.Scope
Method getDeclaredFields returns the declaredFields of this Scope object.
getOperationDeclaredFields() - Method in class cascading.flow.stream.element.OperatorStage
 
getOperator() - Method in class cascading.flow.stream.element.EachStage
 
getOperator() - Method in class cascading.flow.stream.element.EveryStage
 
getOperator() - Method in class cascading.flow.stream.element.OperatorStage
 
getOrderComparator() - Method in class cascading.flow.planner.rule.RuleSetExec
 
getOrderedTopologicalIterator(Comparator<Process>) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getOrderedTopologicalIterator() - Method in class cascading.flow.planner.process.FlowNodeGraph
 
getOrderedTopologicalIterator(Comparator<Process>) - Method in interface cascading.flow.planner.process.ProcessGraph
 
getOrdinal() - Method in interface cascading.flow.FlowStep
 
getOrdinal() - Method in class cascading.flow.planner.BaseFlowNode
 
getOrdinal() - Method in class cascading.flow.planner.BaseFlowStep
 
getOrdinal() - Method in interface cascading.flow.planner.process.ProcessModel
 
getOrdinal() - Method in class cascading.flow.planner.Scope
 
getOrdinal() - Method in class cascading.flow.stream.duct.DuctGraph.Ordinal
 
getOrdinal() - Method in class cascading.stats.FlowNodeStats
 
getOrdinalMap(Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
getOrdinals() - Method in class cascading.flow.planner.rule.util.ResultTree.Path
 
getOrdinalTopologicalIterator() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getOrdinalTopologicalIterator() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getOriginal() - Method in class cascading.tap.DecoratorTap
 
getOutgoingEntry() - Method in class cascading.scheme.ConcreteCall
 
getOutgoingEntry() - Method in interface cascading.scheme.SinkCall
Method getOutgoingEntry returns the final TupleEntry to be passed to the SinkCall.getOutput() output handler.
getOutgoingFields() - Method in class cascading.flow.stream.element.ElementStage
 
getOutgoingScopes() - Method in class cascading.flow.stream.element.BoundaryStage
 
getOutgoingScopes() - Method in interface cascading.flow.stream.element.ElementDuct
 
getOutgoingScopes() - Method in class cascading.flow.stream.element.ElementStage
 
getOutgoingScopes() - Method in class cascading.flow.stream.element.SpliceGate
 
getOutgoingSelector() - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
getOutgoingSelector() - Method in class cascading.flow.stream.element.BufferEveryWindow
 
getOutgoingSelector() - Method in class cascading.flow.stream.element.EachStage
 
getOutgoingSelector() - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
getOutgoingSelector() - Method in class cascading.flow.stream.element.OperatorStage
 
getOutGroupingFields() - Method in class cascading.flow.planner.Scope
Method getOutGroupingFields returns the outGroupingFields of this Scope object.
getOutGroupingSelector() - Method in class cascading.flow.planner.Scope
Method getOutGroupingSelector returns the outGroupingSelector of this Scope object.
getOutGroupingValueFields() - Method in class cascading.flow.planner.Scope
 
getOutput() - Method in class cascading.flow.stream.element.SinkStage
 
getOutput() - Method in class cascading.operation.Debug
 
getOutput() - Method in class cascading.scheme.ConcreteCall
 
getOutput() - Method in interface cascading.scheme.SinkCall
 
getOutput() - Method in class cascading.tuple.TupleEntrySchemeCollector
 
getOutputCollector() - Method in interface cascading.operation.AggregatorCall
Returns the TupleEntryCollector used to emit result values.
getOutputCollector() - Method in interface cascading.operation.BufferCall
Returns the TupleEntryCollector used to emit result values.
getOutputCollector() - Method in class cascading.operation.ConcreteCall
 
getOutputCollector() - Method in interface cascading.operation.FunctionCall
Returns the TupleEntryCollector used to emit result values.
getOutputPath() - Method in class cascading.CascadingTestCase
 
getOutputPathElements() - Method in class cascading.CascadingTestCase
 
getOutputSelector() - Method in class cascading.pipe.Operator
Method getOutputSelector returns the outputSelector of this Operator object.
getOutputSelector() - Method in exception cascading.pipe.OperatorException
Method getOutputSelector returns the outputSelector of this OperatorException object.
getOutValuesFields() - Method in class cascading.flow.planner.Scope
Method getOutValuesFields returns the outValuesFields of this Scope object.
getOutValuesSelector() - Method in class cascading.flow.planner.Scope
Method getOutValuesSelector returns the outValuesSelector of this Scope object.
getPairs() - Method in class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
getPairs() - Method in class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
getParent() - Method in class cascading.pipe.Pipe
Returns the enclosing parent Pipe instance, if any.
getParent() - Method in class cascading.tap.partition.BasePartitionTap
Method getParent returns the parent Tap of this PartitionTap object.
getPartition() - Method in class cascading.tap.partition.BasePartitionTap
Method getPartition returns the Partition instance used by this PartitionTap
getPartitionFields() - Method in class cascading.tap.partition.DelimitedPartition
 
getPartitionFields() - Method in interface cascading.tap.partition.Partition
The Fields used to populate the partition.
getPartitionSource() - Method in class cascading.flow.planner.rule.RulePartitioner
 
getPathDepth() - Method in class cascading.tap.partition.DelimitedPartition
 
getPathDepth() - Method in interface cascading.tap.partition.Partition
Returns the directory search depth of the partition.
getPathFor(ElementGraph, ElementGraph) - Method in class cascading.flow.planner.rule.RuleResult
 
getPathFor(ElementGraph) - Method in class cascading.flow.planner.rule.RuleResult
 
getPattern() - Method in class cascading.operation.regex.RegexOperation
Method getPattern returns the pattern of this RegexOperation object.
getPattern() - Method in class cascading.tap.partition.DelimitedPartition
 
getPatternString() - Method in class cascading.operation.assertion.AssertGroupBase
 
getPatternString() - Method in class cascading.operation.regex.RegexOperation
Method getPatternString returns the patternString of this RegexOperation object.
getPayload() - Method in exception cascading.tap.TapException
 
getPendingTime() - Method in class cascading.stats.CascadingStats
Method getPendingTime returns the pendingTime of this CascadingStats object.
getPermittedExceptions() - Method in class cascading.tuple.TupleEntrySchemeIteratorProps
 
getPipelineGraphFor(FlowElement) - Method in interface cascading.flow.FlowNode
 
getPipelineGraphFor(FlowElement) - Method in class cascading.flow.planner.BaseFlowNode
 
getPipelineGraphs() - Method in interface cascading.flow.FlowNode
 
getPipelineGraphs() - Method in class cascading.flow.planner.BaseFlowNode
 
getPipePos() - Method in class cascading.pipe.Splice
 
getPlanComparator() - Method in class cascading.flow.planner.rule.RuleRegistrySet
Returns planner comparator.
getPlanComparator() - Method in class cascading.flow.planner.rule.RuleSetExec
 
getPlannerContext() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getPlannerException() - Method in class cascading.flow.planner.rule.RuleResult
 
getPlannerInfo() - Method in class cascading.flow.BaseFlow
 
getPlannerInfo() - Method in interface cascading.flow.Flow
Returns any meta-data about the planner that created this Flow instance.
getPlannerInfo(String) - Method in class cascading.flow.planner.FlowPlanner
 
getPlannerLevel() - Method in class cascading.pipe.Operator
Method getPlannerLevel returns the plannerLevel of this Operator object.
getPlannerLevelFor(Class<? extends PlannerLevel>) - Method in class cascading.flow.planner.PlannerContext
 
getPlannerTimeoutSec() - Method in class cascading.flow.planner.rule.RuleRegistrySet
Gets planner timeout, in seconds.
getPlanPath() - Method in class cascading.CascadingTestCase
 
getPlanPathElements() - Method in class cascading.CascadingTestCase
 
getPlanStatsPath() - Method in class cascading.flow.planner.rule.util.TraceWriter
 
getPlanTracePath() - Method in class cascading.flow.planner.rule.util.TraceWriter
 
getPlanTransformTracePath() - Method in class cascading.flow.planner.rule.util.TraceWriter
 
getPlatformInfo() - Method in class cascading.flow.BaseFlow
 
getPlatformInfo() - Method in interface cascading.flow.Flow
Returns any meta-data about the underlying platform this Flow instance will run against.
getPlatformInfo() - Method in class cascading.flow.FlowConnector
Method getPlatformInfo returns an instance of PlatformInfo for the underlying platform.
getPlatformInfo() - Method in class cascading.flow.planner.FlowPlanner
 
getPos() - Method in class cascading.tuple.Fields
Method getPos returns the pos array of this Fields object.
getPos(Fields) - Method in class cascading.tuple.Fields
 
getPos(Comparable) - Method in class cascading.tuple.Fields
Method getPos returns the index of the give field value in this Fields instance.
getPos(Fields, Fields) - Method in class cascading.tuple.Tuple
 
getPredecessorFlows(Flow) - Method in class cascading.cascade.BaseCascade
 
getPredecessorFlows(Flow) - Method in interface cascading.cascade.Cascade
Method getPredecessorFlows returns a Collection of all the Flow instances that will be executed before the given Flow instance.
getPrefix() - Method in class cascading.operation.Debug
 
getPrefix() - Method in class cascading.stats.CascadingStats
 
getPrevious() - Method in class cascading.pipe.Pipe
Get all the upstream pipes this pipe is connected to.
getPrevious() - Method in class cascading.pipe.Splice
 
getPrevious() - Method in class cascading.pipe.SubAssembly
 
getPreviousScopes(FlowElement) - Method in interface cascading.flow.FlowNode
 
getPreviousScopes(FlowElement) - Method in class cascading.flow.planner.BaseFlowNode
 
getPreviousScopes(FlowElement) - Method in class cascading.flow.planner.BaseFlowStep
Method getPreviousScopes returns the previous Scope instances.
getPrintFieldsEvery() - Method in class cascading.operation.Debug
Method getPrintFieldsEvery returns the printFieldsEvery interval value of this Debug object.
getPrintTupleEvery() - Method in class cascading.operation.Debug
Method getPrintTupleEvery returns the printTupleEvery interval value of this Debug object.
getPriorName() - Method in class cascading.flow.planner.Scope
 
getProcess() - Method in class cascading.flow.process.ProcessFlow
Method getProcess returns the process of this ProcessFlow object.
getProcessAnnotations() - Method in class cascading.flow.planner.BaseFlowNode
 
getProcessAnnotations() - Method in class cascading.flow.planner.BaseFlowStep
 
getProcessAnnotations() - Method in interface cascading.flow.planner.process.ProcessModel
Method getProcessAnnotations returns an immutable Map of platform specific annotations or meta-data that describe the current model type.
getProcessAttemptID() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getProcessDuration() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getProcessFinishTime() - Method in class cascading.stats.FlowSliceStats
 
getProcessHostname() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getProcessID() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getProcessID() - Method in class cascading.stats.FlowSliceStats
 
getProcessLevels() - Method in class cascading.flow.planner.rule.RuleRegistry
 
getProcessLogger() - Method in class cascading.stats.CascadeStats
 
getProcessLogger() - Method in class cascading.stats.CascadingStats
 
getProcessLogger() - Method in class cascading.stats.FlowNodeStats
 
getProcessLogger() - Method in class cascading.stats.FlowStats
 
getProcessLogger() - Method in class cascading.stats.FlowStepStats
 
getProcessNodeID() - Method in class cascading.stats.FlowSliceStats
 
getProcessPendingTime() - Method in class cascading.stats.FlowSliceStats
 
getProcessProgress() - Method in class cascading.stats.FlowSliceStats
 
getProcessRunTime() - Method in class cascading.stats.FlowSliceStats
 
getProcessSliceID() - Method in class cascading.stats.FlowSliceStats
 
getProcessStartTime() - Method in class cascading.stats.FlowSliceStats
 
getProcessStatus() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getProcessStatus() - Method in class cascading.stats.FlowSliceStats
 
getProcessStatusURL() - Method in class cascading.stats.FlowStepStats
 
getProcessStepID() - Method in class cascading.stats.FlowSliceStats
 
getProcessStepID() - Method in class cascading.stats.FlowStepStats
Method getProcessStepID returns the ID representing the under platform process.
getProcessStepID() - Method in class cascading.stats.process.ProcessStepStats
 
getProcessSubmitTime() - Method in class cascading.stats.FlowSliceStats
 
getProperties() - Method in class cascading.flow.FlowConnector
Method getProperties returns the properties of this FlowConnector object.
getProperty(String) - Method in interface cascading.flow.Flow
Returns the String property associated with the given key from the current Configuration instance.
getProperty(String) - Method in class cascading.flow.FlowProcess
Method getProperty should be used to return configuration parameters from the underlying system.
getProperty(String) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getProperty(String) - Method in class cascading.flow.FlowProcessWrapper
 
getProperty(String) - Method in class cascading.flow.process.ProcessFlow
 
getProperty(String) - Method in class cascading.flow.stream.element.ElementFlowProcess
 
getProperty(String) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
getProperty(String) - Method in class cascading.flow.stream.graph.StreamGraph
 
getProperty(Map<Object, Object>, String) - Static method in class cascading.property.PropertyUtil
 
getProperty(Map<Object, Object>, String, A) - Static method in class cascading.property.PropertyUtil
 
getProperty(Map<Object, Object>, ScopedElement, String) - Static method in class cascading.property.PropertyUtil
 
getProperty(Map<Object, Object>, ConfigDef, String) - Static method in class cascading.property.PropertyUtil
 
getPropertyKeys() - Method in class cascading.flow.FlowProcess
Method getPropertyKeys returns an immutable collection of all available property key values.
getPropertyKeys() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
getPropertyKeys() - Method in class cascading.flow.FlowProcessWrapper
 
getPropertyKeys() - Method in class cascading.flow.stream.element.ElementFlowProcess
 
getQuote() - Method in class cascading.scheme.util.DelimitedParser
 
getRecursions() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getRegistry() - Method in class cascading.flow.planner.rule.RuleResult
 
getRelease() - Static method in class cascading.util.Version
 
getReleaseBuild() - Static method in class cascading.util.Version
 
getReleaseFull() - Static method in class cascading.util.Version
 
getReleaseMajor() - Static method in class cascading.util.Version
 
getReleaseMinor() - Static method in class cascading.util.Version
 
getRemainderPassThroughFields() - Method in class cascading.flow.planner.Scope
Method getRemainderFields returns the remainderFields of this Scope object.
getReplacement() - Method in class cascading.operation.regex.RegexReplace
 
getResolvedKeyFields() - Method in class cascading.flow.planner.process.ProcessEdge
 
getResolvedSortFields() - Method in class cascading.flow.planner.process.ProcessEdge
 
getResolvedValueFields() - Method in class cascading.flow.planner.process.ProcessEdge
 
getResult(AggregatorCall<Pair<Long[], Tuple>>) - Method in class cascading.operation.aggregator.Count
 
getResult(AggregatorCall<Tuple[]>) - Method in class cascading.operation.aggregator.ExtentBase
 
getResult(AggregatorCall<ExtremaValueBase.Context>) - Method in class cascading.operation.aggregator.ExtremaValueBase
 
getResult(AggregatorCall<Pair<Double[], Tuple>>) - Method in class cascading.operation.aggregator.Sum
 
getResultFieldSelectors() - Method in class cascading.operation.function.UnGroup
 
getResultStatus() - Method in class cascading.flow.planner.rule.RuleResult
 
getReversedGraph() - Method in class cascading.flow.stream.graph.StreamGraph
 
getReversedTopologicalOrderIterator() - Method in class cascading.flow.stream.graph.StreamGraph
 
getReverseTopologicalIterator(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
getRhs() - Method in class cascading.tuple.io.TuplePair
Method getRhs returns the rhs of this TuplePair object.
getRhs() - Method in class cascading.util.Pair
 
getRuleName() - Method in class cascading.flow.planner.iso.assertion.Asserted
 
getRuleName() - Method in class cascading.flow.planner.iso.GraphResult
 
getRuleName() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
getRuleName() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getRuleName() - Method in interface cascading.flow.planner.rule.Rule
 
getRuleName() - Method in class cascading.flow.planner.rule.RuleAssert
 
getRuleName() - Method in class cascading.flow.planner.rule.RulePartitioner
 
getRuleName() - Method in class cascading.flow.planner.rule.RuleTransformer
 
getRulePhase() - Method in interface cascading.flow.planner.rule.Rule
 
getRulePhase() - Method in class cascading.flow.planner.rule.RuleAssert
 
getRulePhase() - Method in class cascading.flow.planner.rule.RulePartitioner
 
getRulePhase() - Method in class cascading.flow.planner.rule.RuleTransformer
 
getRuleRegistry() - Method in class cascading.flow.planner.PlannerContext
 
getRuleRegistrySet() - Method in class cascading.flow.FlowConnector
Returns the configured RuleRegistry, or the default for this platform.
getRulesFor(PlanPhase) - Method in class cascading.flow.planner.rule.RuleRegistry
 
getRunID() - Method in class cascading.flow.BaseFlow
 
getRunID() - Method in interface cascading.flow.Flow
Returns the run ID given when this Flow instance was defined in the FlowDef.
getRunID() - Method in class cascading.flow.FlowDef
 
getRunTime() - Method in class cascading.stats.CascadingStats
Method getRunTime returns the runTime of this CascadingStats object.
getScheme() - Method in class cascading.tap.DecoratorTap
 
getScheme() - Method in class cascading.tap.MultiSinkTap
 
getScheme() - Method in class cascading.tap.MultiSourceTap
 
getScheme() - Method in class cascading.tap.Tap
Method getScheme returns the scheme of this Tap object.
getSearchOrder() - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
getSecondValue() - Method in class cascading.operation.function.SetValue
 
getSeed() - Method in class cascading.operation.filter.Sample
 
getSelect() - Method in class cascading.flow.planner.rule.RuleRegistrySet
Returns the result selection type.
getSelectorFields() - Method in exception cascading.tuple.FieldsResolverException
Method getSelectorFields returns the selectorFields of this FieldsResolverException object.
getShort(int) - Method in class cascading.tuple.Tuple
Method getShort returns the element at the given position as an short.
getShort(Comparable) - Method in class cascading.tuple.TupleEntry
Method getShort returns the element for the given field name or position as a short.
getSimpleTypeName(Type) - Static method in class cascading.util.Util
 
getSink(String) - Method in class cascading.flow.BaseFlow
 
getSink() - Method in class cascading.flow.BaseFlow
 
getSink(String) - Method in interface cascading.flow.Flow
 
getSink() - Method in interface cascading.flow.Flow
Method getSink returns the first sink of this Flow object.
getSink() - Method in interface cascading.flow.FlowStep
 
getSink() - Method in class cascading.flow.planner.BaseFlowStep
 
getSink() - Method in class cascading.flow.stream.element.SinkStage
 
getSinkAnnotations() - Method in class cascading.flow.planner.process.ProcessEdge
 
getSinkAsList(Flow) - Static method in class cascading.CascadingTestCase
 
getSinkElementNames() - Method in interface cascading.flow.FlowNode
 
getSinkElementNames() - Method in class cascading.flow.planner.BaseFlowNode
 
getSinkElements(Enum) - Method in interface cascading.flow.FlowNode
 
getSinkElements() - Method in class cascading.flow.planner.BaseFlowNode
 
getSinkElements(Enum) - Method in class cascading.flow.planner.BaseFlowNode
 
getSinkElements() - Method in class cascading.flow.planner.BaseFlowStep
 
getSinkElements() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getSinkElements() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getSinkElements() - Method in interface cascading.flow.planner.process.ProcessModel
 
getSinkExpectedOrdinals() - Method in class cascading.flow.planner.process.ProcessEdge
 
getSinkFields() - Method in class cascading.scheme.Scheme
Method getSinkFields returns the sinkFields of this Scheme object.
getSinkFields() - Method in class cascading.tap.DecoratorTap
 
getSinkFields() - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
getSinkFields() - Method in class cascading.tap.SourceTap
 
getSinkFields() - Method in class cascading.tap.Tap
Method getSinkFields returns the sinkFields of this Tap object.
getSinkMap() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getSinkMode() - Method in class cascading.tap.DecoratorTap
 
getSinkMode() - Method in class cascading.tap.Tap
Method getSinkMode returns the SinkMode }of this Tap object.
getSinkModified() - Method in class cascading.flow.BaseFlow
 
getSinkModified() - Method in interface cascading.flow.Flow
Method getSinkModified returns the youngest modified date of any sink Tap managed by this Flow instance.
getSinkModified(Object, Collection<Tap>) - Static method in class cascading.util.Util
 
getSinkName(Tap) - Method in interface cascading.flow.FlowStep
 
getSinkName(Tap) - Method in class cascading.flow.planner.BaseFlowStep
 
getSinkNames() - Method in class cascading.flow.BaseFlow
 
getSinkNames() - Method in interface cascading.flow.Flow
 
getSinkProcessID() - Method in class cascading.flow.planner.process.ProcessEdge
 
getSinks() - Method in class cascading.flow.BaseFlow
 
getSinks() - Method in interface cascading.flow.Flow
Method getSinks returns the sinks of this Flow object.
getSinks() - Method in class cascading.flow.FlowDef
Method getSinks returns the sinks of this FlowDef object.
getSinks() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getSinksCollection() - Method in class cascading.flow.BaseFlow
 
getSinksCollection() - Method in interface cascading.flow.Flow
Method getSinksCollection returns a Collection of sink Taps for this Flow object.
getSinksCopy() - Method in class cascading.flow.FlowDef
Method getSinksCopy returns a copy of the sink Map.
getSinkTapNames(Tap) - Method in interface cascading.flow.FlowNode
 
getSinkTapNames(Tap) - Method in class cascading.flow.planner.BaseFlowNode
 
getSinkTaps() - Method in class cascading.cascade.BaseCascade
 
getSinkTaps() - Method in interface cascading.cascade.Cascade
Method getSinkTaps returns all sink Tap instances in this Cascade instance.
getSinkTaps() - Method in class cascading.flow.planner.BaseFlowNode
 
getSinkTaps() - Method in class cascading.flow.planner.BaseFlowStep
 
getSinkTaps() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getSinkTaps() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getSinkTaps() - Method in interface cascading.flow.planner.process.ProcessModel
 
getSinkTapsMap() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getSinkTapsMap() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getSinkWith(String) - Method in interface cascading.flow.FlowStep
 
getSinkWith(String) - Method in class cascading.flow.planner.BaseFlowStep
 
getSize() - Method in class cascading.operation.assertion.AssertGroupBase
 
getSize() - Method in class cascading.operation.assertion.AssertGroupSizeEquals
 
getSize() - Method in class cascading.operation.assertion.AssertGroupSizeLessThan
 
getSize() - Method in class cascading.operation.assertion.AssertGroupSizeMoreThan
 
getSize() - Method in class cascading.operation.assertion.AssertSizeEquals
 
getSize() - Method in class cascading.operation.assertion.AssertSizeLessThan
 
getSize() - Method in class cascading.operation.assertion.AssertSizeMoreThan
 
getSize() - Method in class cascading.operation.function.UnGroup
 
getSize(FlowProcess<? extends Config>) - Method in interface cascading.tap.type.FileType
Method getSize returns the size of the file referenced by this tap.
getSize(Config) - Method in interface cascading.tap.type.FileType
Method getSize returns the size of the file referenced by this tap.
getSortingSelector() - Method in exception cascading.pipe.OperatorException
Method getSortingSelector returns the sortingSelector of this OperatorException object.
getSortingSelectors() - Method in class cascading.flow.planner.Scope
Method getSortingSelectors returns the sortingSelectors of this Scope object.
getSortingSelectors() - Method in interface cascading.pipe.Group
 
getSortingSelectors() - Method in class cascading.pipe.Splice
Method getSortingSelectors returns the sortingSelectors of this Splice object.
getSource(String) - Method in class cascading.flow.BaseFlow
 
getSource(String) - Method in interface cascading.flow.Flow
 
getSource() - Method in class cascading.flow.stream.element.SourceStage
 
getSourceAnnotations() - Method in class cascading.flow.planner.process.ProcessEdge
 
getSourceAsList(Flow) - Static method in class cascading.CascadingTestCase
 
getSourceElementNames() - Method in interface cascading.flow.FlowNode
 
getSourceElementNames() - Method in class cascading.flow.planner.BaseFlowNode
 
getSourceElements(Enum) - Method in interface cascading.flow.FlowNode
 
getSourceElements() - Method in class cascading.flow.planner.BaseFlowNode
 
getSourceElements(Enum) - Method in class cascading.flow.planner.BaseFlowNode
 
getSourceElements() - Method in class cascading.flow.planner.BaseFlowStep
 
getSourceElements() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getSourceElements() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getSourceElements() - Method in interface cascading.flow.planner.process.ProcessModel
 
getSourceFields() - Method in class cascading.scheme.Scheme
Method getSourceFields returns the sourceFields of this Scheme object.
getSourceFields() - Method in class cascading.tap.DecoratorTap
 
getSourceFields() - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
getSourceFields() - Method in class cascading.tap.SinkTap
 
getSourceFields() - Method in class cascading.tap.Tap
Method getSourceFields returns the sourceFields of this Tap object.
getSourceFields() - Method in exception cascading.tuple.FieldsResolverException
Method getSourceFields returns the sourceFields of this FieldsResolverException object.
getSourceMap() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getSourceModified(Object, Iterator<Tap>, long) - Static method in class cascading.util.Util
 
getSourceName(Tap) - Method in interface cascading.flow.FlowStep
 
getSourceName(Tap) - Method in class cascading.flow.planner.BaseFlowStep
 
getSourceNames() - Method in class cascading.flow.BaseFlow
 
getSourceNames() - Method in interface cascading.flow.Flow
 
getSourceProcessID() - Method in class cascading.flow.planner.process.ProcessEdge
 
getSourceProvidedOrdinals() - Method in class cascading.flow.planner.process.ProcessEdge
 
getSources() - Method in class cascading.flow.BaseFlow
 
getSources() - Method in interface cascading.flow.Flow
Method getSources returns the sources of this Flow object.
getSources() - Method in class cascading.flow.FlowDef
Method getSources returns the sources of this FlowDef object.
getSources() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getSourcesCollection() - Method in class cascading.flow.BaseFlow
 
getSourcesCollection() - Method in interface cascading.flow.Flow
Method getSourcesCollection returns a Collection of source Taps for this Flow object.
getSourcesCopy() - Method in class cascading.flow.FlowDef
Method getSourcesCopy returns a copy of the sources Map.
getSourceTapNames(Tap) - Method in interface cascading.flow.FlowNode
 
getSourceTapNames(Tap) - Method in class cascading.flow.planner.BaseFlowNode
 
getSourceTaps() - Method in class cascading.cascade.BaseCascade
 
getSourceTaps() - Method in interface cascading.cascade.Cascade
Method getSourceTaps returns all source Tap instances in this Cascade instance.
getSourceTaps() - Method in class cascading.flow.planner.BaseFlowNode
 
getSourceTaps() - Method in class cascading.flow.planner.BaseFlowStep
 
getSourceTaps() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getSourceTaps() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getSourceTaps() - Method in interface cascading.flow.planner.process.ProcessModel
 
getSourceTapsMap() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getSourceTapsMap() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getSourceWith(String) - Method in interface cascading.flow.FlowStep
 
getSourceWith(String) - Method in class cascading.flow.planner.BaseFlowStep
 
getSpanElements(ProcessGraph<? extends ProcessModel>) - Method in class cascading.util.DOTProcessGraphWriter
 
getSpawnStrategy() - Method in class cascading.cascade.BaseCascade
 
getSpawnStrategy() - Method in class cascading.flow.BaseFlow
 
getSpawnStrategy() - Method in interface cascading.management.UnitOfWork
 
getSpillListener() - Method in class cascading.tuple.collect.SpillableTupleMap
 
getSpillReason(Spillable) - Method in interface cascading.tuple.collect.Spillable.SpillStrategy
 
getSplice() - Method in class cascading.flow.stream.element.SpliceGate
 
getStackTraceLineDelimiter() - Method in class cascading.tap.TrapProps
 
getStartTime() - Method in class cascading.stats.CascadingStats
Method getStartTime returns the startTime of this CascadingStats object.
getStats() - Method in class cascading.cascade.BaseCascade
 
getStats() - Method in class cascading.flow.BaseFlow
 
getStats() - Method in interface cascading.management.UnitOfWork
 
getStatsString() - Method in class cascading.stats.CascadingStats
 
getStatsString() - Method in class cascading.stats.FlowStats
 
getStatus() - Method in class cascading.operation.state.Status
 
getStatus() - Method in class cascading.stats.CascadingStats
Method getStatus returns the CascadingStats.Status of this CascadingStats object.
getStatus() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getStatus() - Method in class cascading.stats.FlowSliceStats
 
getStatusURL() - Method in class cascading.stats.FlowSliceStats.FlowSliceAttempt
 
getStepConfigDef() - Method in interface cascading.flow.planner.ScopedElement
 
getStepConfigDef() - Method in class cascading.pipe.Pipe
Returns a ConfigDef instance that allows for process level properties to be set and made available via a resulting FlowProcess instance when the pipe is invoked.
getStepConfigDef() - Method in class cascading.tap.DecoratorTap
 
getStepConfigDef() - Method in class cascading.tap.Tap
Returns a ConfigDef instance that allows for process level properties to be set and made available via a resulting FlowProcess instance when the tap is invoked.
getStepDisplayName() - Method in interface cascading.flow.FlowStep
Method getStepDisplayName returns the stepDisplayName of this FlowStep object.
getStepDisplayName() - Method in class cascading.flow.planner.BaseFlowStep
 
getStepDisplayName(int) - Method in class cascading.flow.planner.BaseFlowStep
 
getStepGraphFrom(Flow) - Static method in class cascading.flow.Flows
 
getStepsCount() - Method in class cascading.stats.FlowStats
Method getStepsCount returns the number of steps this Flow executed.
getStepsCount() - Method in class cascading.stats.process.ProcessFlowStats
 
getStepStats() - Method in class cascading.flow.planner.FlowStepJob
Method getStepStats returns the stepStats of this FlowStepJob object.
getStepToNodeGraphMap() - Method in class cascading.flow.planner.rule.RuleResult
 
getString(String[]) - Method in class cascading.management.CascadingServices.NullMetricsService
 
getString(String[]) - Method in interface cascading.management.MetricsService
 
getString(int) - Method in class cascading.tuple.Tuple
Method getString returns the element at the given position as a String.
getString(Comparable) - Method in class cascading.tuple.TupleEntry
Method getString returns the element for the given field name or position as a String.
getStringProperty(String) - Method in class cascading.flow.FlowProcess
Method getStringProperty should be used to return configuration parameters from the underlying system.
getStringProperty(String, String) - Method in class cascading.flow.FlowProcess
Method getStringProperty should be used to return configuration parameters from the underlying system.
getStringProperty(String) - Method in class cascading.flow.planner.PlannerContext
 
getStringProperty(Map<Object, Object>, String) - Static method in class cascading.property.PropertyUtil
 
getStringProperty(Properties, Map<Object, Object>, String) - Static method in class cascading.property.PropertyUtil
 
getSubGraphs() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
getSubmitPriority() - Method in class cascading.flow.BaseFlow
 
getSubmitPriority() - Method in interface cascading.flow.Flow
Method getSubmitPriority returns the submitPriority of this Flow object.
getSubmitPriority() - Method in interface cascading.flow.FlowStep
Method getSubmitPriority returns the submitPriority of this FlowStep object.
getSubmitPriority() - Method in class cascading.flow.planner.BaseFlowNode
 
getSubmitPriority() - Method in class cascading.flow.planner.BaseFlowStep
 
getSubmitPriority() - Method in interface cascading.flow.planner.process.ProcessModel
 
getSubmitTime() - Method in class cascading.stats.CascadingStats
Method getSubmitTime returns the submitTime of this CascadingStats object.
getSuccessorFlows(Flow) - Method in class cascading.cascade.BaseCascade
 
getSuccessorFlows(Flow) - Method in interface cascading.cascade.Cascade
Method getSuccessorFlows returns a Collection of all the Flow instances that will be executed after the given Flow instance.
getTags() - Method in class cascading.cascade.BaseCascade
Method getTags returns the tags associated with this Cascade object.
getTags() - Method in class cascading.flow.BaseFlow
 
getTags() - Method in interface cascading.flow.Flow
 
getTags() - Method in interface cascading.management.UnitOfWork
 
getTags() - Method in class cascading.property.AppProps
 
getTags() - Method in class cascading.property.UnitOfWorkDef
 
getTailFlows() - Method in class cascading.cascade.BaseCascade
 
getTailFlows() - Method in interface cascading.cascade.Cascade
Method getTailFlows returns all Flow instances that are at the "tail" of the flow graph.
getTailNames() - Method in class cascading.pipe.SubAssembly
Method getTailNames returns the tailNames of this SubAssembly object.
getTails() - Method in interface cascading.flow.AssemblyPlanner.Context
 
getTails() - Method in class cascading.flow.FlowDef
Method getTails returns all the current pipe assembly tails the FlowDef holds.
getTails() - Method in class cascading.flow.stream.graph.StreamGraph
 
getTails() - Method in class cascading.pipe.SubAssembly
Method getTails returns all the tails of this SubAssembly object.
getTailsArray() - Method in class cascading.flow.FlowDef
Method getTailsArray returns all the current pipe assembly tails the FlowDef holds.
getTapForID(Set<Tap>, String) - Static method in class cascading.flow.Flows
 
getTapGraph() - Method in class cascading.cascade.BaseCascade
 
getTapGraphFrom(Cascade) - Static method in class cascading.cascade.Cascades
 
getTaps() - Method in class cascading.tap.MultiSinkTap
 
getTaps() - Method in class cascading.tap.MultiSourceTap
Method getTaps returns the taps of this MultiTap object.
getTemporaryTapDecoratorClassName() - Method in class cascading.flow.FlowConnectorProps
 
getTestCaseName() - Method in class cascading.CascadingTestCase
 
getTestName() - Method in class cascading.CascadingTestCase
 
getTestOutputRoot() - Static method in class cascading.CascadingTestCase
 
getTestPlanRoot() - Static method in class cascading.CascadingTestCase
 
getThreshold(FlowProcess, int) - Static method in class cascading.tuple.collect.SpillableTupleList
 
getThrowable() - Method in class cascading.flow.planner.FlowStepJob
 
getThrowable() - Method in class cascading.stats.CascadingStats
Method getThrowable returns the throwable of this CascadingStats object.
getThrowableTrace() - Method in class cascading.stats.CascadingStats
Method getThrowableTrace returns the throwableTrace of this CascadingStats object.
getTopologicalIterator() - Method in class cascading.cascade.planner.FlowGraph
 
getTopologicalIterator(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
getTopologicalIterator() - Method in class cascading.flow.planner.graph.FlowElementGraph
Method getTopologicalIterator returns the topologicalIterator of this ElementGraph object.
getTopologicalIterator() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getTopologicalIterator() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getTopologicalOrderIterator() - Method in class cascading.flow.stream.graph.StreamGraph
 
getTotalSliceCPUMilliSeconds() - Method in class cascading.flow.BaseFlow
 
getTrace() - Method in class cascading.operation.BaseOperation
 
getTrace() - Method in class cascading.pipe.Pipe
 
getTrace() - Method in class cascading.scheme.Scheme
 
getTrace() - Method in class cascading.tap.DecoratorTap
 
getTrace() - Method in class cascading.tap.Tap
 
getTrace() - Method in interface cascading.util.Traceable
Method getTrace returns a String that pinpoints the caller that created this instance.
getTransformerName() - Method in class cascading.flow.planner.iso.transformer.Transformed
 
getTrap(String) - Method in interface cascading.flow.FlowNode
 
getTrap(String) - Method in interface cascading.flow.FlowStep
 
getTrap(String) - Method in class cascading.flow.planner.BaseFlowNode
 
getTrap(String) - Method in class cascading.flow.planner.BaseFlowStep
 
getTrapCollectorFor(Tap) - Method in class cascading.flow.FlowProcess
Method getTrapCollectorFor will return a new TupleEntryCollector if one hasn't previously been created for the given trap Tap.
getTrapCollectorFor(Tap) - Method in class cascading.flow.FlowProcessWrapper
 
getTrapCollectors() - Method in class cascading.flow.FlowProcess
 
getTrapMap() - Method in class cascading.flow.planner.BaseFlowNode
 
getTrapMap() - Method in class cascading.flow.planner.BaseFlowStep
 
getTrapMap() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getTrapMap() - Method in interface cascading.flow.planner.process.ProcessModel
 
getTrapNames() - Method in class cascading.flow.BaseFlow
 
getTrapNames() - Method in interface cascading.flow.Flow
 
getTraps() - Method in class cascading.flow.BaseFlow
 
getTraps() - Method in interface cascading.flow.Flow
Method getTraps returns the traps of this Flow object.
getTraps() - Method in class cascading.flow.FlowDef
Method getTraps returns the traps of this FlowDef object.
getTraps() - Method in interface cascading.flow.FlowNode
 
getTraps() - Method in interface cascading.flow.FlowStep
 
getTraps() - Method in class cascading.flow.planner.BaseFlowNode
 
getTraps() - Method in class cascading.flow.planner.BaseFlowStep
 
getTraps() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
getTrapsCollection() - Method in class cascading.flow.BaseFlow
 
getTrapsCollection() - Method in interface cascading.flow.Flow
Method getTrapsCollection returns a Collection of trap Taps for this Flow object.
getTrapsCopy() - Method in class cascading.flow.FlowDef
Method getTrapsCopy returns a copy of the trap Map.
getTrapsMap() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
getTrapsMap() - Method in interface cascading.flow.planner.process.ProcessGraph
 
getTuple() - Method in class cascading.tuple.io.IndexTuple
 
getTuple() - Method in class cascading.tuple.TupleEntry
Method getTuple returns the tuple of this TupleEntry object.
getTupleCopy() - Method in class cascading.tuple.TupleEntry
Method getTupleCopy returns a copy of the tuple of this TupleEntry object.
getTupleEntry() - Method in class cascading.tuple.TupleEntryIterator
Method getTupleEntry returns the entry of this TupleEntryIterator object.
getType(FlowElement) - Method in class cascading.flow.planner.iso.expression.OperationExpression
 
getType(FlowElement) - Method in class cascading.flow.planner.iso.expression.TypeExpression
 
getType() - Method in class cascading.operation.aggregator.Sum
 
getType() - Method in class cascading.stats.CascadeStats
 
getType() - Method in class cascading.stats.CascadingStats
 
getType() - Method in class cascading.stats.FlowNodeStats
 
getType() - Method in class cascading.stats.FlowStats
 
getType() - Method in class cascading.stats.FlowStepStats
 
getType(Comparable) - Method in class cascading.tuple.Fields
Returns the Type at the given position or having the fieldName.
getType(int) - Method in class cascading.tuple.Fields
 
getTypeClass(Comparable) - Method in class cascading.tuple.Fields
Returns the Class for the given position value.
getTypeClass(int) - Method in class cascading.tuple.Fields
 
getTypeName(Type) - Static method in class cascading.util.Util
 
getTypeNames(Type[]) - Static method in class cascading.tuple.coerce.Coercions
 
getTypes() - Method in class cascading.operation.Identity
 
getTypes(String[]) - Static method in class cascading.tuple.coerce.Coercions
 
getTypes() - Method in class cascading.tuple.Fields
Returns a copy of the current types Type[] if any, else null.
getTypes() - Method in class cascading.tuple.Tuple
Method getTypes returns an array of the element classes.
getTypesClasses() - Method in class cascading.tuple.Fields
Returns a copy of the current types Class[] if any, else null.
getValue() - Method in class cascading.operation.assertion.AssertEqualsAll
 
getValueAssertion() - Method in class cascading.pipe.Each
 
getValueFields() - Method in class cascading.pipe.joiner.JoinerClosure
Returns an array of all the incoming fields for each incoming pipe.
getValues() - Method in class cascading.operation.assertion.AssertEquals
 
getValues() - Method in class cascading.operation.assertion.AssertNotEquals
 
getValues() - Method in class cascading.operation.Insert
 
getValues() - Method in class cascading.util.MultiMap
 
getValues(K) - Method in class cascading.util.MultiMap
 
getVersionString() - Static method in class cascading.util.Version
 
getVertex(Flow, Tap) - Method in class cascading.cascade.planner.IdentifierGraph
 
getVertex(Flow, Tap) - Method in class cascading.cascade.planner.TapGraph
 
getVertex(Flow, Tap) - Method in class cascading.cascade.planner.TopologyGraph
 
getVertexMapping() - Method in class cascading.flow.planner.iso.finder.Match
 
getVertexName(V) - Method in class cascading.util.jgrapht.IntegerNameProvider
 
getVertexName(V) - Method in class cascading.util.jgrapht.StringNameProvider
 
getVertexName(V) - Method in interface cascading.util.jgrapht.VertexNameProvider
 
getWriterFor(Class) - Method in class cascading.tuple.io.TupleOutputStream
 
graph - Variable in class cascading.flow.planner.graph.BaseElementGraph
 
GraphAssert<E extends ElementGraph> - Class in cascading.flow.planner.iso.assertion
TODO: add level for warning or error, and fail on errors
GraphAssert(ExpressionGraph, String) - Constructor for class cascading.flow.planner.iso.assertion.GraphAssert
 
GraphAssert(ExpressionGraph, String, GraphAssert.AssertionType) - Constructor for class cascading.flow.planner.iso.assertion.GraphAssert
 
GraphAssert.AssertionType - Enum in cascading.flow.planner.iso.assertion
 
GraphFinder - Class in cascading.flow.planner.iso.finder
 
GraphFinder(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.finder.GraphFinder
 
GraphFinderException - Exception in cascading.flow.planner.iso.finder
 
GraphFinderException() - Constructor for exception cascading.flow.planner.iso.finder.GraphFinderException
 
GraphFinderException(String) - Constructor for exception cascading.flow.planner.iso.finder.GraphFinderException
 
GraphFinderException(String, Throwable) - Constructor for exception cascading.flow.planner.iso.finder.GraphFinderException
 
GraphFinderException(Throwable) - Constructor for exception cascading.flow.planner.iso.finder.GraphFinderException
 
GraphFinderException(String, DirectedGraph) - Constructor for exception cascading.flow.planner.iso.finder.GraphFinderException
 
GraphPartitioner - Class in cascading.flow.planner.iso.subgraph
 
GraphPartitioner() - Constructor for class cascading.flow.planner.iso.subgraph.GraphPartitioner
 
graphPartitioner - Variable in class cascading.flow.planner.rule.RulePartitioner
 
GraphResult<R extends ElementGraph> - Class in cascading.flow.planner.iso
 
GraphResult() - Constructor for class cascading.flow.planner.iso.GraphResult
 
graphTransformer - Variable in class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
GraphTransformer<In extends ElementGraph,Out extends ElementGraph> - Class in cascading.flow.planner.iso.transformer
 
GraphTransformer() - Constructor for class cascading.flow.planner.iso.transformer.GraphTransformer
 
graphTransformer - Variable in class cascading.flow.planner.iso.transformer.MutateGraphTransformer
 
graphTransformer - Variable in class cascading.flow.planner.rule.RuleTransformer
 
GREEN - Static variable in class cascading.flow.planner.rule.util.TraceWriter
 
Group - Interface in cascading.pipe
 
GROUP - Static variable in class cascading.tuple.Fields
Field KEYS represents all fields used as they key for the last grouping
GroupAssertion<C> - Interface in cascading.operation
Class GroupAssertion is a kind of Assertion used with the Every pipe Operator.
GroupAssertionCall<C> - Interface in cascading.operation
Interface GroupAssertionCall provides access to the current GroupAssertion invocation arguments.
GroupAssertionEveryStage - Class in cascading.flow.stream.element
 
GroupAssertionEveryStage(FlowProcess, Every) - Constructor for class cascading.flow.stream.element.GroupAssertionEveryStage
 
GroupBy - Class in cascading.pipe
The GroupBy pipe groups the Tuple stream by the given groupFields.
GroupBy(Pipe) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on Fields.ALL fields.
GroupBy(Pipe, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names.
GroupBy(Pipe, Fields, boolean) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names.
GroupBy(String, Pipe, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names.
GroupBy(String, Pipe, Fields, boolean) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names.
GroupBy(Pipe, Fields, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(String, Pipe, Fields, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(Pipe, Fields, Fields, boolean) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(String, Pipe, Fields, Fields, boolean) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(Pipe[]) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on Fields.FIRST.
GroupBy(Pipe[], Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names.
GroupBy(Pipe, Pipe, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names.
GroupBy(String, Pipe[], Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names.
GroupBy(String, Pipe, Pipe, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names.
GroupBy(Pipe[], Fields, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(String, Pipe[], Fields, Fields) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(Pipe[], Fields, Fields, boolean) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
GroupBy(String, Pipe[], Fields, Fields, boolean) - Constructor for class cascading.pipe.GroupBy
Creates a new GroupBy instance that will first merge the given pipes, then group on the given groupFields field names and sorts the grouped values on the given sortFields fields names.
groupComparators - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
groupHasher - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
Grouping<Group,ItemIterator extends Iterator> - Class in cascading.flow.stream.duct
 
Grouping() - Constructor for class cascading.flow.stream.duct.Grouping
 
grouping - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
GroupingSpliceGate - Class in cascading.flow.stream.element
 
GroupingSpliceGate(FlowProcess, Splice) - Constructor for class cascading.flow.stream.element.GroupingSpliceGate
 
GroupingSpliceGate(FlowProcess, Splice, IORole) - Constructor for class cascading.flow.stream.element.GroupingSpliceGate
 
GroupingSpliceGate.DelegatedTuple - Class in cascading.flow.stream.element
 
GroupingSpliceGate.DelegatedTuple(Tuple) - Constructor for class cascading.flow.stream.element.GroupingSpliceGate.DelegatedTuple
 
GroupOrMergeElementExpression - Class in cascading.flow.planner.rule.elementexpression
 
GroupOrMergeElementExpression() - Constructor for class cascading.flow.planner.rule.elementexpression.GroupOrMergeElementExpression
 
GroupOrMergeElementExpression(TypeExpression.Topo) - Constructor for class cascading.flow.planner.rule.elementexpression.GroupOrMergeElementExpression
 
GroupOrMergeElementExpression(ElementCapture) - Constructor for class cascading.flow.planner.rule.elementexpression.GroupOrMergeElementExpression
 
GroupOrMergeElementExpression(ElementCapture, TypeExpression.Topo) - Constructor for class cascading.flow.planner.rule.elementexpression.GroupOrMergeElementExpression
 
groupSortTuple - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
GroupTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
GroupTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.GroupTapExpressionGraph
 
groupTuple - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 

H

hadKey(K, V) - Method in class cascading.util.MultiMap
 
handleDuct(FlowElement, Duct) - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
handleException(Throwable, TupleEntry) - Method in class cascading.flow.stream.element.BoundaryStage
 
handleException(Throwable, TupleEntry) - Method in class cascading.flow.stream.element.ElementStage
 
handleException(Throwable, TupleEntry) - Method in class cascading.flow.stream.element.SpliceGate
 
handleException(Throwable, TupleEntry) - Method in class cascading.flow.stream.element.TrapHandler
 
handleException(String, Tap, Throwable, TupleEntry) - Method in class cascading.flow.stream.element.TrapHandler
 
handleExceptionDuringPlanning(FlowDef, Exception, FlowElementGraph) - Method in class cascading.flow.planner.FlowPlanner
 
handleExecutorShutdown() - Method in class cascading.flow.BaseFlow
 
handleReThrowableException(String, Throwable) - Method in class cascading.flow.stream.element.BoundaryStage
 
handleReThrowableException(String, Throwable) - Method in class cascading.flow.stream.element.ElementStage
 
handleReThrowableException(String, Throwable) - Method in class cascading.flow.stream.element.SpliceGate
 
handleReThrowableException(String, Throwable) - Method in class cascading.flow.stream.element.TrapHandler
 
HAS_DOT_EXEC - Static variable in class cascading.util.Util
 
hasAllVersionInfo() - Static method in class cascading.util.Version
 
hasAnnotations() - Method in class cascading.flow.planner.graph.AnnotatedDecoratedElementGraph
 
hasAnnotations() - Method in interface cascading.flow.planner.graph.AnnotatedGraph
 
hasAnnotations() - Method in class cascading.flow.planner.graph.BaseAnnotatedElementGraph
 
hasCapturedFinalDetail - Variable in class cascading.stats.FlowNodeStats
 
hasCapturedFinalDetail() - Method in class cascading.stats.FlowNodeStats
 
hasCapturedFinalDetail() - Method in class cascading.stats.FlowStepStats
 
hasClass(String) - Static method in class cascading.util.Util
 
hasComparators() - Method in class cascading.tuple.Fields
Method hasComparators test if this Fields instance has Comparators.
hasConfigDef() - Method in interface cascading.flow.planner.ScopedElement
 
hasConfigDef() - Method in class cascading.pipe.Pipe
Returns true if there are properties in the configDef instance.
hasConfigDef() - Method in class cascading.tap.DecoratorTap
 
hasConfigDef() - Method in class cascading.tap.Tap
Returns true if there are properties in the configDef instance.
hasContractedMatches() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
hasElementFactory(String) - Method in class cascading.flow.planner.rule.RuleRegistry
 
hash(Tuple, Hasher[]) - Method in class cascading.tuple.util.TupleHasher.HashFunction
 
hashCode() - Method in class cascading.flow.planner.BaseFlowNode
 
hashCode() - Method in class cascading.flow.planner.BaseFlowStep
 
hashCode() - Method in class cascading.flow.planner.graph.AnnotatedDecoratedElementGraph
 
hashCode() - Method in class cascading.flow.planner.graph.BaseAnnotatedElementGraph
 
hashCode() - Method in class cascading.flow.planner.graph.BaseElementGraph
 
hashCode() - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
hashCode() - Method in class cascading.flow.planner.graph.IgnoresAnnotationsElementGraph
 
hashCode() - Method in class cascading.flow.planner.PlannerInfo
 
hashCode() - Method in class cascading.flow.planner.PlatformInfo
 
hashCode() - Method in class cascading.flow.planner.rule.RuleRegistry
 
hashCode() - Method in class cascading.flow.planner.rule.util.ResultTree.Delegate
 
hashCode() - Method in class cascading.flow.stream.duct.DuctGraph.Ordinal
 
hashCode() - Method in class cascading.flow.stream.element.ElementStage
 
hashCode() - Method in class cascading.flow.stream.element.GroupingSpliceGate.DelegatedTuple
 
hashCode() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
hashCode() - Method in class cascading.operation.aggregator.ExtentBase
 
hashCode() - Method in class cascading.operation.aggregator.ExtremaValueBase
 
hashCode() - Method in class cascading.operation.aggregator.Sum
 
hashCode() - Method in class cascading.operation.assertion.AssertEquals
 
hashCode() - Method in class cascading.operation.assertion.AssertEqualsAll
 
hashCode() - Method in class cascading.operation.assertion.AssertGroupBase
 
hashCode() - Method in class cascading.operation.assertion.AssertNotEquals
 
hashCode() - Method in class cascading.operation.assertion.AssertSizeEquals
 
hashCode() - Method in class cascading.operation.assertion.AssertSizeLessThan
 
hashCode() - Method in class cascading.operation.assertion.AssertSizeMoreThan
 
hashCode() - Method in class cascading.operation.assertion.BaseAssertion
 
hashCode() - Method in class cascading.operation.BaseOperation
 
hashCode() - Method in class cascading.operation.Debug
 
hashCode() - Method in class cascading.operation.filter.Limit
 
hashCode() - Method in class cascading.operation.filter.Logic
 
hashCode() - Method in class cascading.operation.filter.Not
 
hashCode() - Method in class cascading.operation.filter.Sample
 
hashCode() - Method in class cascading.operation.function.SetValue
 
hashCode() - Method in class cascading.operation.function.UnGroup
 
hashCode() - Method in class cascading.operation.Identity
 
hashCode() - Method in class cascading.operation.Insert
 
hashCode() - Method in class cascading.operation.regex.RegexFilter
 
hashCode() - Method in class cascading.operation.regex.RegexMatcher
 
hashCode() - Method in class cascading.operation.regex.RegexOperation
 
hashCode() - Method in class cascading.operation.regex.RegexParser
 
hashCode() - Method in class cascading.operation.regex.RegexReplace
 
hashCode() - Method in class cascading.operation.state.Counter
 
hashCode() - Method in class cascading.operation.state.Status
 
hashCode() - Method in class cascading.operation.text.DateOperation
 
hashCode() - Method in class cascading.operation.text.DateParser
 
hashCode() - Method in class cascading.operation.text.FieldFormatter
 
hashCode() - Method in class cascading.operation.text.FieldJoiner
 
hashCode() - Method in class cascading.pipe.assembly.AggregateBy.CompositeFunction
 
hashCode() - Method in class cascading.pipe.assembly.Unique.FilterPartialDuplicates
 
hashCode() - Method in class cascading.pipe.Operator
 
hashCode() - Method in class cascading.pipe.Pipe
 
hashCode() - Method in class cascading.pipe.Splice
 
hashCode() - Method in class cascading.scheme.Scheme
 
hashCode() - Method in class cascading.stats.FlowStats
 
hashCode() - Method in class cascading.tap.MultiSinkTap
 
hashCode() - Method in class cascading.tap.MultiSourceTap
 
hashCode() - Method in class cascading.tap.partition.BasePartitionTap
 
hashCode() - Method in class cascading.tap.Tap
 
hashCode() - Method in class cascading.tuple.coerce.Coercions.Coerce
 
hashCode() - Method in class cascading.tuple.Fields
 
hashCode(V) - Method in interface cascading.tuple.Hasher
Return the hashCode of the given value.
hashCode() - Method in class cascading.tuple.io.IndexTuple
 
hashCode() - Method in class cascading.tuple.io.TuplePair
 
hashCode() - Method in class cascading.tuple.Tuple
 
hashCode() - Method in class cascading.tuple.TupleEntry
 
hashCode(Tuple) - Method in class cascading.tuple.util.TupleHasher
 
hashCode() - Method in class cascading.util.MultiMap
 
hashCode() - Method in class cascading.util.Pair
 
hashCodeIgnoreAnnotations(ElementGraph) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
hashCodeIgnoreAnnotations(Graph<V, E>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
Hasher<V> - Interface in cascading.tuple
The Hasher allows a Comparator implementation to also be delegated to during hashCode generation during grouping partitioning.
hashFunction - Variable in class cascading.tuple.util.TupleHasher
 
hashInt(int) - Static method in class cascading.util.Murmur3
Applies murmur3 to the given input.
HashJoin - Class in cascading.pipe
The HashJoin pipe allows for two or more tuple streams to join into a single stream via a Joiner when all but one tuple stream is considered small enough to fit into memory.
HashJoin(String, Pipe, Fields, Pipe, Fields) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe, Fields, Pipe, Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe, Fields, Pipe, Fields, Fields) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe, Fields, Pipe, Fields, Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe, Fields, int, Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe, Fields, int, Fields) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe, Fields, int, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(String, Pipe[], Fields[], Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, Pipe, Fields) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, Pipe, Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, Pipe, Fields, Fields) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, Pipe, Fields, Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, int, Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, int, Fields) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe, Fields, int, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new HashJoin instance.
HashJoin(Pipe[], Fields[], Fields, Joiner) - Constructor for class cascading.pipe.HashJoin
Constructor HashJoin creates a new Join instance.
HashJoinBlockingHashJoinAnnotator - Class in cascading.flow.planner.rule.annotator
 
HashJoinBlockingHashJoinAnnotator() - Constructor for class cascading.flow.planner.rule.annotator.HashJoinBlockingHashJoinAnnotator
 
hasInstanceMethod(Object, String, Class[]) - Static method in class cascading.util.Util
 
hasKey(V) - Method in class cascading.util.MultiMap
 
hasListeners() - Method in class cascading.cascade.BaseCascade
 
hasListeners() - Method in interface cascading.cascade.Cascade
 
hasListeners() - Method in class cascading.flow.BaseFlow
 
hasListeners() - Method in interface cascading.flow.Flow
Method hasListeners returns true if FlowListener instances have been registered.
hasListeners() - Method in interface cascading.flow.FlowStep
Method hasListeners returns true if FlowStepListener instances have been registered.
hasListeners() - Method in class cascading.flow.planner.BaseFlowStep
 
hasMajorMinorVersionInfo() - Static method in class cascading.util.Version
 
hasNext() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
hasNext() - Method in class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
hasNext() - Method in class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
hasNext() - Method in class cascading.pipe.joiner.InnerJoin.JoinIterator
 
hasNext() - Method in class cascading.tap.partition.PartitionTupleEntryIterator
 
hasNext() - Method in class cascading.tuple.TupleChainIterator
Method hasNext returns true if there is a next TupleEntry
hasNext() - Method in class cascading.tuple.TupleEntryChainIterator
Method hasNext returns true if there is a next TupleEntry
hasNext() - Method in class cascading.tuple.TupleEntryIterableChainIterator
Method hasNext returns true if there is a next TupleEntry
hasNext() - Method in class cascading.tuple.TupleEntrySchemeIterator
 
hasNext() - Method in class cascading.util.SingleValueIterator
 
hasNodeConfigDef() - Method in interface cascading.flow.planner.ScopedElement
 
hasNodeConfigDef() - Method in class cascading.pipe.Pipe
Returns true if there are properties in the nodeConfigDef instance.
hasNodeConfigDef() - Method in class cascading.tap.DecoratorTap
 
hasNodeConfigDef() - Method in class cascading.tap.Tap
Returns true if there are properties in the nodeConfigDef instance.
hasPlannerException() - Method in class cascading.flow.planner.rule.RuleResult
 
hasPlannerLevel() - Method in class cascading.pipe.Operator
Method hasPlannerLevel returns true if this Operator object holds a PlannedOperation object with an associated PlannerLevel level.
hasRelativePos() - Method in class cascading.tuple.Fields
Method hasRelativePos returns true if any ordinal position is relative (< 0)
hasRule(String) - Method in class cascading.flow.planner.rule.RuleRegistry
 
hasStepConfigDef() - Method in interface cascading.flow.planner.ScopedElement
 
hasStepConfigDef() - Method in class cascading.pipe.Pipe
Returns true if there are properties in the stepConfigDef instance.
hasStepConfigDef() - Method in class cascading.tap.DecoratorTap
 
hasStepConfigDef() - Method in class cascading.tap.Tap
Returns true if there are properties in the stepConfigDef instance.
hasStepListeners() - Method in class cascading.flow.BaseFlow
 
hasStepListeners() - Method in interface cascading.flow.Flow
Method hasStepListeners returns true if FlowStepListener instances have been registered with any of the FlowSteps belonging to this instance
hasSubGraphs() - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
hasTrapHandler() - Method in class cascading.flow.stream.element.BoundaryStage
 
hasTrapHandler() - Method in interface cascading.flow.stream.element.ElementDuct
 
hasTrapHandler() - Method in class cascading.flow.stream.element.ElementStage
 
hasTrapHandler() - Method in class cascading.flow.stream.element.SpliceGate
 
hasTypes() - Method in class cascading.tuple.Fields
Returns true if there are types associated with this instance.
hasTypes() - Method in class cascading.tuple.TupleEntry
Returns true if there are types associated with this instance.

I

id(FlowElement) - Static method in class cascading.flow.FlowElements
 
id(Pipe) - Static method in class cascading.pipe.Pipe
 
id(Tap) - Static method in class cascading.tap.Tap
Creates and returns a unique ID for the given Tap, this value is cached and may be used to uniquely identify the Tap instance in properties files etc.
ID_LENGTH - Static variable in class cascading.util.Util
 
IdentifierGraph - Class in cascading.cascade.planner
 
IdentifierGraph(Flow...) - Constructor for class cascading.cascade.planner.IdentifierGraph
 
Identity - Class in cascading.operation
The Identity function simply passes incoming arguments back out again.
Identity() - Constructor for class cascading.operation.Identity
Constructor Identity creates a new Identity instance that will pass the argument values to its output.
Identity(Class...) - Constructor for class cascading.operation.Identity
Constructor Identity creates a new Identity instance that will coerce the values to the give types.
Identity(Fields) - Constructor for class cascading.operation.Identity
Constructor Identity creates a new Identity instance that will rename the argument fields to the given fieldDeclaration.
Identity(Fields, Class...) - Constructor for class cascading.operation.Identity
Constructor Identity creates a new Identity instance that will rename the argument fields to the given fieldDeclaration, and coerce the values to the give types.
IgnoreAnnotationsHashSet - Class in cascading.flow.planner.graph
 
IgnoreAnnotationsHashSet(Collection<? extends ElementGraph>) - Constructor for class cascading.flow.planner.graph.IgnoreAnnotationsHashSet
 
IgnoresAnnotationsElementGraph - Class in cascading.flow.planner.graph
 
IgnoresAnnotationsElementGraph(ElementGraph) - Constructor for class cascading.flow.planner.graph.IgnoresAnnotationsElementGraph
 
ignoreValues - Variable in class cascading.operation.aggregator.ExtremaValueBase
Field ignoreValues
IncludeRemainderSubGraphIterator - Class in cascading.flow.planner.iso.subgraph.iterator
 
IncludeRemainderSubGraphIterator(SubGraphIterator) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
incomingEdgesOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
incomingEdgesOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
incomingEdgesOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
incomingEdgesOf(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
incomingEdgesOf(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
incomingEntry - Variable in class cascading.flow.stream.element.OperatorStage
 
incomingScopes - Variable in class cascading.flow.stream.element.BoundaryStage
 
incomingScopes - Variable in class cascading.flow.stream.element.ElementStage
 
incomingScopes - Variable in class cascading.flow.stream.element.SpliceGate
 
increment(Enum, long) - Method in class cascading.flow.FlowProcess
Method increment is used to increment a custom counter.
increment(String, String, long) - Method in class cascading.flow.FlowProcess
Method increment is used to increment a custom counter.
increment(Enum, long) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
increment(String, String, long) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
increment(Enum, long) - Method in class cascading.flow.FlowProcessWrapper
 
increment(String, String, long) - Method in class cascading.flow.FlowProcessWrapper
 
increment(String[], int) - Method in class cascading.management.CascadingServices.NullMetricsService
 
increment(String[], int) - Method in interface cascading.management.MetricsService
 
increment() - Method in class cascading.operation.filter.Limit.Context
 
inDegreeOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
inDegreeOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
inDegreeOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
inDegreeOf(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
inDegreeOf(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
INDENT - Static variable in class cascading.util.DOTProcessGraphWriter
 
indexOf(RuleRegistry) - Method in class cascading.flow.planner.rule.RuleRegistrySet
 
IndexTuple - Class in cascading.tuple.io
Class IndexTuple allows for managing an int index value with a Tuple instance.
IndexTuple() - Constructor for class cascading.tuple.io.IndexTuple
Constructor IndexTuple creates a new IndexTuple instance.
IndexTuple(int, Tuple) - Constructor for class cascading.tuple.io.IndexTuple
Constructor IndexTuple creates a new IndexTuple instance.
inferTypeFrom(int, String) - Method in interface cascading.scheme.util.FieldTypeResolver
 
inferTypes(Object[]) - Method in class cascading.scheme.util.DelimitedParser
 
init(List<BaseCascade.CascadeJob>) - Method in class cascading.cascade.BaseCascade.CascadeJob
 
init() - Method in class cascading.pipe.joiner.InnerJoin.JoinIterator
 
init() - Method in class cascading.pipe.joiner.OuterJoin.JoinIterator
 
initComparators() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
initConfFromNodeConfigDef(ElementGraph, ConfigDef.Setter) - Method in class cascading.flow.planner.BaseFlowStep
 
initConfFromStepConfigDef(ConfigDef.Setter) - Method in class cascading.flow.planner.BaseFlowStep
 
initConfig(Map<Object, Object>, Config) - Method in class cascading.flow.BaseFlow
This method creates a new internal Config with the parentConfig as defaults using the properties to override the defaults.
initConfig(Map<Object, Object>, Config) - Method in class cascading.flow.process.ProcessFlow
 
initFromProperties(Map<Object, Object>) - Method in class cascading.flow.BaseFlow
 
initialAssembly - Variable in class cascading.flow.planner.rule.RuleResult
 
initialize(FlowElementGraph, FlowStepGraph) - Method in class cascading.flow.BaseFlow
 
initialize(FlowConnector, Map<Object, Object>) - Method in class cascading.flow.planner.FlowPlanner
 
initialize(Map<String, Tap>, Map<String, Tap>, Pipe...) - Method in class cascading.flow.planner.graph.FlowElementGraph
 
initialize() - Method in class cascading.flow.stream.duct.Duct
Called immediately after bind
initialize() - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
initialize() - Method in class cascading.flow.stream.element.BoundaryStage
 
initialize() - Method in class cascading.flow.stream.element.BufferEveryWindow
 
initialize() - Method in class cascading.flow.stream.element.FilterEachStage
 
initialize() - Method in class cascading.flow.stream.element.FunctionEachStage
 
initialize() - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
initialize() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
initialize() - Method in class cascading.flow.stream.element.MemorySpliceGate
 
initialize() - Method in class cascading.flow.stream.element.MergeStage
 
initialize() - Method in class cascading.flow.stream.element.OperatorStage
 
initialize() - Method in class cascading.flow.stream.element.SourceStage
 
initialize() - Method in class cascading.flow.stream.element.SpliceGate
 
initialize() - Method in class cascading.flow.stream.element.ValueAssertionEachStage
 
initialize(CascadingServices, String) - Method in class cascading.management.state.BaseState
 
initialize(Fields, Pipe[], Fields, AggregateBy.Functor, Aggregator) - Method in class cascading.pipe.assembly.AggregateBy
 
initialize(Fields, Pipe[], Fields[], AggregateBy.Functor[], Aggregator[]) - Method in class cascading.pipe.assembly.AggregateBy
 
initialize(FlowProcess<? extends Config>) - Method in interface cascading.provider.CascadingFactory
Method initialize will configure an initialize this factory instance.
initialize(Comparator, Comparator[]) - Method in class cascading.tuple.util.TupleHasher
 
initialize(FlowProcess<? extends Config>) - Method in class cascading.util.cache.BaseCacheFactory
 
initialize() - Method in interface cascading.util.cache.CascadingCache
Method to initialize the Cache.
initialize() - Method in class cascading.util.cache.DirectMappedCache
 
initialize() - Method in class cascading.util.cache.LRUHashMapCache
 
initialize() - Method in class cascading.util.cache.OrderedHashMapCache
 
initializeChildStats() - Method in class cascading.flow.BaseFlow
 
initialized - Variable in class cascading.util.cache.DirectMappedCache
 
initializeNewJobsMap() - Method in class cascading.flow.BaseFlow
 
initResult(FlowElementGraph) - Method in class cascading.flow.planner.rule.RuleResult
 
initSteps() - Method in class cascading.flow.BaseFlow
 
INNER - Static variable in class cascading.pipe.joiner.MixedJoin
Field INNER
InnerJoin - Class in cascading.pipe.joiner
Class InnerJoin will return an Iterator that will iterate over a given Joiner and return tuples that represent and inner join of the CoGrouper internal grouped tuple collections.
InnerJoin() - Constructor for class cascading.pipe.joiner.InnerJoin
 
InnerJoin(Fields) - Constructor for class cascading.pipe.joiner.InnerJoin
 
InnerJoin.JoinIterator - Class in cascading.pipe.joiner
 
InnerJoin.JoinIterator(JoinerClosure) - Constructor for class cascading.pipe.joiner.InnerJoin.JoinIterator
 
InputSource - Interface in cascading.flow.stream.element
 
inputStream - Variable in class cascading.tuple.io.TupleInputStream
Field inputStream
Insert - Class in cascading.operation
Class Insert adds literal values to the Tuple stream.
Insert(Fields, Object...) - Constructor for class cascading.operation.Insert
Constructor Insert creates a new Insert instance with the given fields and values.
insertFlowElementAfter(ElementGraph, FlowElement, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
insertFlowElementBefore(ElementGraph, FlowElement, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
insertFlowElementBetweenEdge(ElementGraph, Scope, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
InsertionGraphTransformer - Class in cascading.flow.planner.iso.transformer
 
InsertionGraphTransformer(ExpressionGraph, String) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer(ExpressionGraph, String, InsertionGraphTransformer.Insertion) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer(ExpressionGraph, ElementCapture, String) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer(ExpressionGraph, ElementCapture, String, InsertionGraphTransformer.Insertion) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer(GraphTransformer, ExpressionGraph, String) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer(GraphTransformer, ExpressionGraph, ElementCapture, String) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer(GraphTransformer, ExpressionGraph, ElementCapture, String, InsertionGraphTransformer.Insertion) - Constructor for class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
InsertionGraphTransformer.Insertion - Enum in cascading.flow.planner.iso.transformer
 
INTEGER - Static variable in class cascading.tuple.coerce.Coercions
 
INTEGER_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
IntegerCoerce - Class in cascading.tuple.coerce
 
IntegerCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.IntegerCoerce
 
IntegerNameProvider<V> - Class in cascading.util.jgrapht
 
IntegerNameProvider() - Constructor for class cascading.util.jgrapht.IntegerNameProvider
 
IntegerObjectCoerce - Class in cascading.tuple.coerce
 
IntegerObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.IntegerObjectCoerce
 
INTERMEDIATE_SCHEME_CLASS - Static variable in class cascading.flow.FlowConnectorProps
 
IntermediateTapElementFactory - Class in cascading.flow.planner.rule.transformer
 
IntermediateTapElementFactory() - Constructor for class cascading.flow.planner.rule.transformer.IntermediateTapElementFactory
 
internalBlockOnStop() - Method in class cascading.flow.planner.FlowStepJob
 
internalClean(boolean) - Method in class cascading.flow.BaseFlow
 
internalClean(boolean) - Method in class cascading.flow.process.ProcessFlow
 
internalCleanup() - Method in class cascading.flow.planner.FlowStepJob
 
internalIsStartedRunning() - Method in class cascading.flow.planner.FlowStepJob
 
internalJobId() - Method in class cascading.flow.planner.FlowStepJob
 
internalNonBlockingIsComplete() - Method in class cascading.flow.planner.FlowStepJob
 
internalNonBlockingIsSuccessful() - Method in class cascading.flow.planner.FlowStepJob
 
internalNonBlockingStart() - Method in class cascading.flow.planner.FlowStepJob
 
internalSet(int, Object) - Method in class cascading.tuple.Tuple
 
internalShutdown() - Method in class cascading.flow.BaseFlow
 
internalShutdown() - Method in class cascading.flow.process.ProcessFlow
 
internalStart() - Method in class cascading.flow.BaseFlow
 
internalStart() - Method in class cascading.flow.process.ProcessFlow
 
internalStopAllJobs() - Method in class cascading.flow.BaseFlow
 
intToByteArray(int) - Static method in class cascading.util.Util
 
invokeAggregator(Aggregator, Tuple[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeAggregator(Aggregator, Tuple[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeAggregator(Aggregator, TupleEntry[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeAggregator(Aggregator, TupleEntry[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeAggregator(Aggregator, TupleEntry, TupleEntry[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeAggregator(Aggregator, TupleEntry, TupleEntry[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeBuffer(Buffer, Tuple[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeBuffer(Buffer, Tuple[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeBuffer(Buffer, TupleEntry[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeBuffer(Buffer, TupleEntry[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeBuffer(Buffer, TupleEntry, TupleEntry[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeBuffer(Buffer, TupleEntry, TupleEntry[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeConstructor(String, Object[], Class[]) - Static method in class cascading.util.Util
 
invokeConstructor(Class<T>, Object[], Class[]) - Static method in class cascading.util.Util
 
invokeFilter(Filter, Tuple) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, Tuple, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, TupleEntry) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, TupleEntry, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, Tuple[]) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, Tuple[], Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, TupleEntry[]) - Static method in class cascading.CascadingTestCase
 
invokeFilter(Filter, TupleEntry[], Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, Tuple, Fields) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, Tuple, Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, TupleEntry, Fields) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, TupleEntry, Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, Tuple[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, Tuple[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, TupleEntry[], Fields) - Static method in class cascading.CascadingTestCase
 
invokeFunction(Function, TupleEntry[], Fields, Map<Object, Object>) - Static method in class cascading.CascadingTestCase
 
invokeInstanceMethod(Object, String, Object[], Class[]) - Static method in class cascading.util.Util
 
invokeInstanceMethodSafe(Object, String, Object[], Class[]) - Static method in class cascading.util.Util
 
invokeStaticMethod(String, String, Object[], Class[]) - Static method in class cascading.util.Util
 
invokeStaticMethod(Class, String, Object[], Class[]) - Static method in class cascading.util.Util
 
IORole - Enum in cascading.flow.stream.graph
Enum IORole specifies how a FlowElement will be used during streaming.
IS_OSX - Static variable in class cascading.util.Util
 
isAggregator() - Method in class cascading.pipe.Every
Method isReducer returns true if this Every instance holds a Aggregator operation.
isAll() - Method in class cascading.tuple.Fields
Method isAll returns true if this instance is the Fields.ALL field set.
isAllChildrenFinished() - Method in class cascading.stats.BaseCachedNodeStats
 
isArgSelector() - Method in class cascading.tuple.Fields
Method isArgSelector returns true if this instance is 'defined' or the field set Fields.ALL, Fields.GROUP, or Fields.VALUES.
isArguments() - Method in class cascading.tuple.Fields
Method isArguments returns true if this instance is the Fields.ARGS field set.
isBlockingStreamed() - Method in class cascading.flow.stream.element.MemoryCoGroupGate
 
isBlockingStreamed() - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
isBlockingStreamed() - Method in class cascading.flow.stream.element.MemorySpliceGate
 
isBuffer() - Method in class cascading.pipe.Every
Method isBuffer returns true if this Every instance holds a Buffer operation.
isChild(CascadingStats.Type) - Method in enum cascading.stats.CascadingStats.Type
 
isCoGroup() - Method in class cascading.flow.planner.Scope
 
isCoGroup() - Method in interface cascading.pipe.Group
 
isCoGroup() - Method in class cascading.pipe.Splice
 
isCompleted(UnitOfWork) - Method in class cascading.management.UnitOfWorkExecutorStrategy
 
isCompleted(UnitOfWork) - Method in interface cascading.management.UnitOfWorkSpawnStrategy
 
isCompressSpill() - Method in class cascading.tuple.collect.SpillableProps
 
isCounterStatusInitialized() - Method in class cascading.flow.FlowProcess
Method isCounterStatusInitialized returns true if it is safe to increment a counter or set a status.
isCounterStatusInitialized() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
isCounterStatusInitialized() - Method in class cascading.flow.FlowProcessWrapper
 
isDebugEnabled() - Method in class cascading.cascade.BaseCascade
 
isDebugEnabled() - Method in class cascading.flow.BaseFlow
 
isDebugEnabled() - Method in class cascading.flow.planner.BaseFlowNode
 
isDebugEnabled() - Method in class cascading.flow.planner.BaseFlowStep
 
isDebugEnabled() - Method in interface cascading.util.ProcessLogger
 
isDeclarator() - Method in class cascading.tuple.Fields
Method isDeclarator returns true if this can be used as a declarator.
isDefined() - Method in class cascading.tuple.Fields
Method isDefined returns true if this instance is not a field set like Fields.ALL or Fields.UNKNOWN.
isDetailStale() - Method in class cascading.stats.CascadingStats
For rate limiting access to the backend.
isDirectory(FlowProcess<? extends Config>) - Method in interface cascading.tap.type.FileType
Method isDirectory returns true if the underlying resource represents a directory or folder instead of an individual file.
isDirectory(Config) - Method in interface cascading.tap.type.FileType
Method isDirectory returns true if the underlying resource represents a directory or folder instead of an individual file.
isEach() - Method in class cascading.flow.planner.Scope
Method isEach returns true if this Scope object represents an Each.
isEmpty(int) - Method in class cascading.flow.stream.element.MemoryCoGroupClosure
 
isEmpty(int) - Method in class cascading.pipe.joiner.JoinerClosure
 
isEmpty() - Method in class cascading.property.ConfigDef
Returns true if there are no properties.
isEmpty() - Method in class cascading.tuple.collect.SpillableTupleList
 
isEmpty() - Method in class cascading.tuple.Tuple
Method isEmpty returns true if this Tuple instance has no values.
isEmpty() - Method in class cascading.tuple.TupleListCollector
Method isEmpty returns true if this collection is empty.
isEmpty() - Method in class cascading.util.cache.DirectMappedCache
 
isEmpty() - Method in class cascading.util.cache.LRUHashMapCache
 
isEmpty() - Method in class cascading.util.cache.OrderedHashMapCache
 
isEmpty() - Method in class cascading.util.MultiMap
 
isEmpty(String) - Static method in class cascading.util.Util
 
isEnabled() - Method in class cascading.management.CascadingServices.NullDocumentService
 
isEnabled() - Method in class cascading.management.CascadingServices.NullMetricsService
 
isEnabled() - Method in class cascading.management.state.BaseState
 
isEnabled() - Method in interface cascading.provider.CascadingService
Returns true if this service has been enabled.
isEngaged() - Method in class cascading.stats.CascadingStats
Method isEngaged returns true when there is work being executed, if CascadingStats.isStarted(), CascadingStats.isSubmitted(), or CascadingStats.isRunning() returns true;
isEvery() - Method in class cascading.flow.planner.Scope
Method isEvery returns true if this Scope object represents an Every.
isFailed() - Method in class cascading.stats.CascadingStats
Method isFailed returns true when the work ended with an error.
isFailOnClose() - Method in class cascading.tap.partition.PartitionTapProps
 
isFilter() - Method in class cascading.pipe.Each
 
isFinished() - Method in class cascading.stats.CascadingStats
Method isFinished returns true if the current status shows no work currently being executed, if CascadingStats.isSkipped(), CascadingStats.isSuccessful(), CascadingStats.isFailed(), or CascadingStats.isStopped() returns true.
isFinished() - Method in enum cascading.stats.CascadingStats.Status
 
isFunction() - Method in class cascading.pipe.Each
 
isGroup() - Method in class cascading.flow.planner.Scope
 
isGroup() - Method in class cascading.tuple.Fields
Method isKeys returns true if this instance is the Fields.GROUP field set.
isGroupAssertion() - Method in class cascading.pipe.Every
 
isGroupBy() - Method in class cascading.flow.planner.Scope
 
isGroupBy() - Method in interface cascading.pipe.Group
 
isGroupBy() - Method in class cascading.pipe.Splice
Method isGroupBy returns true if this Splice instance will perform a GroupBy operation.
isHashJoin() - Method in class cascading.flow.planner.Scope
 
isIdentity(ProcessModel, Class<? extends FlowElement>) - Static method in class cascading.flow.planner.process.ProcessModels
Does the given process perform any work?
isIdentity(ProcessModel) - Static method in class cascading.flow.planner.process.ProcessModels
Does the given process perform any work?
isIgnoreFailed() - Method in class cascading.flow.planner.rule.RuleRegistrySet
When true, failures during planning will be ignored unless no registries are successful.
isIgnoreMode() - Method in class cascading.flow.planner.iso.expression.PathScopeExpression
 
isIllegal() - Method in class cascading.flow.planner.rule.RuleResult
 
isInfoEnabled() - Method in class cascading.cascade.BaseCascade
 
isInfoEnabled() - Method in class cascading.flow.BaseFlow
 
isInfoEnabled() - Method in class cascading.flow.planner.BaseFlowNode
 
isInfoEnabled() - Method in class cascading.flow.planner.BaseFlowStep
 
isInfoEnabled() - Method in interface cascading.util.ProcessLogger
 
isInterrupted() - Method in class cascading.flow.planner.rule.RuleResult
 
isJoin() - Method in class cascading.pipe.Splice
 
isKeep() - Method in class cascading.tap.DecoratorTap
 
isKeep() - Method in class cascading.tap.Tap
Method isKeep indicates whether the resource represented by this instance should be kept if it already exists when the Flow is started.
isLogThrowableStackTrace() - Method in class cascading.tap.TrapProps
 
isMatchEachElement() - Method in class cascading.operation.regex.RegexFilter
 
isMerge() - Method in class cascading.flow.planner.Scope
 
isMerge() - Method in class cascading.pipe.Splice
 
isNegateMatch() - Method in class cascading.operation.regex.RegexMatcher
 
isNonBlocking() - Method in class cascading.flow.planner.Scope
 
isNone() - Method in class cascading.tuple.Fields
Method isNone returns returns true if this instance is the Fields.NONE field set.
isNoneLevel() - Method in enum cascading.operation.AssertionLevel
 
isNoneLevel() - Method in enum cascading.operation.DebugLevel
 
isNoneLevel() - Method in interface cascading.operation.PlannerLevel
Returns true if this enum instance represents a value that instructs the FlowPlanner to remove all instances from the plan.
isNull(Comparator[]) - Static method in class cascading.tuple.util.TupleHasher
 
isOrdered() - Method in class cascading.tuple.Fields
Method isOrdered returns true if this instance is ordered.
isOuter(int) - Method in class cascading.pipe.joiner.LeftJoin.JoinIterator
 
isOuter(int) - Method in class cascading.pipe.joiner.MixedJoin.JoinIterator
 
isOuter(int) - Method in class cascading.pipe.joiner.OuterJoin.JoinIterator
 
isOuter(int) - Method in class cascading.pipe.joiner.RightJoin.JoinIterator
 
isOutSelector() - Method in class cascading.tuple.Fields
Method isOutSelector returns true if this instance is 'defined', or the field set Fields.ALL or Fields.RESULTS.
isPending() - Method in class cascading.stats.CascadingStats
Method isPending returns true if no work has been submitted.
isPreserveTemporaryFiles() - Method in class cascading.flow.FlowProps
 
isPrevious(Pipe, Pipe) - Static method in class cascading.flow.FlowElements
 
isPrintFields() - Method in class cascading.operation.Debug
 
isRecordElementTrace() - Method in class cascading.tap.TrapProps
 
isRecordThrowableMessage() - Method in class cascading.tap.TrapProps
 
isRecordThrowableStackTrace() - Method in class cascading.tap.TrapProps
 
isRemoteExecution() - Method in class cascading.flow.planner.FlowStepJob
 
isRemove(FlowProcess, FilterCall<Long>) - Method in class cascading.operation.Debug
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.filter.And
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.filter.FilterNotNull
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.filter.FilterNull
 
isRemove(FlowProcess, FilterCall<Context>) - Method in interface cascading.operation.Filter
Method isRemove returns true if input should be removed from the tuple stream.
isRemove(FlowProcess, FilterCall<Limit.Context>) - Method in class cascading.operation.filter.Limit
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.filter.Not
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.filter.Or
 
isRemove(FlowProcess, FilterCall<Random>) - Method in class cascading.operation.filter.Sample
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.filter.Xor
 
isRemove(FlowProcess, FilterCall<Matcher>) - Method in class cascading.operation.regex.RegexFilter
 
isRemove(FlowProcess, FilterCall) - Method in class cascading.operation.state.Counter
 
isRemove(FlowProcess, FilterCall<Boolean>) - Method in class cascading.operation.state.Status
 
isRemove(FlowProcess, FilterCall<CascadingCache<Tuple, Object>>) - Method in class cascading.pipe.assembly.Unique.FilterPartialDuplicates
 
isReplace() - Method in class cascading.tap.DecoratorTap
 
isReplace() - Method in class cascading.tap.MultiSourceTap
 
isReplace() - Method in class cascading.tap.Tap
Method isReplace indicates whether the resource represented by this instance should be deleted if it already exists when the Flow is started.
isReplace() - Method in class cascading.tuple.Fields
Method isReplace returns true if this instance is the Fields.REPLACE field set.
isReplaceAll() - Method in class cascading.operation.regex.RegexReplace
 
isResolved() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
isResults() - Method in class cascading.tuple.Fields
Method isResults returns true if this instance is the Fields.RESULTS field set.
isRetainValues() - Method in interface cascading.operation.BufferCall
Returns true if non-grouping fields will not be nulled after the argumentsIterator is completed.
isRetainValues() - Method in class cascading.operation.ConcreteCall
 
isReversed() - Method in enum cascading.flow.planner.iso.finder.SearchOrder
 
isRunning() - Method in class cascading.stats.CascadingStats
Method isRunning returns true when work has begun.
isSafe() - Method in class cascading.operation.BaseOperation
 
isSafe() - Method in interface cascading.operation.Operation
Returns true if this Operation instance can safely execute on the same 'record' multiple times, false otherwise.
isSelfJoin() - Method in class cascading.pipe.joiner.JoinerClosure
 
isSelfJoin() - Method in class cascading.pipe.Splice
 
isSink() - Method in class cascading.scheme.Scheme
Method isSink returns true if this Scheme instance can be used as a sink.
isSink() - Method in class cascading.tap.DecoratorTap
 
isSink() - Method in class cascading.tap.SourceTap
 
isSink() - Method in class cascading.tap.Tap
Method isSink returns true if this Tap instance can be used as a sink.
isSkipFlow() - Method in class cascading.flow.BaseFlow
 
isSkipFlow() - Method in interface cascading.flow.Flow
Method isSkipFlow returns true if the parent Cascade should skip this Flow instance.
isSkipFlowStep() - Method in class cascading.flow.planner.FlowStepJob
 
isSkipped() - Method in class cascading.stats.CascadingStats
Method isSkipped returns true when the works was skipped.
isSorted() - Method in interface cascading.pipe.Group
 
isSorted() - Method in class cascading.pipe.Splice
Method isSorted returns true if this Splice instance is sorting values other than the group fields.
isSortReversed() - Method in interface cascading.pipe.Group
 
isSortReversed() - Method in class cascading.pipe.Splice
Method isSortReversed returns true if sorting is reversed.
isSource() - Method in class cascading.scheme.Scheme
Method isSource returns true if this Scheme instance can be used as a source.
isSource() - Method in class cascading.tap.DecoratorTap
 
isSource() - Method in class cascading.tap.SinkTap
 
isSource() - Method in class cascading.tap.Tap
Method isSource returns true if this Tap instance can be used as a source.
isSplice() - Method in class cascading.flow.planner.Scope
 
isStackTraceTrimLine() - Method in class cascading.tap.TrapProps
 
isStarted() - Method in class cascading.flow.planner.FlowStepJob
Method isStarted returns true if this underlying job has started running
isStarted() - Method in class cascading.stats.CascadingStats
Method isStarted returns true when work has started.
isStopJobsOnExit() - Method in class cascading.flow.BaseFlow
 
isStopJobsOnExit() - Method in interface cascading.flow.Flow
Method isStopJobsOnExit returns the stopJobsOnExit of this Flow object.
isStopJobsOnExit() - Method in class cascading.flow.FlowProps
 
isStopped() - Method in class cascading.stats.CascadingStats
Method isStopped returns true when the user stopped the work.
isStricterThan(PlannerLevel) - Method in enum cascading.operation.AssertionLevel
 
isStricterThan(PlannerLevel) - Method in enum cascading.operation.DebugLevel
 
isStricterThan(PlannerLevel) - Method in interface cascading.operation.PlannerLevel
Returns true if the given PlannerLevel is less strict than this instance.
isSubmitted() - Method in class cascading.stats.CascadingStats
Method isSubmitted returns true if no work has started.
isSubstitution() - Method in class cascading.tuple.Fields
Method isSubstitution returns true if this instance is a substitution fields set.
isSuccess() - Method in class cascading.flow.planner.rule.RuleResult
 
isSuccessful() - Method in class cascading.cascade.BaseCascade.CascadeJob
 
isSuccessful() - Method in class cascading.flow.planner.FlowStepJob
Method isSuccessful returns true if this step completed successfully or was skipped.
isSuccessful() - Method in class cascading.stats.CascadingStats
Method isSuccessful returns true when work has completed successfully.
isSwap() - Method in class cascading.tuple.Fields
Method isSwap returns true if this instance is the Fields.SWAP field set.
isSymmetrical() - Method in class cascading.scheme.Scheme
Method isSymmetrical returns true if the sink fields equal the source fields.
isTap() - Method in class cascading.flow.planner.Scope
Method isTap returns true if this Scope object represents a Tap.
isTemporary() - Method in class cascading.tap.DecoratorTap
 
isTemporary() - Method in class cascading.tap.Tap
Method isTemporary returns true if this Tap is temporary (used for intermediate results).
isTransformTraceDisabled() - Method in class cascading.flow.planner.rule.util.TraceWriter
 
isTransformTraceEnabled() - Method in class cascading.flow.planner.rule.util.TraceWriter
 
isTransformTracingEnabled() - Method in class cascading.flow.planner.PlannerContext
 
isUnknown() - Method in class cascading.tuple.Fields
Method isUnknown returns true if this instance is the Fields.UNKNOWN field set.
isUnmodifiable - Variable in class cascading.tuple.Tuple
Field isUnmodifiable
isUnmodifiable() - Method in class cascading.tuple.Tuple
Method isUnmodifiable returns true if this Tuple instance is unmodifiable.
isUnmodifiable() - Method in class cascading.tuple.TupleEntry
Method isUnmodifiable returns true if this TupleEntry is unmodifiable.
isUnOrdered() - Method in class cascading.tuple.Fields
Method isUnOrdered returns true if this instance is unordered.
isUnsupported() - Method in class cascading.flow.planner.rule.RuleResult
 
isUpdate() - Method in class cascading.tap.DecoratorTap
 
isUpdate() - Method in class cascading.tap.Tap
Method isUpdate indicates whether the resource represented by this instance should be updated if it already exists.
isValueAssertion() - Method in class cascading.pipe.Each
 
isValues() - Method in class cascading.tuple.Fields
Method isValues returns true if this instance is the Fields.VALUES field set.
iterator() - Method in class cascading.tuple.collect.SpillableTupleList
 
iterator() - Method in class cascading.tuple.Fields
Method iterator return an unmodifiable iterator of field values.
iterator() - Method in class cascading.tuple.Tuple
Method iterator returns an Iterator over this Tuple instances values.
iterator() - Method in class cascading.tuple.TupleChainIterable
 
iterator() - Method in class cascading.tuple.TupleListCollector
Method iterator returns an iterator for this collection.

J

jarClass - Variable in class cascading.property.AppProps
 
jarPath - Variable in class cascading.property.AppProps
 
JOB_POLLING_INTERVAL - Static variable in class cascading.flow.FlowProps
 
jobConfiguration - Variable in class cascading.flow.planner.FlowStepJob
Field jobConfiguration
join(Fields...) - Static method in class cascading.tuple.Fields
Method join joins all given Fields instances into a new Fields instance.
join(boolean, Fields...) - Static method in class cascading.tuple.Fields
 
join(int[], String) - Static method in class cascading.util.Util
This method joins the values in the given list with the delim String value.
join(int[], String, boolean) - Static method in class cascading.util.Util
 
join(String, String...) - Static method in class cascading.util.Util
 
join(String, boolean, String...) - Static method in class cascading.util.Util
 
join(Object[], String) - Static method in class cascading.util.Util
This method joins the values in the given list with the delim String value.
join(Object[], String, boolean) - Static method in class cascading.util.Util
 
join(Object[], String, boolean, int) - Static method in class cascading.util.Util
 
join(Object[], String, boolean, int, int) - Static method in class cascading.util.Util
 
join(Iterable, String, boolean) - Static method in class cascading.util.Util
 
join(Collection) - Static method in class cascading.util.Util
This method joins each value in the collection with a tab character as the delimiter.
join(Collection, String) - Static method in class cascading.util.Util
This method joins each valuein the collection with the given delimiter.
join(Collection, String, boolean) - Static method in class cascading.util.Util
 
join(StringBuffer, Collection, String) - Static method in class cascading.util.Util
This method joins each value in the collection with the given delimiter.
join(StringBuffer, Collection, String, boolean) - Static method in class cascading.util.Util
 
Joiner - Interface in cascading.pipe.joiner
Interface Joiner allows for custom join strategies against a CoGroup.
joinerClosure - Variable in class cascading.flow.stream.duct.Grouping
 
JoinerClosure - Class in cascading.pipe.joiner
Class JoinerClosure wraps all incoming tuple streams with iterator instances allowing for just join implementations.
JoinerClosure(FlowProcess, Fields[], Fields[]) - Constructor for class cascading.pipe.joiner.JoinerClosure
 
joinFields - Variable in class cascading.pipe.joiner.JoinerClosure
 
joinFirstLine(Iterable, Appendable) - Method in class cascading.scheme.util.DelimitedParser
 
joinIterator - Variable in class cascading.flow.stream.duct.Grouping
 
joinLine(Iterable, Appendable) - Method in class cascading.scheme.util.DelimitedParser
 
joinNoQuote(Iterable, Appendable) - Method in class cascading.scheme.util.DelimitedParser
 
joinWithQuote(Iterable, Appendable) - Method in class cascading.scheme.util.DelimitedParser
 

K

keepAlive() - Method in class cascading.flow.FlowProcess
Method keepAlive notifies the system that the current process is still alive.
keepAlive() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
keepAlive() - Method in class cascading.flow.FlowProcessWrapper
 
keepParentOnDelete - Variable in class cascading.tap.partition.BasePartitionTap
Field keepParentOnDelete
key - Variable in class cascading.flow.stream.duct.Grouping
 
keyBuilder - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
keyEntry - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
keyFields - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
keyFieldsMap - Variable in class cascading.pipe.Splice
Field groupFieldsMap
KeyIndexTuple - Class in cascading.tuple.io
 
KeyIndexTuple() - Constructor for class cascading.tuple.io.KeyIndexTuple
 
KeyIndexTuple(int, Tuple) - Constructor for class cascading.tuple.io.KeyIndexTuple
 
keys - Variable in class cascading.flow.stream.element.MemorySpliceGate
 
keySet() - Method in class cascading.util.cache.DirectMappedCache
 
keySet() - Method in class cascading.util.cache.LRUHashMapCache
 
keySet() - Method in class cascading.util.cache.OrderedHashMapCache
 
keyTuple - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
KeyTuple - Class in cascading.tuple.io
 
KeyTuple(List<Object>) - Constructor for class cascading.tuple.io.KeyTuple
 
KeyTuple(Fields, List<Object>) - Constructor for class cascading.tuple.io.KeyTuple
 
KeyTuple() - Constructor for class cascading.tuple.io.KeyTuple
 
KeyTuple(Tuple) - Constructor for class cascading.tuple.io.KeyTuple
 
KeyTuple(Object...) - Constructor for class cascading.tuple.io.KeyTuple
 
keyValues - Variable in class cascading.flow.stream.element.MemorySpliceGate
 

L

Last - Class in cascading.operation.aggregator
Class Last is an Aggregator that returns the last Tuple encountered.
Last() - Constructor for class cascading.operation.aggregator.Last
Selects and returns the last argument Tuple encountered.
Last(Fields) - Constructor for class cascading.operation.aggregator.Last
Selects and returns the last argument Tuple encountered.
Last(Fields, Tuple...) - Constructor for class cascading.operation.aggregator.Last
Selects and returns the last argument Tuple encountered, unless the Tuple is a member of the set ignoreTuples.
LAST - Static variable in class cascading.tuple.Fields
Field LAST represents the last field position, -1
lastCaptureDetail - Variable in class cascading.stats.CascadingStats
 
latch - Variable in class cascading.flow.stream.element.MemoryHashJoinGate
 
leave(int[]) - Method in class cascading.tuple.Tuple
Method is the inverse of Tuple.remove(int[]).
LeftJoin - Class in cascading.pipe.joiner
Class LeftJoin will return an Iterator that will iterate over a given Joiner and return tuples that represent a left inner, right outer join of the CoGrouper internal grouped tuple collections.
LeftJoin() - Constructor for class cascading.pipe.joiner.LeftJoin
 
LeftJoin(Fields) - Constructor for class cascading.pipe.joiner.LeftJoin
 
LeftJoin.JoinIterator - Class in cascading.pipe.joiner
 
LeftJoin.JoinIterator(JoinerClosure) - Constructor for class cascading.pipe.joiner.LeftJoin.JoinIterator
 
Limit - Class in cascading.operation.filter
Class Limit is a Filter that will limit the number of Tuple instances that it will allow to pass.
Limit(long) - Constructor for class cascading.operation.filter.Limit
Creates a new Limit class that only allows limit number of Tuple instances to pass.
limit - Variable in class cascading.operation.filter.Limit.Context
 
Limit.Context - Class in cascading.operation.filter
 
Limit.Context() - Constructor for class cascading.operation.filter.Limit.Context
 
LIST_THRESHOLD - Static variable in class cascading.tuple.collect.SpillableProps
Number of tuples to hold in memory before spilling them to disk.
listeners - Variable in class cascading.stats.CascadingStats
 
loadClass(String) - Static method in class cascading.util.Util
 
loadClassSafe(String) - Static method in class cascading.util.Util
 
loadFactoryFrom(FlowProcess, String, Class<Factory>) - Method in class cascading.provider.FactoryLoader
 
loadServiceFrom(Properties, Map<Object, Object>, String) - Method in class cascading.provider.ServiceLoader
 
loadSingletonServiceFrom(Properties, Map<Object, Object>, String) - Method in class cascading.provider.ServiceLoader
 
loadVersionProperties() - Static method in class cascading.util.Version
 
locale - Variable in class cascading.operation.text.DateOperation
Field locale
locale - Variable in class cascading.tuple.type.DateType
Field locale
LOG_COUNTERS - Static variable in class cascading.flow.FlowRuntimeProps
 
LOG_THROWABLE_STACK_TRACE - Static variable in class cascading.tap.TrapProps
 
logCounters(Logger, String, FlowProcess) - Static method in class cascading.util.LogUtil
 
logDebug(String, Object...) - Method in class cascading.cascade.BaseCascade
 
logDebug(String, Object...) - Method in class cascading.flow.BaseFlow
 
logDebug(String, Object...) - Method in class cascading.flow.planner.BaseFlowNode
 
logDebug(String, Object...) - Method in class cascading.flow.planner.BaseFlowStep
 
logDebug(String, Object...) - Method in class cascading.stats.CascadingStats
 
logDebug(String, Object...) - Method in interface cascading.util.ProcessLogger
 
logError(String, Object...) - Method in class cascading.cascade.BaseCascade
 
logError(String, Throwable) - Method in class cascading.cascade.BaseCascade
 
logError(String, Object...) - Method in class cascading.flow.BaseFlow
 
logError(String, Throwable) - Method in class cascading.flow.BaseFlow
 
logError(String, Object...) - Method in class cascading.flow.planner.BaseFlowNode
 
logError(String, Throwable) - Method in class cascading.flow.planner.BaseFlowNode
 
logError(String, Object...) - Method in class cascading.flow.planner.BaseFlowStep
 
logError(String, Throwable) - Method in class cascading.flow.planner.BaseFlowStep
 
logError(String, Object...) - Method in class cascading.stats.CascadingStats
 
logError(String, Throwable) - Method in class cascading.stats.CascadingStats
 
logError(String, Object...) - Method in interface cascading.util.ProcessLogger
 
logError(String, Throwable) - Method in interface cascading.util.ProcessLogger
 
Logic - Class in cascading.operation.filter
Class Logic is the base class for logical Filter operations.
Logic(Filter...) - Constructor for class cascading.operation.filter.Logic
 
Logic(Fields, Filter, Fields, Filter) - Constructor for class cascading.operation.filter.Logic
 
Logic(Fields[], Filter[]) - Constructor for class cascading.operation.filter.Logic
 
Logic.Context - Class in cascading.operation.filter
 
Logic.Context() - Constructor for class cascading.operation.filter.Logic.Context
 
logInfo(String, Object...) - Method in class cascading.cascade.BaseCascade
 
logInfo(String, Object...) - Method in class cascading.flow.BaseFlow
 
logInfo(String, Object...) - Method in class cascading.flow.planner.BaseFlowNode
 
logInfo(String, Object...) - Method in class cascading.flow.planner.BaseFlowStep
 
logInfo(String, Object...) - Method in class cascading.stats.CascadingStats
 
logInfo(String, Object...) - Method in interface cascading.util.ProcessLogger
 
logMemory(Logger, String) - Static method in class cascading.util.LogUtil
 
logThrowableStackTrace - Variable in class cascading.tap.TrapProps
 
LogUtil - Class in cascading.util
 
LogUtil() - Constructor for class cascading.util.LogUtil
 
logWarn(String) - Method in class cascading.cascade.BaseCascade
 
logWarn(String, Throwable) - Method in class cascading.cascade.BaseCascade
 
logWarn(String, Object...) - Method in class cascading.cascade.BaseCascade
 
logWarn(String) - Method in class cascading.flow.BaseFlow
 
logWarn(String, Throwable) - Method in class cascading.flow.BaseFlow
 
logWarn(String, Object...) - Method in class cascading.flow.BaseFlow
 
logWarn(String) - Method in class cascading.flow.planner.BaseFlowNode
 
logWarn(String, Object...) - Method in class cascading.flow.planner.BaseFlowNode
 
logWarn(String, Throwable) - Method in class cascading.flow.planner.BaseFlowNode
 
logWarn(String) - Method in class cascading.flow.planner.BaseFlowStep
 
logWarn(String, Throwable) - Method in class cascading.flow.planner.BaseFlowStep
 
logWarn(String, Object...) - Method in class cascading.flow.planner.BaseFlowStep
 
logWarn(String, Object...) - Method in class cascading.stats.CascadingStats
 
logWarn(String) - Method in interface cascading.util.ProcessLogger
 
logWarn(String, Object...) - Method in interface cascading.util.ProcessLogger
 
logWarn(String, Throwable) - Method in interface cascading.util.ProcessLogger
 
LoneGroupAssert - Class in cascading.flow.planner.rule.assertion
Verifies that there are not only GroupAssertions following any given Group instance.
LoneGroupAssert() - Constructor for class cascading.flow.planner.rule.assertion.LoneGroupAssert
 
LoneGroupExpression - Class in cascading.flow.planner.rule.expression
 
LoneGroupExpression() - Constructor for class cascading.flow.planner.rule.expression.LoneGroupExpression
 
LONG - Static variable in class cascading.tuple.coerce.Coercions
 
LONG_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
LongCoerce - Class in cascading.tuple.coerce
 
LongCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.LongCoerce
 
LongObjectCoerce - Class in cascading.tuple.coerce
 
LongObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.LongObjectCoerce
 
longToByteArray(long) - Static method in class cascading.util.Util
 
LRUHashMapCache<Key,Value> - Class in cascading.util.cache
Implementation of the CascadingCache interface backed by a LinkedHashMap configured to evict the least recently used key.
LRUHashMapCache() - Constructor for class cascading.util.cache.LRUHashMapCache
 
LRUHashMapCacheFactory - Class in cascading.util.cache
Concrete sub-class of BaseCacheFactory for creating LRUHashMapCache instances.
LRUHashMapCacheFactory() - Constructor for class cascading.util.cache.LRUHashMapCacheFactory
 

M

makeFileName(int, String, String) - Method in class cascading.flow.planner.iso.GraphResult
 
makeFlowNodeName(FlowNode, int, int) - Method in class cascading.flow.planner.BaseFlowNodeFactory
 
makeFlowNodeName(FlowNode, int, int) - Method in interface cascading.flow.planner.process.FlowNodeFactory
 
makeFlowStepName(FlowStep, int, int) - Method in class cascading.flow.planner.BaseFlowStepFactory
 
makeFlowStepName(FlowStep, int, int) - Method in interface cascading.flow.planner.process.FlowStepFactory
 
makeOrdinal(int) - Method in class cascading.flow.stream.duct.DuctGraph
 
makePath(String, String) - Static method in class cascading.util.Util
 
makeResult(Tuple, Tuple) - Method in class cascading.tuple.util.TupleBuilder
 
makeSeed() - Method in class cascading.operation.filter.Sample
 
makeTempTap(String) - Method in class cascading.flow.planner.FlowPlanner
 
makeTempTap(String, String) - Method in class cascading.flow.planner.FlowPlanner
 
MAP_CAPACITY - Static variable in class cascading.tuple.collect.SpillableProps
The initial hash map capacity.
MAP_LOADFACTOR - Static variable in class cascading.tuple.collect.SpillableProps
The initial hash map load factor.
MAP_THRESHOLD - Static variable in class cascading.tuple.collect.SpillableProps
The total number of tuple values (not keys) to attempt to keep in memory.
markDetailCaptured() - Method in class cascading.stats.CascadingStats
 
markFailed() - Method in class cascading.stats.CascadingStats
Method markFailed sets the status to CascadingStats.Status.FAILED.
markFailed(Throwable) - Method in class cascading.stats.CascadingStats
Method markFailed sets the status to CascadingStats.Status.FAILED.
markFailed(String[]) - Method in class cascading.stats.CascadingStats
Method markFailed sets the status to CascadingStats.Status.FAILED.
markFailed(Throwable, String[]) - Method in class cascading.stats.CascadingStats
 
markFinishedTime() - Method in class cascading.stats.CascadingStats
 
markPending() - Method in class cascading.stats.CascadingStats
Method markPending sets the status to CascadingStats.Status.PENDING.
markPendingTime() - Method in class cascading.stats.CascadingStats
 
markRunning() - Method in class cascading.stats.CascadingStats
Method markRunning sets the status to CascadingStats.Status.RUNNING.
markRunTime() - Method in class cascading.stats.CascadingStats
 
markSkipped() - Method in class cascading.stats.CascadingStats
Method markSkipped sets the status to CascadingStats.Status.SKIPPED.
markStarted() - Method in class cascading.stats.CascadingStats
Method markStarted sets the status to CascadingStats.Status.STARTED.
markStartedThenRunning() - Method in class cascading.stats.CascadingStats
Method markStartedThenRunning consecutively marks the status as CascadingStats.Status.STARTED then CascadingStats.Status.RUNNING and forces the start and running time to be equals.
markStartTime() - Method in class cascading.stats.CascadingStats
 
markStartToRunTime() - Method in class cascading.stats.CascadingStats
 
markStopped() - Method in class cascading.stats.CascadingStats
Method markStopped sets the status to CascadingStats.Status.STOPPED.
markSubmitted() - Method in class cascading.stats.CascadingStats
Method markSubmitted sets the status to CascadingStats.Status.SUBMITTED.
markSubmitTime() - Method in class cascading.stats.CascadingStats
 
markSuccessful() - Method in class cascading.stats.CascadingStats
Method markSuccessful sets the status to CascadingStats.Status.SUCCESSFUL.
mask(Fields, Fields) - Static method in class cascading.tuple.Fields
 
Match - Class in cascading.flow.planner.iso.finder
 
Match(ExpressionGraph, ElementGraph, Map<ElementExpression, FlowElement>, Collection<FlowElement>, Collection<Scope>) - Constructor for class cascading.flow.planner.iso.finder.Match
 
Match(ExpressionGraph, ElementGraph, Map<ElementExpression, FlowElement>, Collection<FlowElement>, Collection<Scope>, EnumMultiMap<FlowElement>) - Constructor for class cascading.flow.planner.iso.finder.Match
 
matchEachElement - Variable in class cascading.operation.regex.RegexFilter
Field matchEachElement
matchEachElement(Matcher, TupleEntry) - Method in class cascading.operation.regex.RegexMatcher
 
matchEachElementPos(Matcher, TupleEntry) - Method in class cascading.operation.regex.RegexMatcher
 
matchExpression - Variable in class cascading.flow.planner.rule.RuleExpression
 
matchGraph - Variable in class cascading.flow.planner.iso.finder.Match
 
matchWholeTuple(Matcher, TupleEntry) - Method in class cascading.operation.regex.RegexMatcher
 
max(Collection<N>) - Static method in class cascading.util.Util
 
MAX_CONCURRENT_FLOWS - Static variable in class cascading.cascade.CascadeProps
 
MAX_CONCURRENT_PLANNERS - Static variable in class cascading.flow.planner.rule.RuleSetExec
 
MAX_CONCURRENT_STEPS - Static variable in class cascading.flow.FlowProps
 
maxAge - Variable in class cascading.stats.CounterCache
 
MaxBy - Class in cascading.pipe.assembly
Class MaxBy is used to find the maximum value in a grouping.
MaxBy(Fields, Fields) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(String, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(String, Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(String, Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy(String, Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MaxBy
Constructor MaxBy creates a new MaxBy instance.
MaxBy.MaxPartials - Class in cascading.pipe.assembly
 
MaxBy.MaxPartials(Fields) - Constructor for class cascading.pipe.assembly.MaxBy.MaxPartials
 
maxFetchAttempts - Variable in class cascading.stats.CounterCache
 
MaxValue - Class in cascading.operation.aggregator
Class MaxValue is an Aggregator that returns the maximum value encountered in the current group.
MaxValue() - Constructor for class cascading.operation.aggregator.MaxValue
Constructs a new instance that returns the maximum value encountered in the field name "max".
MaxValue(Fields) - Constructor for class cascading.operation.aggregator.MaxValue
Constructs a new instance that returns the maximum value encountered in the given fieldDeclaration field name.
MaxValue(Fields, Object...) - Constructor for class cascading.operation.aggregator.MaxValue
Constructs a new instance that returns the maximum value encountered in the given fieldDeclaration field name.
MemoryCoGroupClosure - Class in cascading.flow.stream.element
 
MemoryCoGroupClosure(FlowProcess, int, Fields[], Fields[]) - Constructor for class cascading.flow.stream.element.MemoryCoGroupClosure
 
MemoryCoGroupGate - Class in cascading.flow.stream.element
 
MemoryCoGroupGate(FlowProcess, Splice) - Constructor for class cascading.flow.stream.element.MemoryCoGroupGate
 
MemoryHashJoinGate - Class in cascading.flow.stream.element
 
MemoryHashJoinGate(FlowProcess, HashJoin) - Constructor for class cascading.flow.stream.element.MemoryHashJoinGate
 
MemorySpliceGate - Class in cascading.flow.stream.element
 
MemorySpliceGate(FlowProcess, Splice) - Constructor for class cascading.flow.stream.element.MemorySpliceGate
 
Merge - Class in cascading.pipe
The Merge Pipe allows for multiple branches, with the same fields to be spliced back into a single stream.
Merge(Pipe...) - Constructor for class cascading.pipe.Merge
Constructor Merge creates a new Merge instance.
Merge(String, Pipe...) - Constructor for class cascading.pipe.Merge
Constructor Merge creates a new Merge instance.
merge(Fields...) - Static method in class cascading.tuple.Fields
Method merge merges all given Fields instances into a new Fields instance where a merge is a set union of all the given Fields instances.
merge(Fields[]) - Static method in class cascading.tuple.util.TupleHasher
 
mergeMapIntoConfig(Config, Map<String, String>) - Method in class cascading.flow.FlowProcess
 
mergeMapIntoConfig(Object, Map<String, String>) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
mergeMapIntoConfig(Config, Map<String, String>) - Method in class cascading.flow.FlowProcessWrapper
 
MergeStage - Class in cascading.flow.stream.element
 
MergeStage(FlowProcess, FlowElement) - Constructor for class cascading.flow.stream.element.MergeStage
 
metaInfo - Variable in class cascading.tap.DecoratorTap
 
METRICS_SERVICE_CLASS_PROPERTY - Static variable in interface cascading.management.MetricsService
 
MetricsService - Interface in cascading.management
Interface MetricsService provides fine grained hooks for managing various metrics.
min(Collection<N>) - Static method in class cascading.util.Util
 
MinBy - Class in cascading.pipe.assembly
Class MinBy is used to find the minimum value in a grouping.
MinBy(Fields, Fields) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(String, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(String, Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(String, Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy(String, Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.MinBy
Constructor MinBy creates a new MinBy instance.
MinBy.MinPartials - Class in cascading.pipe.assembly
 
MinBy.MinPartials(Fields) - Constructor for class cascading.pipe.assembly.MinBy.MinPartials
Constructor MinPartials creates a new MinPartials instance.
MinValue - Class in cascading.operation.aggregator
Class Min is an Aggregator that returns the minimum value encountered in the current group.
MinValue() - Constructor for class cascading.operation.aggregator.MinValue
Constructs a new instance that returns the Min value encountered in the field name "min".
MinValue(Fields) - Constructor for class cascading.operation.aggregator.MinValue
Constructs a new instance that returns the minimum value encountered in the given fieldDeclaration field name.
MinValue(Fields, Object...) - Constructor for class cascading.operation.aggregator.MinValue
Constructs a new instance that returns the minimum value encountered in the given fieldDeclaration field name.
MissingGroupAssert - Class in cascading.flow.planner.rule.assertion
 
MissingGroupAssert() - Constructor for class cascading.flow.planner.rule.assertion.MissingGroupAssert
 
MissingGroupExpression - Class in cascading.flow.planner.rule.expression
 
MissingGroupExpression() - Constructor for class cascading.flow.planner.rule.expression.MissingGroupExpression
 
MixedJoin - Class in cascading.pipe.joiner
Class MixedJoin will return an Iterator that will iterate over a given Joiner and return tuples that represent a join as defined by the given boolean array.
MixedJoin(boolean[]) - Constructor for class cascading.pipe.joiner.MixedJoin
Constructor MixedJoin creates a new MixedJoin instance.
MixedJoin(Fields, boolean[]) - Constructor for class cascading.pipe.joiner.MixedJoin
 
MixedJoin.JoinIterator - Class in cascading.pipe.joiner
 
MixedJoin.JoinIterator(JoinerClosure) - Constructor for class cascading.pipe.joiner.MixedJoin.JoinIterator
 
mixH1(int, int) - Static method in class cascading.util.Murmur3
 
mixK1(int) - Static method in class cascading.util.Murmur3
 
MultiMap<C extends Collection<V>,K,V> - Class in cascading.util
 
MultiMap() - Constructor for class cascading.util.MultiMap
 
MultiSinkTap<Child extends Tap,Config,Output> - Class in cascading.tap
Class MultiSinkTap is both a CompositeTap and SinkTap that can write to multiple child Tap instances simultaneously.
MultiSinkTap(Child...) - Constructor for class cascading.tap.MultiSinkTap
Constructor MultiSinkTap creates a new MultiSinkTap instance.
MultiSourceTap<Child extends Tap,Config,Input> - Class in cascading.tap
Class MultiSourceTap is used to tie multiple Tap instances into a single resource.
MultiSourceTap(Scheme<Config, Input, ?, ?, ?>) - Constructor for class cascading.tap.MultiSourceTap
 
MultiSourceTap(Child...) - Constructor for class cascading.tap.MultiSourceTap
Constructor MultiSourceTap creates a new MultiSourceTap instance.
MultiTapGroupExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
MultiTapGroupExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.MultiTapGroupExpressionGraph
 
Murmur3 - Class in cascading.util
Murmur3 is a fast non cryptographic hash algorithm.
Murmur3() - Constructor for class cascading.util.Murmur3
 
MutateGraphTransformer - Class in cascading.flow.planner.iso.transformer
 
MutateGraphTransformer(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.MutateGraphTransformer
 
MutateGraphTransformer(GraphTransformer, ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.MutateGraphTransformer
 

N

name - Variable in class cascading.CascadingTestCase
 
name - Variable in class cascading.flow.planner.PlannerInfo
 
name - Variable in class cascading.flow.planner.PlatformInfo
 
name - Variable in class cascading.pipe.Pipe
Field name
name - Variable in class cascading.property.AppProps
 
name - Variable in class cascading.property.UnitOfWorkDef
 
name - Variable in class cascading.stats.CascadingStats
Field name
named(String, Pipe...) - Static method in class cascading.pipe.Pipe
 
names(Pipe...) - Static method in class cascading.pipe.Pipe
Convenience method for finding all Pipe names in an assembly.
names(Comparable...) - Static method in class cascading.tuple.Fields
 
narrowIdentitySet(Class<T>, Collection) - Static method in class cascading.util.Util
 
narrowIdentitySet(Class<T>, Collection, boolean) - Static method in class cascading.util.Util
 
narrowIdentitySet(Class<T>, Iterator) - Static method in class cascading.util.Util
 
narrowIdentitySet(Class<T>, Iterator, boolean) - Static method in class cascading.util.Util
 
narrowSet(Class<T>, Collection) - Static method in class cascading.util.Util
 
narrowSet(Class<T>, Collection, boolean) - Static method in class cascading.util.Util
 
narrowSet(Class<T>, Iterator) - Static method in class cascading.util.Util
 
narrowSet(Class<T>, Iterator, boolean) - Static method in class cascading.util.Util
 
negateMatch - Variable in class cascading.operation.regex.RegexMatcher
 
newConfig(Config) - Method in class cascading.flow.BaseFlow
 
newConfig(Config) - Method in class cascading.flow.process.ProcessFlow
 
newInstance(String) - Method in class cascading.flow.FlowProcess
Method newInstance creates a new object instance from the given className argument delegating to any platform specific instantiation and configuration routines.
newInstance(String) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
newInstance(String) - Method in class cascading.flow.FlowProcessWrapper
 
newInstance(String, Object...) - Static method in class cascading.util.Util
 
newInstance(Class<T>, Object...) - Static method in class cascading.util.Util
 
next() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
next() - Method in class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
next() - Method in class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
next - Variable in class cascading.flow.stream.duct.Duct
 
next() - Method in class cascading.pipe.joiner.InnerJoin.JoinIterator
 
next() - Method in class cascading.tap.partition.PartitionTupleEntryIterator
 
next() - Method in class cascading.tuple.TupleChainIterator
Method next returns the next TupleEntry.
next() - Method in class cascading.tuple.TupleEntryChainIterator
Method next returns the next TupleEntry.
next() - Method in class cascading.tuple.TupleEntryIterableChainIterator
Method next returns the next TupleEntry.
next() - Method in class cascading.tuple.TupleEntrySchemeIterator
 
next() - Method in class cascading.util.ForeverValueIterator
 
next() - Method in class cascading.util.SingleValueIterator
 
NoCoGroupJoinTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoCoGroupJoinTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoCoGroupJoinTapExpressionGraph
 
node - Variable in class cascading.flow.stream.graph.NodeStreamGraph
 
NODE_COUNTER_MAX_AGE_PROPERTY - Static variable in class cascading.stats.CounterCache
 
nodeConfigDef - Variable in class cascading.pipe.Pipe
 
NodeStreamGraph - Class in cascading.flow.stream.graph
 
NodeStreamGraph(FlowProcess, FlowNode) - Constructor for class cascading.flow.stream.graph.NodeStreamGraph
 
NodeStreamGraph(FlowProcess, FlowNode, FlowElement) - Constructor for class cascading.flow.stream.graph.NodeStreamGraph
 
nodeSubGraph - Variable in class cascading.flow.planner.BaseFlowNode
 
NoGroupJoinMergeBoundaryTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoGroupJoinMergeBoundaryTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoGroupJoinMergeBoundaryTapExpressionGraph
 
NoGroupJoinTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoGroupJoinTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoGroupJoinTapExpressionGraph
 
NoGroupMergeTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoGroupMergeTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoGroupMergeTapExpressionGraph
 
NoGroupTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoGroupTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoGroupTapExpressionGraph
 
NoMergeTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoMergeTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoMergeTapExpressionGraph
 
NON_BLOCKING - Static variable in class cascading.flow.planner.iso.expression.PathScopeExpression
 
NonBlockedBlockedJoinAnnotatorExpression - Class in cascading.flow.planner.rule.expression
 
NonBlockedBlockedJoinAnnotatorExpression() - Constructor for class cascading.flow.planner.rule.expression.NonBlockedBlockedJoinAnnotatorExpression
 
NonBlockedBlockedJoinExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NonBlockedBlockedJoinExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NonBlockedBlockedJoinExpressionGraph
 
NonBlockedBlockedJoinJoinAnnotatorExpression - Class in cascading.flow.planner.rule.expression
 
NonBlockedBlockedJoinJoinAnnotatorExpression() - Constructor for class cascading.flow.planner.rule.expression.NonBlockedBlockedJoinJoinAnnotatorExpression
 
NonBlockedBlockedJoinJoinExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NonBlockedBlockedJoinJoinExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NonBlockedBlockedJoinJoinExpressionGraph
 
NONE - Static variable in class cascading.tuple.Fields
Field NONE represents a wildcard for no fields
NonSafeAndSplitAndSyncPipeExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NonSafeAndSplitAndSyncPipeExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NonSafeAndSplitAndSyncPipeExpressionGraph
 
NonSafeOperationExpression - Class in cascading.flow.planner.iso.expression
 
NonSafeOperationExpression(ElementCapture) - Constructor for class cascading.flow.planner.iso.expression.NonSafeOperationExpression
 
NonSafeOperationExpression(TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.NonSafeOperationExpression
 
NonSafeOperationExpression() - Constructor for class cascading.flow.planner.iso.expression.NonSafeOperationExpression
 
NoOp - Class in cascading.operation
Class NoOp does nothing.
NoOp() - Constructor for class cascading.operation.NoOp
Constructor NoOp creates a new NoOp instance that will ignore the argument values and return no output.
NoOpPipeExpression - Class in cascading.flow.planner.rule.expression
 
NoOpPipeExpression() - Constructor for class cascading.flow.planner.rule.expression.NoOpPipeExpression
 
NoOpPipeExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
NoOpPipeExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.NoOpPipeExpressionGraph
 
normalizeUrl(String) - Static method in class cascading.util.Util
This method attempts to remove duplicate consecutive forward slashes from the given url.
not(ElementExpression) - Static method in class cascading.flow.planner.iso.expression.NotElementExpression
 
Not - Class in cascading.operation.filter
Class Not is a Filter class that will logically 'not' (negation) the results of the constructor provided Filter instance.
Not(Filter) - Constructor for class cascading.operation.filter.Not
Constructor Not creates a new Not instance.
NOT_ORDINAL_ZERO - Static variable in class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
NotElementExpression - Class in cascading.flow.planner.iso.expression
 
NotElementExpression(ElementExpression) - Constructor for class cascading.flow.planner.iso.expression.NotElementExpression
 
notify(CascadingStats, CascadingStats.Status, CascadingStats.Status) - Method in interface cascading.stats.StatsListener
 
notifyReadSpillBegin(Spillable) - Method in interface cascading.tuple.collect.Spillable.SpillListener
 
notifyWriteSpillBegin(Spillable, int, String) - Method in interface cascading.tuple.collect.Spillable.SpillListener
 
notifyWriteSpillEnd(SpillableTupleList, long) - Method in interface cascading.tuple.collect.Spillable.SpillListener
 
NULL - Static variable in class cascading.flow.FlowProcess
Field NULL is a noop implementation of FlowSession.
NULL - Static variable in class cascading.flow.FlowSession
Field NULL is a noop implementation of FlowSession.
NULL - Static variable in class cascading.flow.planner.graph.BaseElementGraph
 
NULL - Static variable in class cascading.flow.planner.PlannerContext
 
NULL - Static variable in class cascading.flow.planner.PlannerInfo
 
NULL - Static variable in class cascading.flow.planner.PlatformInfo
 
NULL - Static variable in class cascading.management.state.ClientState
 
NULL - Static variable in interface cascading.tuple.collect.Spillable.SpillListener
 
NULL - Static variable in class cascading.tuple.io.KeyTuple
A constant empty Tuple instance.
NULL - Static variable in class cascading.tuple.io.ValueTuple
A constant empty Tuple instance.
NULL - Static variable in class cascading.tuple.Tuple
A constant empty Tuple instance.
NULL - Static variable in class cascading.tuple.TupleEntry
An EMPTY TupleEntry instance for use as a stand in instead of a null.
NULL - Static variable in interface cascading.util.cache.CacheEvictionCallback
NO-OP implementation of CacheEvictionCallback.
NULL - Static variable in interface cascading.util.ProcessLogger
 
nulledCopy(TupleEntry, Fields) - Static method in class cascading.tuple.Tuples
 
nulledCopy(Fields, Tuple, Fields) - Static method in class cascading.tuple.Tuples
 
NullNotEquivalentComparator - Class in cascading.util
Class NullNotEquivalentComparator simply returns -1 if the lhs is null, 1 if the rhs is null, or the result of lhs.compareTo(rhs).
NullNotEquivalentComparator() - Constructor for class cascading.util.NullNotEquivalentComparator
 
nullsAreNotEqual - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
NullScheme<Config,Input,Output,SourceContext,SinkContext> - Class in cascading.scheme
Class NullScheme is a Scheme that neither reads or writes any values.
NullScheme() - Constructor for class cascading.scheme.NullScheme
 
NullScheme(Fields, Fields) - Constructor for class cascading.scheme.NullScheme
 
numArgs - Variable in class cascading.operation.BaseOperation
Field numArgs
numIncomingEventingPaths - Variable in class cascading.flow.stream.element.MemorySpliceGate
 
numJoins() - Method in class cascading.pipe.joiner.BufferJoin
 
numJoins() - Method in class cascading.pipe.joiner.InnerJoin
 
numJoins() - Method in interface cascading.pipe.joiner.Joiner
Returns the number of joins this instance can handle.
numJoins() - Method in class cascading.pipe.joiner.LeftJoin
 
numJoins() - Method in class cascading.pipe.joiner.MixedJoin
 
numJoins() - Method in class cascading.pipe.joiner.OuterJoin
 
numJoins() - Method in class cascading.pipe.joiner.RightJoin
 
numValues - Variable in class cascading.scheme.util.DelimitedParser
Field numValues

O

OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
ObjectCoerce - Class in cascading.tuple.coerce
 
ObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.ObjectCoerce
 
offsetSelector(int, int) - Static method in class cascading.tuple.Fields
Method offsetSelector is a factory that makes new instances of Fields the given size but offset by startPos.
onCompleted(Cascade) - Method in interface cascading.cascade.CascadeListener
The onCompleted event is fired when a Cascade instance has completed all work whether if was success or failed.
onCompleted(Flow) - Method in interface cascading.flow.FlowListener
The onCompleted event is fired when a Flow instance has completed all work whether if was success or failed.
onlyParseLine(String) - Method in class cascading.scheme.util.DelimitedParser
 
OnlyPipeExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
OnlyPipeExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.OnlyPipeExpressionGraph
 
onStarting(Cascade) - Method in interface cascading.cascade.CascadeListener
The onStarting event is fired when a Cascade instance receives the start() message.
onStarting(Flow) - Method in interface cascading.flow.FlowListener
The onStarting event is fired when a Flow instance receives the start() message.
onStepCompleted(FlowStep) - Method in interface cascading.flow.FlowStepListener
The onStepCompleted event is fired when a flowStepJob completed its work
onStepRunning(FlowStep) - Method in interface cascading.flow.FlowStepListener
The onStepRunning event is fired when a given FlowStep moves into the running state
onStepStarting(FlowStep) - Method in interface cascading.flow.FlowStepListener
The onStarting event is fired when a given FlowStep job has been submitted i.e.
onStepStopping(FlowStep) - Method in interface cascading.flow.FlowStepListener
The onStepStopping event is fired when a given FlowStep job is stopped
onStepThrowable(FlowStep, Throwable) - Method in interface cascading.flow.FlowStepListener
The onStepThrowable event is fired if a given FlowStep throws a Throwable type.
onStopping(Cascade) - Method in interface cascading.cascade.CascadeListener
The onStopping event is fired when a Cascade instance receives the stop() message.
onStopping(Flow) - Method in interface cascading.flow.FlowListener
The onStopping event is fired when a Flow instance receives the stop() message.
onThrowable(Cascade, Throwable) - Method in interface cascading.cascade.CascadeListener
The onThrowable event is fired if any child Flow throws a Throwable type.
onThrowable(Flow, Throwable) - Method in interface cascading.flow.FlowListener
The onThrowable event is fired if any child FlowStep throws a Throwable type.
OPEN_WRITES_THRESHOLD_DEFAULT - Static variable in class cascading.tap.partition.BasePartitionTap
Field OPEN_FILES_THRESHOLD_DEFAULT
OpenDuct<Incoming,Outgoing> - Class in cascading.flow.stream.duct
 
OpenDuct(Duct<Outgoing, ?>) - Constructor for class cascading.flow.stream.duct.OpenDuct
 
openForRead(FlowProcess<? extends Config>, Input) - Method in class cascading.tap.DecoratorTap
 
openForRead(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
openForRead(FlowProcess<? extends Config>, Input) - Method in class cascading.tap.MultiSourceTap
 
openForRead(FlowProcess<? extends Config>, Input) - Method in class cascading.tap.partition.BasePartitionTap
 
openForRead(FlowProcess<? extends Config>, Void) - Method in class cascading.tap.SinkTap
 
openForRead(FlowProcess<? extends Config>, Input) - Method in class cascading.tap.Tap
Method openForRead opens the resource represented by this Tap instance for reading.
openForRead(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method openForRead opens the resource represented by this Tap instance for reading.
openForWrite(FlowProcess<? extends Config>, Output) - Method in class cascading.tap.DecoratorTap
 
openForWrite(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
openForWrite(FlowProcess<? extends Config>, Output) - Method in class cascading.tap.MultiSinkTap
 
openForWrite(FlowProcess<? extends Config>, Output) - Method in class cascading.tap.partition.BasePartitionTap
 
openForWrite(FlowProcess<? extends Config>, Void) - Method in class cascading.tap.SourceTap
 
openForWrite(FlowProcess<? extends Config>, Output) - Method in class cascading.tap.Tap
Method openForWrite opens the resource represented by this Tap instance for writing.
openForWrite(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method openForWrite opens the resource represented by this Tap instance for writing.
OpenReducingDuct<Incoming,Outgoing> - Class in cascading.flow.stream.duct
 
OpenReducingDuct(Duct<Outgoing, ?>) - Constructor for class cascading.flow.stream.duct.OpenReducingDuct
 
openSink() - Method in class cascading.flow.BaseFlow
 
openSink(String) - Method in class cascading.flow.BaseFlow
 
openSink() - Method in interface cascading.flow.Flow
Method openSink opens the first sink Tap.
openSink(String) - Method in interface cascading.flow.Flow
Method openSink opens the named sink Tap.
openSource() - Method in class cascading.flow.BaseFlow
 
openSource(String) - Method in class cascading.flow.BaseFlow
 
openSource() - Method in interface cascading.flow.Flow
Method openSource opens the first source Tap.
openSource(String) - Method in interface cascading.flow.Flow
Method openSource opens the named source Tap.
openSystemIntermediateForWrite() - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
openSystemIntermediateForWrite() - Method in class cascading.flow.FlowProcess
 
openSystemIntermediateForWrite() - Method in class cascading.flow.FlowProcessWrapper
 
openTapForRead(Tap) - Method in class cascading.flow.BaseFlow
 
openTapForRead(Tap) - Method in interface cascading.flow.Flow
Method openTapForRead return a TupleEntryIterator for the given Tap instance.
openTapForRead(Tap) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
openTapForRead(Tap) - Method in class cascading.flow.FlowProcess
Method openTapForRead return a TupleEntryIterator for the given Tap instance.
openTapForRead(Tap) - Method in class cascading.flow.FlowProcessWrapper
 
openTapForWrite(Tap) - Method in class cascading.flow.BaseFlow
 
openTapForWrite(Tap) - Method in interface cascading.flow.Flow
Method openTapForWrite returns a (@link TupleCollector} for the given Tap instance.
openTapForWrite(Tap) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
openTapForWrite(Tap) - Method in class cascading.flow.FlowProcess
Method openTapForWrite returns a (@link TupleCollector} for the given Tap instance.
openTapForWrite(Tap) - Method in class cascading.flow.FlowProcessWrapper
 
openTrap() - Method in class cascading.flow.BaseFlow
 
openTrap(String) - Method in class cascading.flow.BaseFlow
 
openTrap() - Method in interface cascading.flow.Flow
Method openTrap opens the first trap Tap.
openTrap(String) - Method in interface cascading.flow.Flow
Method openTrap opens the named trap Tap.
openTrapForWrite(Tap) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
openTrapForWrite(Tap) - Method in class cascading.flow.FlowProcess
Method openTrapForWrite returns a (@link TupleCollector} for the given Tap instance.
openTrapForWrite(Tap) - Method in class cascading.flow.FlowProcessWrapper
 
OpenWindow - Interface in cascading.flow.stream.duct
 
openWritesThreshold - Variable in class cascading.tap.partition.BasePartitionTap
Field openTapsThreshold
operate(FlowProcess, BufferCall) - Method in class cascading.operation.buffer.FirstNBuffer
 
operate(FlowProcess, BufferCall<Context>) - Method in interface cascading.operation.Buffer
Method operate is called once for each grouping.
operate(FlowProcess, FunctionCall<Context>) - Method in interface cascading.operation.Function
Method operate provides the implementation of this Function.
operate(FlowProcess, FunctionCall) - Method in class cascading.operation.function.SetValue
 
operate(FlowProcess, FunctionCall) - Method in class cascading.operation.function.UnGroup
 
operate(FlowProcess, FunctionCall<Identity.Functor>) - Method in class cascading.operation.Identity
 
operate(FlowProcess, FunctionCall) - Method in class cascading.operation.Insert
 
operate(FlowProcess, FunctionCall) - Method in class cascading.operation.NoOp
 
operate(FlowProcess, FunctionCall<Pair<Matcher, Tuple>>) - Method in class cascading.operation.regex.RegexGenerator
 
operate(FlowProcess, FunctionCall<Pair<Matcher, Tuple>>) - Method in class cascading.operation.regex.RegexParser
 
operate(FlowProcess, FunctionCall<Pair<Matcher, Tuple>>) - Method in class cascading.operation.regex.RegexReplace
 
operate(FlowProcess, FunctionCall<Pair<Pattern, Tuple>>) - Method in class cascading.operation.regex.RegexSplitGenerator
 
operate(FlowProcess, FunctionCall<Pair<Pattern, Tuple>>) - Method in class cascading.operation.regex.RegexSplitter
 
operate(FlowProcess, FunctionCall<Pair<SimpleDateFormat, Tuple>>) - Method in class cascading.operation.text.DateFormatter
 
operate(FlowProcess, FunctionCall<Pair<SimpleDateFormat, Tuple>>) - Method in class cascading.operation.text.DateParser
 
operate(FlowProcess, FunctionCall<Tuple>) - Method in class cascading.operation.text.FieldFormatter
 
operate(FlowProcess, FunctionCall<Tuple>) - Method in class cascading.operation.text.FieldJoiner
 
operate(FlowProcess, FunctionCall<AggregateBy.CompositeFunction.Context>) - Method in class cascading.pipe.assembly.AggregateBy.CompositeFunction
 
operate() - Method in interface cascading.util.Util.RetryOperator
 
Operation<Context> - Interface in cascading.operation
Interface Operation is the base interface for all functions applied to Tuple streams.
operation - Variable in class cascading.pipe.Operator
Field operation
operationCall - Variable in class cascading.flow.stream.element.OperatorStage
 
OperationCall<Context> - Interface in cascading.operation
 
OperationException - Exception in cascading.operation
Class OperationException is thrown by BaseOperation classes.
OperationException() - Constructor for exception cascading.operation.OperationException
Constructor OperationException creates a new OperationException instance.
OperationException(String) - Constructor for exception cascading.operation.OperationException
Constructor OperationException creates a new OperationException instance.
OperationException(String, Throwable) - Constructor for exception cascading.operation.OperationException
Constructor OperationException creates a new OperationException instance.
OperationException(Throwable) - Constructor for exception cascading.operation.OperationException
Constructor OperationException creates a new OperationException instance.
OperationExpression - Class in cascading.flow.planner.iso.expression
 
OperationExpression(ElementCapture, boolean, Class<? extends Operation>) - Constructor for class cascading.flow.planner.iso.expression.OperationExpression
 
OperationExpression(ElementCapture, Class<? extends Operation>) - Constructor for class cascading.flow.planner.iso.expression.OperationExpression
 
OperationExpression(boolean, Class<? extends Operation>) - Constructor for class cascading.flow.planner.iso.expression.OperationExpression
 
OperationExpression(Class<? extends Operation>) - Constructor for class cascading.flow.planner.iso.expression.OperationExpression
 
Operator - Class in cascading.pipe
An Operator is a type of Pipe.
Operator(Operation) - Constructor for class cascading.pipe.Operator
 
Operator(String, Operation) - Constructor for class cascading.pipe.Operator
 
Operator(String, Operation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(String, Fields, Operation) - Constructor for class cascading.pipe.Operator
 
Operator(String, Fields, Operation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(Pipe, Operation) - Constructor for class cascading.pipe.Operator
 
Operator(Pipe, Fields, Operation) - Constructor for class cascading.pipe.Operator
 
Operator(Pipe, Fields, Operation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(Pipe, Operation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(String, PlannerLevel, PlannedOperation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(String, Fields, PlannerLevel, PlannedOperation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(Pipe, PlannerLevel, PlannedOperation, Fields) - Constructor for class cascading.pipe.Operator
 
Operator(Pipe, Fields, PlannerLevel, PlannedOperation, Fields) - Constructor for class cascading.pipe.Operator
 
OperatorException - Exception in cascading.pipe
Class OperatorException is thrown during field name resolution during planning
OperatorException() - Constructor for exception cascading.pipe.OperatorException
 
OperatorException(Pipe, String) - Constructor for exception cascading.pipe.OperatorException
Constructor OperatorException creates a new OperatorException instance.
OperatorException(Pipe, String, Throwable) - Constructor for exception cascading.pipe.OperatorException
Constructor OperatorException creates a new OperatorException instance.
OperatorException(String) - Constructor for exception cascading.pipe.OperatorException
 
OperatorException(String, Throwable) - Constructor for exception cascading.pipe.OperatorException
 
OperatorException(Throwable) - Constructor for exception cascading.pipe.OperatorException
 
OperatorException(Pipe, Fields, Fields, Fields, Throwable) - Constructor for exception cascading.pipe.OperatorException
Constructor OperatorException creates a new OperatorException instance.
OperatorException(Pipe, OperatorException.Kind, Fields, Fields, Throwable) - Constructor for exception cascading.pipe.OperatorException
Constructor OperatorException creates a new OperatorException instance.
OperatorStage<Incoming> - Class in cascading.flow.stream.element
 
OperatorStage(FlowProcess, FlowElement) - Constructor for class cascading.flow.stream.element.OperatorStage
 
or(ElementExpression...) - Static method in class cascading.flow.planner.iso.expression.OrElementExpression
 
or(ElementCapture, ElementExpression...) - Static method in class cascading.flow.planner.iso.expression.OrElementExpression
 
Or - Class in cascading.operation.filter
Class Or is a Filter class that will logically 'or' the results of the constructor provided Filter instances.
Or(Filter...) - Constructor for class cascading.operation.filter.Or
Constructor Or creates a new Or instance where all Filter instances receive all arguments.
Or(Fields, Filter, Fields, Filter) - Constructor for class cascading.operation.filter.Or
Constructor Or creates a new Or instance.
Or(Fields[], Filter[]) - Constructor for class cascading.operation.filter.Or
Constructor Or creates a new Or instance.
ORANGE - Static variable in class cascading.flow.planner.rule.util.TraceWriter
 
Order - Enum in cascading.management.annotation
Order describes the order in which Property annotations shall be displayed.
OrderedHashMapCache<Key,Value> - Class in cascading.util.cache
Implementation of the CascadingCache interface backed by a LinkedHashMap.
OrderedHashMapCache() - Constructor for class cascading.util.cache.OrderedHashMapCache
 
OrderedHashMapCacheFactory - Class in cascading.util.cache
Concrete sub-class of BaseCacheFactory for creating OrderedHashMapCache instances.
OrderedHashMapCacheFactory() - Constructor for class cascading.util.cache.OrderedHashMapCacheFactory
 
ordinal - Variable in class cascading.flow.stream.duct.Duct
 
ORDINAL_ZERO - Static variable in class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
ordinalBetween(Duct, Duct) - Method in class cascading.flow.stream.graph.StreamGraph
 
ordinalMap - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
OrdinalScopeExpression - Class in cascading.flow.planner.iso.expression
 
OrdinalScopeExpression(int) - Constructor for class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
OrdinalScopeExpression(ScopeExpression.Applies, int) - Constructor for class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
OrdinalScopeExpression(boolean, int) - Constructor for class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
OrdinalScopeExpression(ScopeExpression.Applies, boolean, int) - Constructor for class cascading.flow.planner.iso.expression.OrdinalScopeExpression
 
OrElementExpression - Class in cascading.flow.planner.iso.expression
 
OrElementExpression(ElementExpression...) - Constructor for class cascading.flow.planner.iso.expression.OrElementExpression
 
OrElementExpression(ElementCapture, ElementExpression...) - Constructor for class cascading.flow.planner.iso.expression.OrElementExpression
 
original - Variable in class cascading.tap.DecoratorTap
 
outDegreeOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
outDegreeOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
outDegreeOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
outDegreeOf(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
outDegreeOf(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
OUTER - Static variable in class cascading.pipe.joiner.MixedJoin
Field OUTER
OuterJoin - Class in cascading.pipe.joiner
Class OuterJoin will return an Iterator that will iterate over a given Joiner and return tuples that represent and outer join of the CoGrouper internal grouped tuple collections.
OuterJoin() - Constructor for class cascading.pipe.joiner.OuterJoin
 
OuterJoin(Fields) - Constructor for class cascading.pipe.joiner.OuterJoin
 
OuterJoin.JoinIterator - Class in cascading.pipe.joiner
 
OuterJoin.JoinIterator(JoinerClosure) - Constructor for class cascading.pipe.joiner.OuterJoin.JoinIterator
 
outgoingBuilder - Variable in class cascading.flow.stream.element.OperatorStage
 
outgoingEdgesOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
outgoingEdgesOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
outgoingEdgesOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
outgoingEdgesOf(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
outgoingEdgesOf(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
outgoingEntry - Variable in class cascading.flow.stream.element.OperatorStage
 
outgoingScopeFor(Set<Scope>) - Method in interface cascading.flow.planner.ScopedElement
Method outgoingScopeFor returns the Scope this FlowElement hands off to the next FlowElement.
outgoingScopeFor(Set<Scope>) - Method in class cascading.pipe.Each
 
outgoingScopeFor(Set<Scope>) - Method in class cascading.pipe.Every
 
outgoingScopeFor(Set<Scope>) - Method in class cascading.pipe.Operator
 
outgoingScopeFor(Set<Scope>) - Method in class cascading.pipe.Pipe
 
outgoingScopeFor(Set<Scope>) - Method in class cascading.pipe.Splice
 
outgoingScopeFor(Set<Scope>) - Method in class cascading.tap.DecoratorTap
 
outgoingScopeFor(Set<Scope>) - Method in class cascading.tap.Tap
 
outgoingScopes - Variable in class cascading.flow.stream.element.BoundaryStage
 
outgoingScopes - Variable in class cascading.flow.stream.element.ElementStage
 
outgoingScopes - Variable in class cascading.flow.stream.element.SpliceGate
 
outgoingSelector - Variable in class cascading.flow.stream.element.OperatorStage
 
outputCollector - Variable in class cascading.flow.stream.element.OperatorStage
 
outputSelector - Variable in class cascading.pipe.Operator
Field outputSelector

P

pair(int, int) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
Pair<Lhs,Rhs> - Class in cascading.util
 
Pair(Lhs, Rhs) - Constructor for class cascading.util.Pair
 
PARAMETER_FILTER_PROPERTY - Static variable in class cascading.management.annotation.URISanitizer
System property for listing URI parameters to be filtered out (usernames, passwords etc.)

Value cases are ignored, thus UserName will be equivalent to username.

parent(ProcessLevel) - Static method in enum cascading.flow.planner.rule.ProcessLevel
 
parent - Variable in class cascading.pipe.Pipe
Field parent
parent - Variable in class cascading.tap.partition.BasePartitionTap
Field parent
parseFirstLine(FlowProcess, Tap) - Method in class cascading.scheme.util.DelimitedParser
 
parseHostname(String) - Static method in class cascading.util.Util
 
parseLine(String) - Method in class cascading.scheme.util.DelimitedParser
 
partition(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.subgraph.GraphPartitioner
 
partition(PlannerContext, ElementGraph, Collection<FlowElement>) - Method in class cascading.flow.planner.iso.subgraph.GraphPartitioner
 
partition(PlannerContext, ElementGraph, Collection<FlowElement>) - Method in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
partition(PlannerContext, ElementGraph, Collection<FlowElement>) - Method in class cascading.flow.planner.iso.subgraph.partitioner.WholeGraphPartitioner
 
partition(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.rule.RulePartitioner
 
partition(PlannerContext, ElementGraph, Collection<FlowElement>) - Method in class cascading.flow.planner.rule.RulePartitioner
 
partition - Variable in class cascading.tap.partition.BasePartitionTap
Field partition
Partition - Interface in cascading.tap.partition
The Partition interface allows for custom partitioning mechanisms to be created with the BasePartitionTap sub-classes.
Partitions - Class in cascading.flow.planner.iso.subgraph
 
Partitions(GraphPartitioner, ElementGraph, Map<ElementGraph, EnumMultiMap>) - Constructor for class cascading.flow.planner.iso.subgraph.Partitions
 
Partitions(GraphPartitioner, ElementGraph, ElementGraph, List<Match>, Map<ElementGraph, EnumMultiMap>) - Constructor for class cascading.flow.planner.iso.subgraph.Partitions
 
partitionSource - Variable in class cascading.flow.planner.rule.RulePartitioner
 
PartitionTapProps - Class in cascading.tap.partition
Class PartitionTapProps is a fluent helper class to set properties which control the behaviour of the BasePartitionTap.
PartitionTapProps() - Constructor for class cascading.tap.partition.PartitionTapProps
Constructs a new PartitionTapProps instance.
partitionTapProps() - Static method in class cascading.tap.partition.PartitionTapProps
Creates a new PartitionTapProps instance.
PartitionTupleEntryIterator - Class in cascading.tap.partition
 
PartitionTupleEntryIterator(Fields, Partition, String, String, TupleEntrySchemeIterator) - Constructor for class cascading.tap.partition.PartitionTupleEntryIterator
 
PATH_DELIM - Static variable in class cascading.tap.partition.DelimitedPartition
 
PathScopeExpression - Class in cascading.flow.planner.iso.expression
All is a special case allowing allowing a node-node match with any number of edges
PathScopeExpression() - Constructor for class cascading.flow.planner.iso.expression.PathScopeExpression
 
PathScopeExpression(ScopeExpression.Applies) - Constructor for class cascading.flow.planner.iso.expression.PathScopeExpression
 
PathScopeExpression(PathScopeExpression.Mode) - Constructor for class cascading.flow.planner.iso.expression.PathScopeExpression
 
PathScopeExpression(ScopeExpression.Applies, PathScopeExpression.Mode) - Constructor for class cascading.flow.planner.iso.expression.PathScopeExpression
 
PathScopeExpression.Mode - Enum in cascading.flow.planner.iso.expression
 
patternString - Variable in class cascading.operation.assertion.AssertGroupBase
Field patternString
patternString - Variable in class cascading.operation.regex.RegexOperation
Field patternString
pendingTime - Variable in class cascading.stats.CascadingStats
Field pendingTime
performMutation(PlannerContext, RuleResult, PlanPhase, Rule) - Method in class cascading.flow.planner.rule.RuleExec
 
performOperation(Tuple[], TupleEntry) - Method in class cascading.operation.aggregator.ExtentBase
 
performOperation(Tuple[], TupleEntry) - Method in class cascading.operation.aggregator.First
 
performOperation(Tuple[], TupleEntry) - Method in class cascading.operation.aggregator.Last
 
PERMITTED_EXCEPTIONS - Static variable in class cascading.tuple.TupleEntrySchemeIteratorProps
 
phase - Variable in class cascading.flow.planner.rule.RulePartitioner
 
Pipe - Class in cascading.pipe
Class Pipe is used to name branches in pipe assemblies, and as a base class for core processing model types, specifically Each, Every, GroupBy, CoGroup, Merge, HashJoin, and SubAssembly.
Pipe() - Constructor for class cascading.pipe.Pipe
 
Pipe(Pipe) - Constructor for class cascading.pipe.Pipe
 
Pipe(String) - Constructor for class cascading.pipe.Pipe
Constructor Pipe creates a new Pipe instance with the given name.
Pipe(String, Pipe) - Constructor for class cascading.pipe.Pipe
Constructor Pipe creates a new Pipe instance with the given name and previous Pipe instance.
pipelineGraphs - Variable in class cascading.flow.planner.BaseFlowNode
 
pipes(Pipe...) - Static method in class cascading.pipe.Pipe
Convenience method to create an array of Pipe instances.
PlannedOperation<Context> - Interface in cascading.operation
Interface PlannedOperation is implemented by all Operation implementations that use a PlannerLevel value to inform the FlowPlanner how to treat the operation during job planning.
PlannerContext - Class in cascading.flow.planner
 
PlannerContext() - Constructor for class cascading.flow.planner.PlannerContext
 
PlannerContext(RuleRegistry) - Constructor for class cascading.flow.planner.PlannerContext
 
PlannerContext(RuleRegistry, FlowPlanner, FlowDef, Flow, boolean) - Constructor for class cascading.flow.planner.PlannerContext
 
PlannerException - Exception in cascading.flow.planner
Class PlannerException is thrown when a job planner fails.
PlannerException() - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(FlowElement, String) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(FlowElement, String, Throwable) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(FlowElement, String, Throwable, ElementGraph) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(String) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(String, Throwable) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(Throwable) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(String, ElementGraph) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(String, Throwable, ElementGraph) - Constructor for exception cascading.flow.planner.PlannerException
Constructor PlannerException creates a new PlannerException instance.
PlannerException(Rule, Exception) - Constructor for exception cascading.flow.planner.PlannerException
 
PlannerException(PlanPhase, Rule, Throwable) - Constructor for exception cascading.flow.planner.PlannerException
 
PlannerException(PlanPhase, Rule, ElementGraph, Throwable) - Constructor for exception cascading.flow.planner.PlannerException
 
PlannerException(RuleRegistry, PlanPhase, Rule, Throwable) - Constructor for exception cascading.flow.planner.PlannerException
 
PlannerException(RuleRegistry, PlanPhase, Rule, ElementGraph, Throwable) - Constructor for exception cascading.flow.planner.PlannerException
 
PlannerInfo - Class in cascading.flow.planner
 
PlannerInfo(String, String, String) - Constructor for class cascading.flow.planner.PlannerInfo
 
PlannerLevel - Interface in cascading.operation
Interface PlannerLevel is the base interface for DebugLevel and AssertionLevel enum types.
plannerLevel - Variable in class cascading.pipe.Operator
Field assertionLevel
PlannerLevelElementExpression - Class in cascading.flow.planner.iso.expression
 
PlannerLevelElementExpression(ElementCapture, Class<? extends PlannerLevel>) - Constructor for class cascading.flow.planner.iso.expression.PlannerLevelElementExpression
 
PlannerLevelExpression - Class in cascading.flow.planner.rule.expression
 
PlannerLevelExpression(Class<? extends PlannerLevel>) - Constructor for class cascading.flow.planner.rule.expression.PlannerLevelExpression
 
PlannerLevelPipeExpressionGraph - Class in cascading.flow.planner.iso.expression
 
PlannerLevelPipeExpressionGraph(Class<? extends PlannerLevel>) - Constructor for class cascading.flow.planner.iso.expression.PlannerLevelPipeExpressionGraph
 
PlanPhase - Enum in cascading.flow.planner.rule
 
planPhases(PlannerContext, boolean, RuleResult) - Method in class cascading.flow.planner.rule.RuleExec
 
platform - Variable in class cascading.flow.planner.PlannerInfo
 
platformInfo - Variable in class cascading.flow.BaseFlow
 
platformInfo - Variable in class cascading.flow.planner.graph.FlowElementGraph
Field platformInfo
PlatformInfo - Class in cascading.flow.planner
 
PlatformInfo(String, String, String) - Constructor for class cascading.flow.planner.PlatformInfo
 
pollFirstEntry() - Method in class cascading.util.SortedListMultiMap
 
pollingInterval - Variable in class cascading.flow.planner.FlowStepJob
Field pollingInterval
predecessorListOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
predecessorListOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
predecessorListOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
predecessorListOf(ProcessGraph<? extends ProcessModel>, ProcessModel) - Static method in class cascading.flow.planner.process.ProcessGraphs
 
predecessors - Variable in class cascading.flow.planner.FlowStepJob
Field predecessors
prepare() - Method in class cascading.cascade.BaseCascade
 
prepare() - Method in class cascading.flow.BaseFlow
 
prepare() - Method in interface cascading.flow.Flow
Method prepare is used by a Cascade to notify the given Flow it should initialize or clear any resources necessary for Flow.start() to be called successfully.
prepare() - Method in class cascading.flow.process.ProcessFlow
 
prepare() - Method in class cascading.flow.stream.duct.Duct
 
prepare() - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
prepare() - Method in class cascading.flow.stream.element.MemorySpliceGate
 
prepare() - Method in class cascading.flow.stream.element.OperatorStage
 
prepare() - Method in class cascading.flow.stream.element.SinkStage
 
prepare() - Method in class cascading.flow.stream.graph.StreamGraph
Calls prepare starting at the tail and working backwards
prepare() - Method in interface cascading.management.UnitOfWork
 
prepare(FlowProcess, OperationCall<Average.Context>) - Method in class cascading.operation.aggregator.Average
 
prepare(FlowProcess, OperationCall<Pair<Long[], Tuple>>) - Method in class cascading.operation.aggregator.Count
 
prepare(FlowProcess, OperationCall<Tuple[]>) - Method in class cascading.operation.aggregator.ExtentBase
 
prepare(FlowProcess, OperationCall<ExtremaValueBase.Context>) - Method in class cascading.operation.aggregator.ExtremaValueBase
 
prepare(FlowProcess, OperationCall<Pair<Double[], Tuple>>) - Method in class cascading.operation.aggregator.Sum
 
prepare(FlowProcess, OperationCall<AssertGroupBase.Context>) - Method in class cascading.operation.assertion.AssertGroupBase
 
prepare(FlowProcess, OperationCall<Context>) - Method in class cascading.operation.BaseOperation
Method prepare does nothing, and may safely be overridden.
prepare(FlowProcess, OperationCall<Long>) - Method in class cascading.operation.Debug
 
prepare(FlowProcess, OperationCall<Limit.Context>) - Method in class cascading.operation.filter.Limit
 
prepare(FlowProcess, OperationCall) - Method in class cascading.operation.filter.Logic
 
prepare(FlowProcess, OperationCall) - Method in class cascading.operation.filter.Not
 
prepare(FlowProcess, OperationCall<Random>) - Method in class cascading.operation.filter.Sample
 
prepare(FlowProcess, OperationCall) - Method in class cascading.operation.function.SetValue
 
prepare(FlowProcess, OperationCall<Identity.Functor>) - Method in class cascading.operation.Identity
 
prepare(FlowProcess, OperationCall<Context>) - Method in interface cascading.operation.Operation
The prepare method is called immediately before the current Operation instance is put into play processing Tuples.
prepare(FlowProcess, OperationCall<Pair<Matcher, Tuple>>) - Method in class cascading.operation.regex.RegexGenerator
 
prepare(FlowProcess, OperationCall<Matcher>) - Method in class cascading.operation.regex.RegexMatcher
 
prepare(FlowProcess, OperationCall<Pair<Matcher, Tuple>>) - Method in class cascading.operation.regex.RegexParser
 
prepare(FlowProcess, OperationCall<Pair<Matcher, Tuple>>) - Method in class cascading.operation.regex.RegexReplace
 
prepare(FlowProcess, OperationCall<Pair<Pattern, Tuple>>) - Method in class cascading.operation.regex.RegexSplitGenerator
 
prepare(FlowProcess, OperationCall<Pair<Pattern, Tuple>>) - Method in class cascading.operation.regex.RegexSplitter
 
prepare(FlowProcess, OperationCall<Boolean>) - Method in class cascading.operation.state.Status
 
prepare(FlowProcess, OperationCall<Pair<SimpleDateFormat, Tuple>>) - Method in class cascading.operation.text.DateOperation
 
prepare(FlowProcess, OperationCall<Tuple>) - Method in class cascading.operation.text.FieldFormatter
 
prepare(FlowProcess, OperationCall<Tuple>) - Method in class cascading.operation.text.FieldJoiner
 
prepare(FlowProcess, OperationCall<AggregateBy.CompositeFunction.Context>) - Method in class cascading.pipe.assembly.AggregateBy.CompositeFunction
 
prepare(FlowProcess, OperationCall<AverageBy.AverageFinal.Context>) - Method in class cascading.pipe.assembly.AverageBy.AverageFinal
 
prepare(FlowProcess, OperationCall<CascadingCache<Tuple, Object>>) - Method in class cascading.pipe.assembly.Unique.FilterPartialDuplicates
 
prepare() - Method in class cascading.stats.CascadingStats
Method prepare initializes this instance.
prepare() - Method in class cascading.tuple.TupleEntrySchemeCollector
Need to defer preparing the scheme till after the fields have been resolved
prepareField(int, String, Type) - Method in interface cascading.scheme.util.FieldTypeResolver
 
prepareFields(Iterable) - Method in class cascading.scheme.util.DelimitedParser
 
prepareForMatch(ProcessLogger, Transformed<ElementGraph>, ElementGraph) - Method in class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
prepareForMatch(ProcessLogger, Transformed<ElementGraph>, ElementGraph) - Method in class cascading.flow.planner.iso.transformer.MutateGraphTransformer
 
prepareForMatch(ProcessLogger, Transformed<E>, E) - Method in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
prepareResourceForRead(Config) - Method in class cascading.tap.DecoratorTap
 
prepareResourceForRead(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
prepareResourceForRead(Config) - Method in class cascading.tap.SinkTap
 
prepareResourceForRead(Config) - Method in class cascading.tap.Tap
Method prepareResourceForRead allows the underlying resource to be notified when reading will begin.
prepareResourceForWrite(Config) - Method in class cascading.tap.DecoratorTap
 
prepareResourceForWrite(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
prepareResourceForWrite(Config) - Method in class cascading.tap.SourceTap
 
prepareResourceForWrite(Config) - Method in class cascading.tap.Tap
Method prepareResourceForWrite allows the underlying resource to be notified when writing will begin.
prepareResources() - Method in class cascading.flow.planner.BaseFlowStep
 
presentSinkFields(FlowElementGraph) - Method in class cascading.flow.BaseFlow
Present the current resolved fields for the Tap
presentSinkFields(FlowProcess<? extends Config>, Tap, Fields) - Method in class cascading.scheme.Scheme
Method presentSinkFields is called after the planner is invoked and all fields are resolved.
presentSinkFields(FlowProcess<? extends Config>, Fields) - Method in class cascading.tap.DecoratorTap
 
presentSinkFields(FlowProcess<? extends Config>, Fields) - Method in class cascading.tap.MultiSinkTap
 
presentSinkFields(FlowProcess<? extends Config>, Fields) - Method in class cascading.tap.Tap
 
presentSinkFieldsInternal(Fields) - Method in class cascading.scheme.Scheme
 
presentSourceFields(FlowElementGraph) - Method in class cascading.flow.BaseFlow
Present the current resolved fields for the Tap
presentSourceFields(FlowProcess<? extends Config>, Tap, Fields) - Method in class cascading.scheme.Scheme
Method presentSourceFields is called after the planner is invoked and all fields are resolved.
presentSourceFields(FlowProcess<? extends Config>, Fields) - Method in class cascading.tap.DecoratorTap
 
presentSourceFields(FlowProcess<? extends Config>, Fields) - Method in class cascading.tap.Tap
 
presentSourceFieldsInternal(Fields) - Method in class cascading.scheme.Scheme
 
PRESERVE_TEMPORARY_FILES - Static variable in class cascading.flow.FlowProps
 
previous - Variable in class cascading.pipe.Pipe
Field previous
primitives - Static variable in class cascading.tuple.coerce.Coercions
 
print() - Method in class cascading.flow.planner.Scope
 
print(Scope) - Method in class cascading.pipe.Pipe
Method print is used internally.
print() - Method in class cascading.tuple.Fields
Method print returns a String representation of this instance.
print() - Method in class cascading.tuple.io.IndexTuple
 
print() - Method in class cascading.tuple.io.TuplePair
 
print() - Method in class cascading.tuple.Tuple
Method print returns a parsable String representation of this Tuple instance.
print(Collection, String) - Static method in class cascading.util.Util
 
print(StringBuffer, Collection, String) - Static method in class cascading.util.Util
 
printBanner() - Static method in class cascading.util.Version
 
printElementGraph(String, SimpleDirectedGraph<String, BaseFlow.FlowHolder>) - Method in class cascading.cascade.BaseCascade
 
printElementGraph(String, ElementGraph, PlatformInfo) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
printGraph(String, String, int) - Method in class cascading.flow.stream.graph.StreamGraph
 
printGraph(String) - Method in class cascading.flow.stream.graph.StreamGraph
 
printGraph(String, SimpleDirectedGraph) - Static method in class cascading.util.Util
 
printGraphError() - Method in class cascading.flow.stream.graph.StreamGraph
 
printInternal(StringBuffer, Scope) - Method in class cascading.pipe.Operator
 
printInternal(StringBuffer, Scope) - Method in class cascading.pipe.Pipe
 
printInternal(StringBuffer, Scope) - Method in class cascading.pipe.Splice
 
printOperationInternal(Operation, StringBuffer, Scope) - Static method in class cascading.operation.BaseOperation
 
printProcessGraph(String, ElementGraph, ProcessGraph<? extends ProcessModel>) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
printProcessGraph(String) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
printTo(StringBuffer) - Method in class cascading.tuple.io.IndexTuple
 
printTo(StringBuffer) - Method in class cascading.tuple.Tuple
 
printVerbose() - Method in class cascading.tuple.Fields
Method printLong returns a String representation of this instance along with the size.
priority() - Method in class cascading.util.ShutdownUtil.Hook
 
ProcessEdge<Process extends ProcessModel> - Class in cascading.flow.planner.process
 
ProcessEdge(Process, FlowElement, Process) - Constructor for class cascading.flow.planner.process.ProcessEdge
 
ProcessEdge(ElementGraph, FlowElement, ElementGraph) - Constructor for class cascading.flow.planner.process.ProcessEdge
 
ProcessEdge(Process, Process) - Constructor for class cascading.flow.planner.process.ProcessEdge
 
ProcessFlow<Process,Config> - Class in cascading.flow.process
Class ProcessFlow is a Flow subclass that supports custom Riffle jobs.
ProcessFlow(String, Process) - Constructor for class cascading.flow.process.ProcessFlow
Constructor ProcessFlow creates a new ProcessFlow instance.
ProcessFlow(Map<Object, Object>, String, Process) - Constructor for class cascading.flow.process.ProcessFlow
Constructor ProcessFlow creates a new ProcessFlow instance.
ProcessFlow(Map<Object, Object>, String, Process, Map<String, String>) - Constructor for class cascading.flow.process.ProcessFlow
Constructor ProcessFlow creates a new ProcessFlow instance.
ProcessFlowStats - Class in cascading.stats.process
ProcessFlowStats is a sub-class of FlowStats which can fetch counters from a ProcessWrapper and hook them into the stats mechanism of Cascading.
ProcessFlowStats(Flow, ClientState, ProcessWrapper) - Constructor for class cascading.stats.process.ProcessFlowStats
Constructs a new ProcessFlowStats instance.
ProcessFlowStep - Class in cascading.flow.process
 
ProcessFlowStep(ProcessWrapper, int) - Constructor for class cascading.flow.process.ProcessFlowStep
 
ProcessFlowStep(ProcessWrapper, int, Map<String, String>) - Constructor for class cascading.flow.process.ProcessFlowStep
 
ProcessGraph<Process extends ProcessModel> - Interface in cascading.flow.planner.process
 
ProcessGraphs - Class in cascading.flow.planner.process
 
ProcessGraphs() - Constructor for class cascading.flow.planner.process.ProcessGraphs
 
ProcessLevel - Enum in cascading.flow.planner.rule
 
ProcessLogger - Interface in cascading.util
 
ProcessModel - Interface in cascading.flow.planner.process
 
ProcessModels - Class in cascading.flow.planner.process
 
ProcessModels() - Constructor for class cascading.flow.planner.process.ProcessModels
 
ProcessStepStats - Class in cascading.stats.process
ProcessStepStats is an implementation of FlowStepStats used in non-hadoop based flows like ProcessFlow.
ProcessStepStats(ClientState, Map<String, Map<String, Long>>, ProcessFlowStep) - Constructor for class cascading.stats.process.ProcessStepStats
Constructs a new ProcessStepStats instance.
project(Fields) - Method in class cascading.tuple.Fields
Method project will return a new Fields instance similar to the given fields instance except any absolute positional elements will be replaced by the current field names, if any.
properties - Variable in class cascading.flow.FlowConnector
Field properties
Property - Annotation Type in cascading.management.annotation
Property annotations can be used to send additional information about certain aspects of Cascading classes to the DocumentService.
PropertyConfigured - Annotation Type in cascading.management.annotation
PropertyConfigured is an annotation to document the configuration key and the default value of a given @Property annotation on the same AnnotatedElement.
PropertyDescription - Annotation Type in cascading.management.annotation
PropertyDescription is an annotation that can be used to describe the @Property annotation present on the same AnnotatedElement.
PropertyOrder - Annotation Type in cascading.management.annotation
PropertyOrder is an annotation at the class level that controls the sort order of the Property annotations present on that class.
PropertyRegexSanitizer - Annotation Type in cascading.management.annotation
PropertyRegexSanitizer is an annotation to be used in conjunction with a Property annotation to sanitize values containing sensitive information with a given regular expression.
PropertySanitizer - Annotation Type in cascading.management.annotation
PropertySanitizer is an annotation to be used in conjunction with a Property annotation to sanitize values containing sensitive information.
PropertyUtil - Class in cascading.property
Class PropertyUtil is a static helper class for handling properties.
PropertyUtil() - Constructor for class cascading.property.PropertyUtil
 
Props - Class in cascading.property
Class Props is the base class for frameworks specific properties helper classes.
Props() - Constructor for class cascading.property.Props
 
ProviderLoader<Provider> - Class in cascading.provider
Class ProviderLoader is the base class for loading various "provider" types.
ProviderLoader() - Constructor for class cascading.provider.ProviderLoader
 
ProviderLoader(String[], URL) - Constructor for class cascading.provider.ProviderLoader
 
ProvidesCounters - Interface in cascading.stats
 
put(String, Object) - Method in class cascading.management.CascadingServices.NullDocumentService
 
put(String, String, Object) - Method in class cascading.management.CascadingServices.NullDocumentService
 
put(String, Object) - Method in interface cascading.management.DocumentService
 
put(String, String, Object) - Method in interface cascading.management.DocumentService
 
put(Fields, Fields, Tuple) - Method in class cascading.tuple.Tuple
Method put places the values of the given tuple into the positions specified by the fields argument.
put(Key, Value) - Method in class cascading.util.cache.DirectMappedCache
 
put(Key, Value) - Method in class cascading.util.cache.LRUHashMapCache
 
put(Key, Value) - Method in class cascading.util.cache.OrderedHashMapCache
 
put(K, V) - Method in class cascading.util.MultiMap
 
putAll(Map<? extends Key, ? extends Value>) - Method in class cascading.util.cache.DirectMappedCache
 
putAll(Map<? extends Key, ? extends Value>) - Method in class cascading.util.cache.LRUHashMapCache
 
putAll(Map<? extends Key, ? extends Value>) - Method in class cascading.util.cache.OrderedHashMapCache
 

Q

quote - Variable in class cascading.scheme.util.DelimitedParser
Field quote
quote(Collection<String>, String) - Static method in class cascading.util.Util
 

R

read(int, DataInputStream) - Method in interface cascading.tuple.io.TupleInputStream.ElementReader
 
read(Class, DataInputStream) - Method in interface cascading.tuple.io.TupleInputStream.ElementReader
 
read(T) - Method in interface cascading.tuple.io.TupleInputStream.TupleElementReader
 
readIndexTuple() - Method in class cascading.tuple.io.TupleInputStream
 
readIndexTuple(IndexTuple) - Method in class cascading.tuple.io.TupleInputStream
 
readToken() - Method in class cascading.tuple.io.TupleInputStream
 
readTuple() - Method in class cascading.tuple.io.TupleInputStream
 
readTuple(T) - Method in class cascading.tuple.io.TupleInputStream
 
readTuplePair() - Method in class cascading.tuple.io.TupleInputStream
 
readTuplePair(TuplePair) - Method in class cascading.tuple.io.TupleInputStream
 
readType(int) - Method in class cascading.tuple.io.TupleInputStream
 
readType(Class) - Method in class cascading.tuple.io.TupleInputStream
 
readTyped(Class[], T) - Method in class cascading.tuple.io.TupleInputStream
 
readUnTyped(T) - Method in class cascading.tuple.io.TupleInputStream
 
readWith(TupleInputStream.TupleElementReader[], T) - Method in class cascading.tuple.io.TupleInputStream
 
receive(Duct, Incoming) - Method in class cascading.flow.stream.duct.CloseReducingDuct
 
receive(Duct, Incoming) - Method in class cascading.flow.stream.duct.Duct
 
receive(Duct, Incoming) - Method in class cascading.flow.stream.duct.Fork
 
receive(Duct, Grouping<Incoming, Iterator<Incoming>>) - Method in class cascading.flow.stream.duct.OpenDuct
 
receive(Duct, Grouping<Incoming, Iterator<Incoming>>) - Method in class cascading.flow.stream.duct.OpenReducingDuct
 
receive(Duct, Incoming) - Method in class cascading.flow.stream.duct.Stage
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
receive(Duct, Grouping<TupleEntry, TupleEntryIterator>) - Method in class cascading.flow.stream.element.BufferEveryWindow
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.FilterEachStage
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.FunctionEachStage
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.MemoryCoGroupGate
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.SinkStage
 
receive(Duct, Void) - Method in class cascading.flow.stream.element.SourceStage
 
receive(Duct, TupleEntry) - Method in class cascading.flow.stream.element.ValueAssertionEachStage
 
receiveFirst(Incoming) - Method in class cascading.flow.stream.duct.Duct
 
record(String, Object) - Method in class cascading.management.state.ClientState
 
RECORD_ELEMENT_TRACE - Static variable in class cascading.tap.TrapProps
 
RECORD_THROWABLE_MESSAGE - Static variable in class cascading.tap.TrapProps
 
RECORD_THROWABLE_STACK_TRACE - Static variable in class cascading.tap.TrapProps
 
recordAllDiagnostics() - Method in class cascading.tap.TrapProps
Method recordAllDiagnostics enables recording of all configurable diagnostic values.
recordCascade(Cascade) - Method in class cascading.management.state.ClientState
 
recordChildStats() - Method in class cascading.stats.BaseCachedNodeStats
Synchronized to prevent state changes mid record, #stop may be called out of band
recordChildStats() - Method in class cascading.stats.BaseCachedStepStats
Synchronized to prevent state changes mid record, #stop may be called out of band
recordChildStats() - Method in class cascading.stats.FlowNodeStats
 
recordChildStats() - Method in class cascading.stats.FlowStepStats
An internal method that will refresh current counters and, if a clientState client is enabled, the child details including node and slice statistics.
recordChildStats() - Method in class cascading.stats.process.ProcessStepStats
 
recordElementTrace - Variable in class cascading.tap.TrapProps
 
recordFlow(Flow) - Method in class cascading.management.state.ClientState
 
recordFlowNode(FlowNode) - Method in class cascading.management.state.ClientState
 
recordFlowStep(FlowStep) - Method in class cascading.management.state.ClientState
 
recordInfo() - Method in class cascading.stats.CascadeStats
 
recordInfo() - Method in class cascading.stats.CascadingStats
 
recordInfo() - Method in class cascading.stats.FlowNodeStats
 
recordInfo() - Method in class cascading.stats.FlowStats
 
recordInfo() - Method in class cascading.stats.FlowStepStats
 
recordStats(CascadingStats) - Method in class cascading.management.state.ClientState
 
recordStats() - Method in class cascading.stats.CascadingStats
Method recordStats forces recording of current status information.
recordThrowableMessage - Variable in class cascading.tap.TrapProps
 
recordThrowableStackTrace - Variable in class cascading.tap.TrapProps
 
RecursiveGraphTransformer<E extends ElementGraph> - Class in cascading.flow.planner.iso.transformer
 
RecursiveGraphTransformer(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
RED - Static variable in class cascading.flow.planner.rule.util.TraceWriter
 
Reducing<Group,Result> - Interface in cascading.flow.stream.duct
 
RegexFilter - Class in cascading.operation.regex
Class RegexFilter will apply the regex patternString against every input Tuple value and filter the Tuple stream accordingly.
RegexFilter(String) - Constructor for class cascading.operation.regex.RegexFilter
Constructor RegexFilter creates a new RegexFilter instance.
RegexFilter(String, String) - Constructor for class cascading.operation.regex.RegexFilter
Constructor RegexFilter creates a new RegexFilter instance.
RegexFilter(String, boolean) - Constructor for class cascading.operation.regex.RegexFilter
Constructor RegexFilter creates a new RegexFilter instance.
RegexFilter(String, boolean, String) - Constructor for class cascading.operation.regex.RegexFilter
Constructor RegexFilter creates a new RegexFilter instance.
RegexFilter(String, boolean, boolean) - Constructor for class cascading.operation.regex.RegexFilter
 
RegexFilter(String, boolean, boolean, String) - Constructor for class cascading.operation.regex.RegexFilter
 
RegexGenerator - Class in cascading.operation.regex
Class RegexGenerator will emit a new Tuple for every matched regex group.
RegexGenerator(String) - Constructor for class cascading.operation.regex.RegexGenerator
Constructor RegexGenerator creates a new RegexGenerator instance.
RegexGenerator(Fields, String) - Constructor for class cascading.operation.regex.RegexGenerator
Constructor RegexGenerator creates a new RegexGenerator instance.
RegexMatcher - Class in cascading.operation.regex
Class RegexMatcher is the base class for common regular expression operations.
RegexMatcher(String) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(String, String) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(String, boolean) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(String, boolean, String) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(Fields, String) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(Fields, String, String) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(Fields, String, boolean) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexMatcher(Fields, String, boolean, String) - Constructor for class cascading.operation.regex.RegexMatcher
 
RegexOperation<C> - Class in cascading.operation.regex
Class RegexOperation is the base class for all regex Operations.
RegexOperation() - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexOperation(int) - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexOperation(Fields) - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexOperation(int, String) - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexOperation(String) - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexOperation(int, Fields) - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexOperation(int, Fields, String) - Constructor for class cascading.operation.regex.RegexOperation
Constructor RegexOperation creates a new RegexOperation instance.
RegexParser - Class in cascading.operation.regex
Class RegexParser is used to extract a matched regex from an incoming argument value.
RegexParser(String) - Constructor for class cascading.operation.regex.RegexParser
Constructor RegexParser creates a new RegexParser instance, where the argument Tuple value is matched and returned in a new Tuple.
RegexParser(Fields, String) - Constructor for class cascading.operation.regex.RegexParser
Constructor RegexParser creates a new RegexParser instance, where the argument Tuple value is matched and returned as the given Field.
RegexParser(String, int[]) - Constructor for class cascading.operation.regex.RegexParser
Constructor RegexParser creates a new RegexParser instance, where the patternString is a regular expression with match groups and whose groups designated by groups are stored in the appropriate number of new fields.
RegexParser(Fields, String, int[]) - Constructor for class cascading.operation.regex.RegexParser
Constructor RegexParser creates a new RegexParser instance, where the patternString is a regular expression with match groups and whose groups designated by groups are stored in the named fieldDeclarations.
RegexReplace - Class in cascading.operation.regex
Class RegexReplace is used to replace a matched regex with a replacement value.
RegexReplace(Fields, String, String, boolean) - Constructor for class cascading.operation.regex.RegexReplace
Constructor RegexReplace creates a new RegexReplace instance,
RegexReplace(Fields, String, String) - Constructor for class cascading.operation.regex.RegexReplace
Constructor RegexReplace creates a new RegexReplace instance.
RegexSplitGenerator - Class in cascading.operation.regex
Class RegexGenerator will emit a new Tuple for every split on the incoming argument value delimited by the given patternString.
RegexSplitGenerator(String) - Constructor for class cascading.operation.regex.RegexSplitGenerator
Constructor RegexGenerator creates a new RegexGenerator instance.
RegexSplitGenerator(Fields, String) - Constructor for class cascading.operation.regex.RegexSplitGenerator
Constructor RegexGenerator creates a new RegexGenerator instance.
RegexSplitter - Class in cascading.operation.regex
Class RegexSplitter will split an incoming argument value by the given regex delimiter patternString.
RegexSplitter(String) - Constructor for class cascading.operation.regex.RegexSplitter
Constructor RegexSplitter creates a new RegexSplitter instance.
RegexSplitter(Fields) - Constructor for class cascading.operation.regex.RegexSplitter
Constructor RegexOperation creates a new RegexOperation instance, where the delimiter is the tab character.
RegexSplitter(Fields, String) - Constructor for class cascading.operation.regex.RegexSplitter
Constructor RegexSplitter creates a new RegexSplitter instance.
registerApiBoundary(String) - Static method in class cascading.util.TraceUtil
Add a regex that serves as a boundary for tracing.
registerPlanner(Class<? extends FlowPlanner>) - Static method in class cascading.util.Update
 
registerShutdownHook() - Method in class cascading.flow.BaseFlow
 
registerShutdownHook() - Static method in class cascading.util.ShutdownUtil
 
registry - Variable in class cascading.flow.planner.PlannerInfo
 
releaseSingletonsAndDestroy() - Static method in class cascading.provider.ServiceLoader
 
releaseSingletonServices() - Method in class cascading.provider.ServiceLoader
 
remainderFields - Variable in class cascading.flow.stream.element.OperatorStage
 
remove() - Method in class cascading.flow.planner.iso.subgraph.iterator.ExpressionSubGraphIterator
 
remove() - Method in class cascading.flow.planner.iso.subgraph.iterator.IncludeRemainderSubGraphIterator
 
remove() - Method in class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
remove() - Method in class cascading.pipe.joiner.InnerJoin.JoinIterator
 
remove() - Method in class cascading.tap.partition.PartitionTupleEntryIterator
 
remove(Object) - Method in class cascading.tuple.collect.SpillableTupleList
 
remove(int[]) - Method in class cascading.tuple.Tuple
Method remove removes the values specified by the given pos array and returns a new Tuple containing the removed values.
remove(Fields, Fields) - Method in class cascading.tuple.Tuple
Method remove removes the values specified by the given selector.
remove() - Method in class cascading.tuple.TupleChainIterator
Method remove removes the current Tuple from the underlying collection.
remove() - Method in class cascading.tuple.TupleEntryChainIterator
Method remove removes the current TupleEntry from the underlying collection.
remove() - Method in class cascading.tuple.TupleEntryIterableChainIterator
Method remove removes the current TupleEntry from the underlying collection.
remove() - Method in class cascading.tuple.TupleEntrySchemeIterator
 
remove(Object) - Method in class cascading.util.cache.DirectMappedCache
 
remove(Object) - Method in class cascading.util.cache.LRUHashMapCache
 
remove(Object) - Method in class cascading.util.cache.OrderedHashMapCache
 
remove(K) - Method in class cascading.util.MultiMap
 
remove() - Method in class cascading.util.SingleValueIterator
 
removeAll(Collection<?>) - Method in class cascading.tuple.collect.SpillableTupleList
 
removeAllEdges(Collection<? extends Scope>) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
removeAllEdges(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
removeAllEdges(Collection<? extends Scope>) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
removeAllEdges(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
removeAllEdges(Collection<? extends Scope>) - Method in interface cascading.flow.planner.graph.ElementGraph
 
removeAllEdges(FlowElement, FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
removeAllEdges(Collection<? extends ProcessEdge>) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
removeAllEdges(Process, Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
removeAllEdges(Collection<? extends ProcessEdge>) - Method in interface cascading.flow.planner.process.ProcessGraph
 
removeAllEdges(Process, Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
removeAllNulls(List) - Static method in class cascading.util.Util
This method removes all nulls from the given List.
removeAllVertices(Collection<? extends FlowElement>) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
removeAllVertices(Collection<? extends FlowElement>) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
removeAllVertices(Collection<? extends FlowElement>) - Method in interface cascading.flow.planner.graph.ElementGraph
 
removeAllVertices(Collection<? extends Process>) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
removeAllVertices(Collection<? extends Process>) - Method in interface cascading.flow.planner.process.ProcessGraph
 
removeAndContract(ElementGraph, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
removeBranchBetween(ElementGraph, FlowElement, FlowElement, boolean) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
removeBranchContaining(ElementGraph, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
RemoveBranchGraphTransformer - Class in cascading.flow.planner.iso.transformer
 
RemoveBranchGraphTransformer(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.RemoveBranchGraphTransformer
 
RemoveBranchGraphTransformer(GraphTransformer, ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.RemoveBranchGraphTransformer
 
removeEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
removeEdge(Scope) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
removeEdge(FlowElement, FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
removeEdge(Scope) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
removeEdge(FlowElement, FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
removeEdge(Scope) - Method in interface cascading.flow.planner.graph.ElementGraph
 
removeEdge(Process, Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
removeEdge(ProcessEdge) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
removeEdge(Process, Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
removeEdge(ProcessEdge) - Method in interface cascading.flow.planner.process.ProcessGraph
 
removeHook(ShutdownUtil.Hook) - Static method in class cascading.util.ShutdownUtil
 
removeListener(CascadeListener) - Method in class cascading.cascade.BaseCascade
 
removeListener(CascadeListener) - Method in interface cascading.cascade.Cascade
 
removeListener(FlowListener) - Method in class cascading.flow.BaseFlow
 
removeListener(FlowListener) - Method in interface cascading.flow.Flow
Method removeListener removes the given flowListener from this instance.
removeListener(FlowStepListener) - Method in interface cascading.flow.FlowStep
Method removeListener removes the given flowStepListener from this instance.
removeListener(FlowStepListener) - Method in class cascading.flow.planner.BaseFlowStep
 
removeListener(StatsListener) - Method in class cascading.stats.CascadingStats
 
RemoveNoOpPipeTransformer - Class in cascading.flow.planner.rule.transformer
 
RemoveNoOpPipeTransformer() - Constructor for class cascading.flow.planner.rule.transformer.RemoveNoOpPipeTransformer
 
removeNulls(String...) - Static method in class cascading.util.Util
 
removeStepListener(FlowStepListener) - Method in class cascading.flow.BaseFlow
 
removeStepListener(FlowStepListener) - Method in interface cascading.flow.Flow
Method removeStepListener removes the given flowStepListener from this instance.
removeVertex(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
removeVertex(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
removeVertex(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
removeVertex(Process) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
removeVertex(Process) - Method in interface cascading.flow.planner.process.ProcessGraph
 
Rename - Class in cascading.pipe.assembly
Class Rename is a SubAssembly that will rename the fromFields to the names in toFields.
Rename(Pipe, Fields, Fields) - Constructor for class cascading.pipe.assembly.Rename
Rename the fromFields in the current Tuple to the given toFields.
rename(Fields, Fields) - Method in class cascading.tuple.Fields
Method rename will rename the from fields to the values in to to fields.
REPLACE - Static variable in class cascading.tuple.Fields
Field REPLACE represents all incoming fields, and allows their values to be replaced by the current operation results.
replaceElementWith(ElementGraph, FlowElement, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
 
ReplaceGraphTransformer - Class in cascading.flow.planner.iso.transformer
 
ReplaceGraphTransformer(ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.ReplaceGraphTransformer
 
ReplaceGraphTransformer(GraphTransformer, ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.ReplaceGraphTransformer
 
requiresRecursiveSearch() - Method in class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
requiresRecursiveSearch() - Method in class cascading.flow.planner.iso.transformer.MutateGraphTransformer
 
requiresRecursiveSearch() - Method in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
By default, prepareForMatch returns the same graph, but sub-classes may return a sub-graph, one of many requiring sub-sequent matches.
reset(Collection<Tuple>[]) - Method in class cascading.flow.stream.element.MemoryCoGroupClosure
 
reset() - Method in class cascading.operation.aggregator.Average.Context
 
reset() - Method in class cascading.operation.aggregator.ExtremaValueBase.Context
 
reset() - Method in class cascading.operation.assertion.AssertGroupBase.Context
 
reset() - Method in class cascading.pipe.assembly.AverageBy.AverageFinal.Context
 
reset(Fields, Fields) - Method in class cascading.scheme.util.DelimitedParser
 
reset(String, String, Type[], boolean, boolean, Fields, Fields, FieldTypeResolver) - Method in class cascading.scheme.util.DelimitedParser
 
reset(Tuple) - Method in class cascading.tuple.io.KeyTuple
 
reset(Tuple, Tuple) - Method in class cascading.tuple.io.TuplePair
 
reset(Tuple) - Method in class cascading.tuple.io.ValueTuple
 
reset(Iterable<Tuple>...) - Method in class cascading.tuple.TupleChainIterable
 
reset(Iterator<Tuple>...) - Method in class cascading.tuple.TupleChainIterator
 
reset(Iterator<Tuple>) - Method in class cascading.tuple.TupleEntryChainIterator
 
reset(Iterator<Tuple>[]) - Method in class cascading.tuple.TupleEntryChainIterator
 
reset(Iterable<Iterator<Tuple>>) - Method in class cascading.tuple.TupleEntryIterableChainIterator
 
reset(V...) - Method in interface cascading.tuple.util.Resettable
 
reset(V) - Method in interface cascading.tuple.util.Resettable1
 
reset(V1, V2) - Method in interface cascading.tuple.util.Resettable2
 
reset(Tuple, V...) - Static method in class cascading.tuple.util.TupleViews
 
reset(Value) - Method in class cascading.util.SingleValueIterator
 
resetAppID() - Static method in class cascading.property.AppProps
Sets the static appID value to null.
Resettable<V> - Interface in cascading.tuple.util
 
Resettable1<V> - Interface in cascading.tuple.util
 
Resettable2<V1,V2> - Interface in cascading.tuple.util
 
resolve(Fields, Fields...) - Static method in class cascading.tuple.Fields
Method resolve returns a new selector expanded on the given field declarations
resolveAssemblyPlanners(FlowDef, Flow, Pipe[]) - Method in class cascading.flow.planner.FlowPlanner
 
resolveFields(FlowElementGraph) - Static method in class cascading.flow.planner.rule.ScopeResolver
 
resolveIncomingOperationArgumentFields(Scope) - Method in interface cascading.flow.planner.ScopedElement
Method resolveIncomingOperationArgumentFields returns the Fields outgoing from the previous FlowElement that are consumable by this FlowElement when preparing Operation arguments.
resolveIncomingOperationArgumentFields(Scope) - Method in class cascading.pipe.Each
 
resolveIncomingOperationArgumentFields(Scope) - Method in class cascading.pipe.Every
 
resolveIncomingOperationArgumentFields(Scope) - Method in class cascading.pipe.Pipe
 
resolveIncomingOperationArgumentFields(Scope) - Method in class cascading.tap.DecoratorTap
 
resolveIncomingOperationArgumentFields(Scope) - Method in class cascading.tap.Tap
 
resolveIncomingOperationPassThroughFields(Scope) - Method in interface cascading.flow.planner.ScopedElement
Method resolveIncomingOperationPassThroughFields returns the Fields outgoing from the previous FlowElement that are consumable by this FlowElement when preparing the Pipe outgoing tuple.
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.pipe.Boundary
 
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.pipe.Each
 
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.pipe.Every
 
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.pipe.Pipe
 
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.pipe.Splice
 
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.tap.DecoratorTap
 
resolveIncomingOperationPassThroughFields(Scope) - Method in class cascading.tap.Tap
 
resolveRemainderFields(Set<Scope>, Fields) - Method in class cascading.pipe.Operator
 
resolveTails(AssemblyPlanner.Context) - Method in interface cascading.flow.AssemblyPlanner
Called when this AssemblyPlanner instance should return any additional tail Pipe instances for used when completing the Flow plan.
resolveTails(FlowDef, F) - Method in class cascading.flow.planner.FlowPlanner
 
resourceExists(Tap) - Method in class cascading.flow.BaseFlow
 
resourceExists(Tap) - Method in interface cascading.flow.Flow
Method resourceExists returns true if the resource represented by the given Tap instance exists.
resourceExists(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
resourceExists(Config) - Method in class cascading.tap.DecoratorTap
 
resourceExists(Config) - Method in class cascading.tap.MultiSinkTap
 
resourceExists(Config) - Method in class cascading.tap.MultiSourceTap
 
resourceExists(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
resourceExists(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
Method resourceExists returns true if the path represented by this instance exists.
resourceExists(Config) - Method in class cascading.tap.Tap
Method resourceExists returns true if the path represented by this instance exists.
result() - Method in class cascading.operation.aggregator.Average.Context
 
result() - Method in class cascading.pipe.assembly.AverageBy.AverageFinal.Context
 
resultGroupFields - Variable in class cascading.pipe.Splice
Field resultGroupFields
RESULTS - Static variable in class cascading.tuple.Fields
Field RESULTS represents all fields returned by the current operation
ResultTree - Class in cascading.flow.planner.rule.util
 
ResultTree() - Constructor for class cascading.flow.planner.rule.util.ResultTree
 
ResultTree.Delegate - Class in cascading.flow.planner.rule.util
 
ResultTree.Delegate(ElementGraph) - Constructor for class cascading.flow.planner.rule.util.ResultTree.Delegate
 
ResultTree.Path - Class in cascading.flow.planner.rule.util
 
ResultTree.Path(ResultTree.Path, int) - Constructor for class cascading.flow.planner.rule.util.ResultTree.Path
 
ResultTree.Path(int...) - Constructor for class cascading.flow.planner.rule.util.ResultTree.Path
 
Retain - Class in cascading.pipe.assembly
Class Retain is a SubAssembly that will discard all incoming fields except those given on the constructor.
Retain(Pipe, Fields) - Constructor for class cascading.pipe.assembly.Retain
 
RETAIN_COLLECTOR - Static variable in class cascading.flow.stream.element.OperatorStage
In 2.2 the collector is now nulled before the Operation.cleanup(cascading.flow.FlowProcess, cascading.operation.OperationCall) is called.
retainAll(Collection<?>) - Method in class cascading.tuple.collect.SpillableTupleList
 
rethrow(Exception) - Method in interface cascading.util.Util.RetryOperator
 
retrieveSinkFields() - Method in class cascading.flow.BaseFlow
Force a Scheme to fetch any fields from a meta-data store
retrieveSinkFields(FlowProcess<? extends Config>, Tap) - Method in class cascading.scheme.Scheme
Method retrieveSinkFields notifies a Scheme when it is appropriate to dynamically update the fields it sources.
retrieveSinkFields(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
retrieveSinkFields(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
A hook for allowing a Scheme to lazily retrieve its sink fields.
retrieveSourceFields() - Method in class cascading.flow.BaseFlow
Force a Scheme to fetch any fields from a meta-data store
retrieveSourceFields(FlowProcess<? extends Config>, Tap) - Method in class cascading.scheme.Scheme
Method retrieveSourceFields notifies a Scheme when it is appropriate to dynamically update the fields it sources.
retrieveSourceFields(FlowProcess<? extends Config>) - Method in class cascading.tap.DecoratorTap
 
retrieveSourceFields(FlowProcess<? extends Config>) - Method in class cascading.tap.Tap
A hook for allowing a Scheme to lazily retrieve its source fields.
retry(Logger, int, int, String, Util.RetryOperator<T>) - Static method in class cascading.util.Util
 
returnInstanceFieldIfExists(Object, String) - Static method in class cascading.util.Util
 
returnInstanceFieldIfExistsSafe(Object, String) - Static method in class cascading.util.Util
 
reverseMap(Map<V, K>, Map<K, V>) - Static method in class cascading.util.Util
 
RightJoin - Class in cascading.pipe.joiner
Class RightJoin will return an Iterator that will iterate over a given Joiner and return tuples that represent a left outer, right inner join of the CoGrouper internal grouped tuple collections.
RightJoin() - Constructor for class cascading.pipe.joiner.RightJoin
 
RightJoin(Fields) - Constructor for class cascading.pipe.joiner.RightJoin
 
RightJoin.JoinIterator - Class in cascading.pipe.joiner
 
RightJoin.JoinIterator(JoinerClosure) - Constructor for class cascading.pipe.joiner.RightJoin.JoinIterator
 
role - Variable in class cascading.flow.stream.element.BoundaryStage
 
role - Variable in class cascading.flow.stream.element.SpliceGate
 
rollbackResource(Config) - Method in class cascading.tap.DecoratorTap
 
rollbackResource(Config) - Method in class cascading.tap.MultiSinkTap
 
rollbackResource(Config) - Method in class cascading.tap.partition.BasePartitionTap
 
rollbackResource(Config) - Method in class cascading.tap.SourceTap
 
rollbackResource(Config) - Method in class cascading.tap.Tap
Method rollbackResource allows the underlying resource to be notified when any write processing has failed or was stopped so that any cleanup may be started.
rollbackSinks() - Method in class cascading.flow.planner.BaseFlowStep
 
ROOT_OUTPUT_PATH - Static variable in class cascading.CascadingTestCase
 
ROOT_PLAN_PATH - Static variable in class cascading.CascadingTestCase
 
Rule - Interface in cascading.flow.planner.rule
Rule instances are the unit of work applied by a RuleExec instance and managed by a RuleRegistry.
RuleAnnotationTransformer - Class in cascading.flow.planner.rule.transformer
 
RuleAnnotationTransformer(PlanPhase, RuleExpression, ElementAnnotation) - Constructor for class cascading.flow.planner.rule.transformer.RuleAnnotationTransformer
 
RuleAssert - Class in cascading.flow.planner.rule
The RuleAssert class is responsible for asserting the structure of a element graph.
RuleAssert(PlanPhase, RuleExpression, String) - Constructor for class cascading.flow.planner.rule.RuleAssert
 
RuleAssert(PlanPhase, RuleExpression, String, GraphAssert.AssertionType) - Constructor for class cascading.flow.planner.rule.RuleAssert
 
RuleContractedTransformer - Class in cascading.flow.planner.rule.transformer
 
RuleContractedTransformer(PlanPhase, RuleExpression) - Constructor for class cascading.flow.planner.rule.transformer.RuleContractedTransformer
 
RuleExec - Class in cascading.flow.planner.rule
 
RuleExec(TraceWriter, RuleRegistry) - Constructor for class cascading.flow.planner.rule.RuleExec
 
RuleExpression - Class in cascading.flow.planner.rule
A RuleExpression describes where a Rule is applied in an element graph.
RuleExpression(ExpressionGraph) - Constructor for class cascading.flow.planner.rule.RuleExpression
 
RuleExpression(ExpressionGraph, ExpressionGraph) - Constructor for class cascading.flow.planner.rule.RuleExpression
 
RuleExpression(ExpressionGraph, ExpressionGraph, ExpressionGraph) - Constructor for class cascading.flow.planner.rule.RuleExpression
 
ruleExpression - Variable in class cascading.flow.planner.rule.RuleTransformer
 
RuleInsertionTransformer - Class in cascading.flow.planner.rule.transformer
 
RuleInsertionTransformer(PlanPhase, RuleExpression, String) - Constructor for class cascading.flow.planner.rule.transformer.RuleInsertionTransformer
 
RuleInsertionTransformer(PlanPhase, RuleExpression, String, InsertionGraphTransformer.Insertion) - Constructor for class cascading.flow.planner.rule.transformer.RuleInsertionTransformer
 
RuleInsertionTransformer(PlanPhase, RuleExpression, ElementCapture, String) - Constructor for class cascading.flow.planner.rule.transformer.RuleInsertionTransformer
 
RuleInsertionTransformer(PlanPhase, RuleExpression, ElementCapture, String, InsertionGraphTransformer.Insertion) - Constructor for class cascading.flow.planner.rule.transformer.RuleInsertionTransformer
 
RuleMode - Enum in cascading.flow.planner.rule
 
RulePartitioner - Class in cascading.flow.planner.rule
The RulePartitioner class is responsible for partitioning an element graph into smaller sub-graphs.
RulePartitioner(PlanPhase, RulePartitioner.PartitionSource, GraphPartitioner) - Constructor for class cascading.flow.planner.rule.RulePartitioner
 
RulePartitioner() - Constructor for class cascading.flow.planner.rule.RulePartitioner
 
RulePartitioner.PartitionSource - Enum in cascading.flow.planner.rule
 
RuleRegistry - Class in cascading.flow.planner.rule
RuleRegistry contains all planner rules for a given platform.
RuleRegistry() - Constructor for class cascading.flow.planner.rule.RuleRegistry
 
RuleRegistrySet - Class in cascading.flow.planner.rule
Class RuleRegistrySet manages the set of RuleRegistry instances that should be applied via the FlowPlanner to the given assembly.
RuleRegistrySet(RuleRegistry...) - Constructor for class cascading.flow.planner.rule.RuleRegistrySet
Instantiates a new Rule Registry Set.
RuleRegistrySet(Collection<RuleRegistry>) - Constructor for class cascading.flow.planner.rule.RuleRegistrySet
Instantiates a new Rule Registry Set.
RuleRegistrySet.Select - Enum in cascading.flow.planner.rule
 
RuleRemoveBranchTransformer - Class in cascading.flow.planner.rule.transformer
 
RuleRemoveBranchTransformer(PlanPhase, RuleExpression) - Constructor for class cascading.flow.planner.rule.transformer.RuleRemoveBranchTransformer
 
RuleReplaceTransformer - Class in cascading.flow.planner.rule.transformer
 
RuleReplaceTransformer(PlanPhase, RuleExpression) - Constructor for class cascading.flow.planner.rule.transformer.RuleReplaceTransformer
 
RuleResult - Class in cascading.flow.planner.rule
 
RuleResult() - Constructor for class cascading.flow.planner.rule.RuleResult
 
RuleResult(RuleRegistry) - Constructor for class cascading.flow.planner.rule.RuleResult
 
RuleResult(FlowElementGraph) - Constructor for class cascading.flow.planner.rule.RuleResult
 
RuleResult(RuleRegistry, FlowElementGraph) - Constructor for class cascading.flow.planner.rule.RuleResult
 
RuleResult.ResultStatus - Enum in cascading.flow.planner.rule
 
RuleSetExec - Class in cascading.flow.planner.rule
 
RuleSetExec(TraceWriter, FlowPlanner, Flow, RuleRegistrySet, FlowDef, FlowElementGraph) - Constructor for class cascading.flow.planner.rule.RuleSetExec
 
RuleTransformer - Class in cascading.flow.planner.rule
The RuleTransformer class is responsible for transforming an element graph into a new graph.
RuleTransformer(PlanPhase, RuleExpression) - Constructor for class cascading.flow.planner.rule.RuleTransformer
 
run(Object) - Method in interface cascading.flow.stream.element.InputSource
 
run(Object) - Method in class cascading.flow.stream.element.SourceStage
 
run(long) - Method in class cascading.management.state.ClientState
 
run() - Method in class cascading.util.Update
 
runID - Variable in class cascading.flow.FlowDef
 
runTime - Variable in class cascading.stats.CascadingStats
Field runTime

S

safe - Variable in class cascading.scheme.util.DelimitedParser
Field safe
safeSleep(long) - Static method in class cascading.util.Util
 
Sample - Class in cascading.operation.filter
Class Sample is a Filter that only allows the given fraction of Tuple instances to pass.
Sample(double) - Constructor for class cascading.operation.filter.Sample
Creates a new Sample that permits percent Tuples to pass.
Sample(long, double) - Constructor for class cascading.operation.filter.Sample
Creates a new Sample that permits percent Tuples to pass.
Sanitizer - Interface in cascading.management.annotation
Sanitizer is an interface to be used in conjunction with PropertySanitizer.
sanitizeUrl(String) - Static method in class cascading.util.Util
This method attempts to remove any username and password from the given url String.
Scheme<Config,Input,Output,SourceContext,SinkContext> - Class in cascading.scheme
A Scheme defines what is stored in a Tap instance by declaring the Tuple field names, and alternately parsing or rendering the incoming or outgoing Tuple stream, respectively.
Scheme() - Constructor for class cascading.scheme.Scheme
Constructor Scheme creates a new Scheme instance.
Scheme(Fields) - Constructor for class cascading.scheme.Scheme
Constructor Scheme creates a new Scheme instance.
Scheme(Fields, int) - Constructor for class cascading.scheme.Scheme
Constructor Scheme creates a new Scheme instance.
Scheme(Fields, Fields) - Constructor for class cascading.scheme.Scheme
Constructor Scheme creates a new Scheme instance.
Scheme(Fields, Fields, int) - Constructor for class cascading.scheme.Scheme
Constructor Scheme creates a new Scheme instance.
Scope - Class in cascading.flow.planner
Class Scope is an internal representation of the linkages between operations.
Scope() - Constructor for class cascading.flow.planner.Scope
Default constructor.
Scope(Scope) - Constructor for class cascading.flow.planner.Scope
Copy constructor
Scope(Fields) - Constructor for class cascading.flow.planner.Scope
Tap constructor
Scope(String, Scope.Kind, Fields, Fields, Fields, Fields, Fields, Fields) - Constructor for class cascading.flow.planner.Scope
Constructor Scope creates a new Scope instance.
Scope(String, Fields, Fields, Map<String, Fields>, Map<String, Fields>, Fields, Scope.Kind) - Constructor for class cascading.flow.planner.Scope
Constructor Scope creates a new Scope instance.
Scope(String) - Constructor for class cascading.flow.planner.Scope
Constructor Scope creates a new Scope instance.
Scope.Kind - Enum in cascading.flow.planner
Enum Kind
ScopedElement - Interface in cascading.flow.planner
 
ScopeExpression - Class in cascading.flow.planner.iso.expression
If ScopeExpression is the only edge, the ScopeExpression.Applies enum will apply, otherwise the number of edges on the target graph must match the number of edges in the expression.
ScopeExpression() - Constructor for class cascading.flow.planner.iso.expression.ScopeExpression
 
ScopeExpression(ScopeExpression.Applies) - Constructor for class cascading.flow.planner.iso.expression.ScopeExpression
 
ScopeExpression.Applies - Enum in cascading.flow.planner.iso.expression
 
ScopeResolver - Class in cascading.flow.planner.rule
 
ScopeResolver() - Constructor for class cascading.flow.planner.rule.ScopeResolver
 
SearchOrder - Enum in cascading.flow.planner.iso.finder
 
SEED - Static variable in class cascading.util.Murmur3
 
select(Fields) - Method in class cascading.tuple.Fields
Method select returns a new Fields instance with fields specified by the given selector.
select(Fields, TupleEntry...) - Static method in class cascading.tuple.TupleEntry
Method select will select a new Tuple instance from the given set of entries.
selectEntry(Fields) - Method in class cascading.tuple.TupleEntry
Method selectEntry selects the fields specified in the selector from this instance.
selectEntryCopy(Fields) - Method in class cascading.tuple.TupleEntry
Method selectEntry selects the fields specified in selector from this instance.
selectInto(Fields, Tuple) - Method in class cascading.tuple.TupleEntry
Method selectInto selects the fields specified in the selector from this instance and copies them into the given tuple argument.
selectPos(Fields) - Method in class cascading.tuple.Fields
Method selectPos returns a Fields instance with only positional fields, no field names.
selectPos(Fields, int) - Method in class cascading.tuple.Fields
Method selectPos returns a Fields instance with only positional fields, offset by given offset value, no field names.
selectTuple(Fields) - Method in class cascading.tuple.TupleEntry
Method selectTuple selects the fields specified in the selector from this instance.
selectTupleCopy(Fields) - Method in class cascading.tuple.TupleEntry
Method selectTupleCopy selects the fields specified in selector from this instance.
ServiceLoader - Class in cascading.provider
Class ServiceLoader is an implementation of a ProviderLoader and is used to load CascadingService instances used by internal frameworks.
set(String[], String) - Method in class cascading.management.CascadingServices.NullMetricsService
 
set(String[], int) - Method in class cascading.management.CascadingServices.NullMetricsService
 
set(String[], long) - Method in class cascading.management.CascadingServices.NullMetricsService
 
set(String[], String) - Method in interface cascading.management.MetricsService
 
set(String[], int) - Method in interface cascading.management.MetricsService
 
set(String[], long) - Method in interface cascading.management.MetricsService
 
set(long, String, String) - Method in class cascading.operation.assertion.AssertGroupBase.Context
 
set(String, String) - Method in interface cascading.property.ConfigDef.Setter
 
set(int, Object) - Method in class cascading.tuple.Tuple
Method set sets the given value to the given index position in this instance.
set(Fields, Fields, Tuple) - Method in class cascading.tuple.Tuple
Method set sets the values in the given selector positions to the values from the given Tuple.
set(Fields, Fields, Tuple, CoercibleType[]) - Method in class cascading.tuple.Tuple
 
set(TupleEntry) - Method in class cascading.tuple.TupleEntry
Method set sets the values from the given tupleEntry into this TupleEntry instance based on the given tupleEntry field names.
set(K, int, V) - Method in class cascading.util.SortedListMultiMap
 
setAll(Tuple) - Method in class cascading.tuple.Tuple
Method setAll sets each element value of the given Tuple instance into the corresponding position of this instance.
setAll(Tuple...) - Method in class cascading.tuple.Tuple
Method setAll sets each element value of the given Tuple instances into the corresponding position of this instance.
setAllowNonRecursiveMatching(boolean) - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
setAnnotation(Enum) - Method in class cascading.flow.planner.iso.ElementAnnotation
 
setAnnotationExcludes(Enum...) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
setAnnotations(ElementAnnotation[]) - Method in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
setAnnotations(ElementAnnotation...) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
setApplicationID(Map<Object, Object>) - Static method in class cascading.property.AppProps
 
setApplicationJarClass(Map<Object, Object>, Class) - Static method in class cascading.property.AppProps
Method setApplicationJarClass is used to set the application jar file.
setApplicationJarPath(Map<Object, Object>, String) - Static method in class cascading.property.AppProps
Method setApplicationJarPath is used to set the application jar file.
setApplicationName(Map<Object, Object>, String) - Static method in class cascading.property.AppProps
 
setApplicationVersion(Map<Object, Object>, String) - Static method in class cascading.property.AppProps
 
setArgumentFields(Fields) - Method in class cascading.operation.ConcreteCall
 
setArguments(TupleEntry) - Method in class cascading.operation.ConcreteCall
 
setArgumentsIterator(Iterator<TupleEntry>) - Method in class cascading.operation.ConcreteCall
 
setAssertionLevel(Map<Object, Object>, AssertionLevel) - Static method in class cascading.flow.FlowConnectorProps
Method setAssertionLevel sets the target planner AssertionLevel.
setAssertionLevel(AssertionLevel) - Method in class cascading.flow.FlowConnectorProps
Method setAssertionLevel sets the target planner AssertionLevel.
setAssertionLevel(AssertionLevel) - Method in class cascading.flow.FlowDef
 
setBoolean(int, boolean) - Method in class cascading.tuple.Tuple
Method setBoolean sets the given value to the given index position in this instance.
setBoolean(Comparable, boolean) - Method in class cascading.tuple.TupleEntry
Method setBoolean sets the value in the given field or position.
setBranchNames(Set<String>) - Method in class cascading.flow.stream.element.BoundaryStage
 
setBranchNames(Set<String>) - Method in interface cascading.flow.stream.element.ElementDuct
 
setBranchNames(Set<String>) - Method in class cascading.flow.stream.element.ElementStage
 
setBranchNames(Set<String>) - Method in class cascading.flow.stream.element.SpliceGate
 
setCacheEvictionCallback(CacheEvictionCallback) - Method in interface cascading.util.cache.CascadingCache
Sets the CacheEvictionCallback of this Cache.
setCacheEvictionCallback(CacheEvictionCallback) - Method in class cascading.util.cache.DirectMappedCache
 
setCacheEvictionCallback(CacheEvictionCallback) - Method in class cascading.util.cache.LRUHashMapCache
 
setCacheEvictionCallback(CacheEvictionCallback) - Method in class cascading.util.cache.OrderedHashMapCache
 
setCacheFactoryClass(Class<? extends BaseCacheFactory>) - Method in class cascading.pipe.assembly.AggregateByProps
Sets the CacheFactory class to use.
setCacheFactoryClass(Class<? extends BaseCacheFactory>) - Method in class cascading.pipe.assembly.UniqueProps
Sets the CacheFactory class to use.
setCacheFactoryClassName(String) - Method in class cascading.pipe.assembly.AggregateByProps
Sets the name of the CacheFactory class to use.
setCacheFactoryClassName(String) - Method in class cascading.pipe.assembly.UniqueProps
Sets the name of the CacheFactory to use.
setCanonicalTuple(Tuple) - Method in class cascading.tuple.TupleEntry
Method setCanonicalTuple replaces each value of the current tuple with the given tuple elements after they are coerced.
setCanonicalValues(Object[]) - Method in class cascading.tuple.TupleEntry
Method setCanonicalValues replaces each value of the current tuple with th give Object[] after they are coerced.
setCapacity(int) - Method in class cascading.pipe.assembly.AggregateByProps
Sets the capacity of the cache.
setCapacity(int) - Method in class cascading.pipe.assembly.UniqueProps
Sets the capacity of the cache.
setCapacity(int) - Method in interface cascading.util.cache.CascadingCache
Sets the capacity of the Cache.
setCapacity(int) - Method in class cascading.util.cache.DirectMappedCache
 
setCapacity(int) - Method in class cascading.util.cache.LRUHashMapCache
 
setCapacity(int) - Method in class cascading.util.cache.OrderedHashMapCache
 
setCapture(ElementCapture) - Method in class cascading.flow.planner.iso.ElementAnnotation
 
setCascade(Cascade) - Method in class cascading.flow.BaseFlow
 
setCheckpoints(Map<String, Tap>) - Method in class cascading.flow.BaseFlow
 
setCheckpointTapDecoratorClass(Map<Object, Object>, String) - Static method in class cascading.flow.FlowConnectorProps
Method checkpointTapDecoratorClassName is used for wrapping a checkpoint Tap.
setCheckpointTapDecoratorClassName(String) - Method in class cascading.flow.FlowConnectorProps
Method setCheckpointTapDecoratorClassName sets the class of a DecoratorTap to use to wrap an Checkpoint Tap instance within the Flow.
setCheckpointTapDecoratorClassName(Class<DecoratorTap>) - Method in class cascading.flow.FlowConnectorProps
Method setCheckpointTapDecoratorClassName sets the class of a DecoratorTap to use to wrap an Checkpoint Tap instance within the Flow.
setChildren(ElementGraph, List<? extends ElementGraph>) - Method in class cascading.flow.planner.rule.util.ResultTree
 
setCodecs(List<String>) - Method in class cascading.tuple.collect.SpillableProps
Method setCodecs sets list of possible codec class names to use.
setCombineSplits(Boolean) - Method in class cascading.flow.FlowRuntimeProps
Method setCombineSplits will enable or disable combining of 'splits' on sources.
setComparator(Comparable, Comparator) - Method in class cascading.tuple.Fields
Method setComparator should be used to associate a Comparator with a given field name or position.
setComparators(Comparator...) - Method in class cascading.tuple.Fields
Method setComparators sets all the comparators of this Fields object.
setCompressSpill(boolean) - Method in class cascading.tuple.collect.SpillableProps
Method setCompressSpill either enables or disables spill compression.
setConfig(Config) - Method in class cascading.flow.planner.BaseFlowStep
Set the initialized flowStepConf Config instance
setConfigProperty(Config, Object, Object) - Method in class cascading.flow.BaseFlow
 
setConfigProperty(Config, Object, Object) - Method in class cascading.flow.process.ProcessFlow
 
setContext(C) - Method in class cascading.operation.ConcreteCall
 
setContext(Context) - Method in interface cascading.operation.OperationCall
Sets the user defined 'context' object.
setContext(Context) - Method in class cascading.scheme.ConcreteCall
 
setContext(Context) - Method in interface cascading.scheme.SinkCall
Method setContext sets the context of this SinkCall object.
setContext(Context) - Method in interface cascading.scheme.SourceCall
Method setContext sets the context of this SourceCall object.
setCurrentProcess(FlowProcess) - Method in class cascading.flow.FlowSession
Method setCurrentProcess sets the currentProcess of this FlowSession object.
setCurrentSession(FlowSession) - Method in class cascading.flow.FlowProcess
Method setCurrentSession sets the currentSession of this FlowProcess object.
setCurrentSession(FlowSession) - Method in class cascading.flow.FlowProcessWrapper
 
setDebugLevel(Map<Object, Object>, DebugLevel) - Static method in class cascading.flow.FlowConnectorProps
Method setDebugLevel sets the target planner DebugLevel.
setDebugLevel(DebugLevel) - Method in class cascading.flow.FlowConnectorProps
Method setDebugLevel sets the target planner DebugLevel.
setDebugLevel(DebugLevel) - Method in class cascading.flow.FlowDef
 
setDefaultTupleElementComparator(Map<Object, Object>, String) - Static method in class cascading.flow.FlowProps
Sets a default Comparator to be used if no Comparator can be found for the class via the Comparison interface.
setDefaultTupleElementComparator(String) - Method in class cascading.flow.FlowProps
Sets a default Comparator to be used if no Comparator can be found for the class via the Comparison interface.
setDouble(int, double) - Method in class cascading.tuple.Tuple
Method setDouble sets the given value to the given index position in this instance.
setDouble(Comparable, double) - Method in class cascading.tuple.TupleEntry
Method setDouble sets the value in the given field or position.
setDuration(long, long) - Method in class cascading.flow.planner.rule.RuleResult
 
setEndGraph(E) - Method in class cascading.flow.planner.iso.transformer.Transformed
 
setFailOnClose(Map<Object, Object>, boolean) - Static method in class cascading.tap.partition.PartitionTapProps
Method setFailOnClose(boolean b) controls if the PartitionTap is ignoring all Excpetions, when a TupleEntryCollector is closed or if it should rethrow the Exception.
setFailOnClose(boolean) - Method in class cascading.tap.partition.PartitionTapProps
Method setFailOnClose controls if the PartitionTap is ignoring all Exceptions, when a TupleEntryCollector is closed or if it should rethrow the Exception.
setFields(Fields) - Method in class cascading.tuple.TupleEntryCollector
 
setFields(Fields) - Method in class cascading.tuple.TupleEntrySchemeCollector
 
setFloat(int, float) - Method in class cascading.tuple.Tuple
Method setFloat sets the given value to the given index position in this instance.
setFloat(Comparable, float) - Method in class cascading.tuple.TupleEntry
Method setFloat sets the value in the given field or position.
setFlow(Flow<Config>) - Method in class cascading.flow.planner.BaseFlowStep
 
setFlowName(String) - Method in class cascading.flow.planner.BaseFlowStep
 
setFlowNodeDescriptor(Map<String, String>) - Method in class cascading.flow.planner.BaseFlowNode
 
setFlowNodeStats(FlowNodeStats) - Method in class cascading.flow.planner.BaseFlowNode
 
setFlowSkipStrategy(FlowSkipStrategy) - Method in class cascading.cascade.BaseCascade
 
setFlowSkipStrategy(FlowSkipStrategy) - Method in interface cascading.cascade.Cascade
Method setFlowSkipStrategy sets a new FlowSkipStrategy, the current strategy, if any, is returned.
setFlowSkipStrategy(FlowSkipStrategy) - Method in class cascading.flow.BaseFlow
 
setFlowSkipStrategy(FlowSkipStrategy) - Method in interface cascading.flow.Flow
Method setFlowSkipStrategy sets a new FlowSkipStrategy, the current strategy is returned.
setFlowStep(FlowStep) - Method in class cascading.flow.planner.BaseFlowNode
 
setFlowStepDescriptor(Map<String, String>) - Method in class cascading.flow.planner.BaseFlowStep
 
setFlowStepGraph(FlowStepGraph) - Method in class cascading.flow.BaseFlow
 
setFlowStepStats(FlowStepStats) - Method in interface cascading.flow.FlowStep
 
setFlowStepStats(FlowStepStats) - Method in class cascading.flow.planner.BaseFlowStep
 
setFlowStepStrategy(FlowStepStrategy) - Method in class cascading.flow.BaseFlow
 
setFlowStepStrategy(FlowStepStrategy) - Method in interface cascading.flow.Flow
Sets a default FlowStepStrategy instance.
setGatherPartitions(int) - Method in class cascading.flow.FlowRuntimeProps
Method setGatherPartitions sets the default number of gather partitions each FlowNode should use.
setGroup(TupleEntry) - Method in class cascading.operation.ConcreteCall
 
setGrouping(Tuple) - Method in interface cascading.tuple.collect.Spillable
 
setGrouping(Tuple) - Method in class cascading.tuple.collect.SpillableTupleList
 
setGrouping(Tuple) - Method in class cascading.tuple.collect.SpillableTupleMap
 
setIgnoreFailed(boolean) - Method in class cascading.flow.planner.rule.RuleRegistrySet
Sets ignore failed setting.
setIncomingEntry(TupleEntry) - Method in class cascading.scheme.ConcreteCall
 
setIndex(int) - Method in class cascading.tuple.io.IndexTuple
 
setInput(IO) - Method in class cascading.scheme.ConcreteCall
 
setInstanceFieldIfExists(Object, String, R) - Static method in class cascading.util.Util
 
setInstanceFieldIfExistsSafe(Object, String, R) - Static method in class cascading.util.Util
 
setInteger(int, int) - Method in class cascading.tuple.Tuple
Method setInteger sets the given value to the given index position in this instance.
setInteger(Comparable, int) - Method in class cascading.tuple.TupleEntry
Method setInteger sets the value in the given field or position.
setIntermediateSchemeClass(Map<Object, Object>, Class<? extends Scheme>) - Static method in class cascading.flow.FlowConnectorProps
Method setIntermediateSchemeClass is used for debugging.
setIntermediateSchemeClass(Map<Object, Object>, String) - Static method in class cascading.flow.FlowConnectorProps
Method setIntermediateSchemeClass is used for debugging.
setIntermediateSchemeClassName(String) - Method in class cascading.flow.FlowConnectorProps
Method setIntermediateSchemeClassName is used for debugging.
setIntermediateSchemeClassName(Class<Scheme>) - Method in class cascading.flow.FlowConnectorProps
Method setIntermediateSchemeClassName is used for debugging.
setJarClass(Class) - Method in class cascading.property.AppProps
Method setJarClass is used to set the application jar file.
setJarPath(String) - Method in class cascading.property.AppProps
Method setJarPath is used to set the application jar file.
setJobPollingInterval(Map<Object, Object>, long) - Static method in class cascading.flow.FlowProps
Property jobPollingInterval will set the time to wait between polling the remote server for the status of a job.
setJobPollingInterval(int) - Method in class cascading.flow.FlowProps
Property jobPollingInterval will set the time to wait between polling the remote server for the status of a job.
setJoinerClosure(JoinerClosure) - Method in class cascading.operation.ConcreteCall
 
setLevelResults(ProcessLevel, Map<ElementGraph, List<? extends ElementGraph>>) - Method in class cascading.flow.planner.rule.RuleResult
 
setLevelResults(ProcessLevel, ElementGraph, ElementGraph) - Method in class cascading.flow.planner.rule.RuleResult
 
setLevelResults(ProcessLevel, ElementGraph, List<? extends ElementGraph>) - Method in class cascading.flow.planner.rule.RuleResult
 
setLhs(Lhs) - Method in class cascading.util.Pair
 
setListSpillThreshold(int) - Method in class cascading.tuple.collect.SpillableProps
Method setListSpillThreshold sets the number of tuples to hold in memory before spilling them to disk.
setLog4jLevel(String[]) - Static method in class cascading.util.LogUtil
 
setLog4jLevel(String, String) - Static method in class cascading.util.LogUtil
 
setLogThrowableStackTrace(boolean) - Method in class cascading.tap.TrapProps
Method setLogThrowableStackTrace will disable logging of the Throwable stacktrace value if set to false.
setLong(int, long) - Method in class cascading.tuple.Tuple
Method setLong sets the given value to the given index position in this instance.
setLong(Comparable, long) - Method in class cascading.tuple.TupleEntry
Method setLong sets the value in the given field or position.
setMapInitialCapacity(int) - Method in class cascading.tuple.collect.SpillableProps
Method setMapInitialCapacity sets the default capacity to be used by the backing Map implementation.
setMapLoadFactor(float) - Method in class cascading.tuple.collect.SpillableProps
Method setMapLoadFactor sets the default load factor to be used by the backing Map implementation.
setMapSpillThreshold(int) - Method in class cascading.tuple.collect.SpillableProps
Method setMapSpillThreshold the total number of tuple values (not keys) to attempt to keep in memory.
setMaxConcurrentFlows(int) - Method in class cascading.cascade.CascadeDef
 
setMaxConcurrentFlows(Map<Object, Object>, int) - Static method in class cascading.cascade.CascadeProps
Method setMaxConcurrentFlows sets the maximum number of Flows that a Cascade can run concurrently.
setMaxConcurrentFlows(int) - Method in class cascading.cascade.CascadeProps
Method setMaxConcurrentFlows sets the maximum number of Flows that a Cascade can run concurrently.
setMaxConcurrentSteps(Map<Object, Object>, int) - Static method in class cascading.flow.FlowProps
Method setMaxConcurrentSteps sets the maximum number of steps that a Flow can run concurrently.
setMaxConcurrentSteps(int) - Method in class cascading.flow.FlowProps
Method setMaxConcurrentSteps sets the maximum number of steps that a Flow can run concurrently.
setMetaInfo(MetaInfo) - Method in class cascading.tap.DecoratorTap
 
setMetric(Enum, long) - Method in class cascading.management.state.BaseState
 
setMetric(String, String, long) - Method in class cascading.management.state.BaseState
 
setMetric(String, String, String) - Method in class cascading.management.state.BaseState
 
SetMultiMap<K,V> - Class in cascading.util
 
SetMultiMap() - Constructor for class cascading.util.SetMultiMap
 
setName(String) - Method in class cascading.flow.BaseFlow
 
setName(String) - Method in class cascading.flow.planner.BaseFlowNode
 
setName(String) - Method in class cascading.flow.planner.BaseFlowStep
 
setName(String) - Method in class cascading.flow.planner.Scope
Method setName sets the name of this Scope object.
setName(String) - Method in class cascading.property.AppProps
Method setName sets the application name.
setName(String) - Method in class cascading.property.UnitOfWorkDef
Method setName sets the UnitOfWork name.
setNonBlocking(boolean) - Method in class cascading.flow.planner.Scope
 
setNumSinkParts(int) - Method in class cascading.scheme.Scheme
Method setNumSinkParts sets the numSinkParts of this Scheme object.
setNumSinkParts(int) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
setObject(Comparable, Object) - Method in class cascading.tuple.TupleEntry
Method set sets the value in the given field or position.
setOnEmpty(TupleEntry, TupleEntry) - Static method in class cascading.tuple.Tuples
 
setOrdinal(int) - Method in class cascading.flow.planner.BaseFlowNode
 
setOrdinal(int) - Method in class cascading.flow.planner.BaseFlowStep
 
setOrdinal(Integer) - Method in class cascading.flow.planner.Scope
 
setOrdinalMap(StreamGraph) - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
setOriginal(Tap<Config, Input, Output>) - Method in class cascading.tap.DecoratorTap
 
setOutgoingEntry(TupleEntry) - Method in class cascading.scheme.ConcreteCall
 
setOutput(IO) - Method in class cascading.scheme.ConcreteCall
 
setOutput(Output) - Method in class cascading.tuple.TupleEntrySchemeCollector
 
setOutputCollector(TupleEntryCollector) - Method in class cascading.operation.ConcreteCall
 
setParent(Pipe) - Method in class cascading.pipe.Pipe
 
setPermittedExceptions(Map<Object, Object>, Class<? extends Exception>...) - Static method in class cascading.tuple.TupleEntrySchemeIteratorProps
Method setPermittedExceptions( Map properties, Class[] ...
setPermittedExceptions(Class<? extends Exception>[]) - Method in class cascading.tuple.TupleEntrySchemeIteratorProps
Method setPermittedExceptions is used to set an array of exceptions which are allowed to be ignored in the TupleEntrySchemeIterator.
setPhase(PlanPhase) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
setPhaseDuration(PlanPhase, long, long) - Method in class cascading.flow.planner.rule.RuleResult
 
setPipelineGraphs(List<? extends ElementGraph>) - Method in class cascading.flow.planner.BaseFlowNode
 
setPlanComparator(Comparator<RuleResult>) - Method in class cascading.flow.planner.rule.RuleRegistrySet
Sets planner result comparator, used only if RuleRegistrySet.getSelect() is RuleRegistrySet.Select.COMPARED.
setPlannerException(Exception) - Method in class cascading.flow.planner.rule.RuleResult
 
setPlannerInfo(PlannerInfo) - Method in class cascading.flow.BaseFlow
 
setPlannerTimeoutSec(int) - Method in class cascading.flow.planner.rule.RuleRegistrySet
Sets planner timeout, in seconds.
setPredecessors(List<FlowStepJob<Config>>) - Method in class cascading.flow.planner.FlowStepJob
 
setPreserveTemporaryFiles(Map<Object, Object>, boolean) - Static method in class cascading.flow.FlowProps
Property preserveTemporaryFiles forces the Flow instance to keep any temporary intermediate data sets.
setPreserveTemporaryFiles(boolean) - Method in class cascading.flow.FlowProps
Property preserveTemporaryFiles forces the Flow instance to keep any temporary intermediate data sets.
setPrevious(Pipe...) - Method in class cascading.pipe.SubAssembly
Must be called by subclasses to set the start end points of the assembly the subclass represents.
setPrintFieldsEvery(int) - Method in class cascading.operation.Debug
Method setPrintFieldsEvery sets the printFieldsEvery interval value of this Debug object.
setPrintTupleEvery(int) - Method in class cascading.operation.Debug
Method setPrintTupleEvery sets the printTupleEvery interval value of this Debug object.
setProperties(Map<Object, Object>) - Method in class cascading.management.CascadingServices.NullDocumentService
 
setProperties(Map<Object, Object>) - Method in class cascading.management.CascadingServices.NullMetricsService
 
setProperties(Map<Object, Object>) - Method in class cascading.management.state.BaseState
 
setProperties(ConfigDef) - Method in class cascading.property.Props
 
setProperties(ConfigDef, ConfigDef.Mode) - Method in class cascading.property.Props
 
setProperties(Map<Object, Object>) - Method in interface cascading.provider.CascadingService
 
setProperty(String, String) - Method in class cascading.property.ConfigDef
Method setProperty sets the value to the given key using the ConfigDef.Mode.REPLACE mode.
setProperty(ConfigDef.Mode, String, String) - Method in class cascading.property.ConfigDef
Method setProperty sets the value to the given key using the given ConfigDef.Mode value.
setProperty(Map<Object, Object>, String, String) - Static method in class cascading.property.PropertyUtil
 
setRaw(int, Object) - Method in class cascading.tuple.TupleEntry
Method set sets the value in the given position.
setRaw(Comparable, Object) - Method in class cascading.tuple.TupleEntry
Method set sets the value in the given field or position.
setRecordElementTrace(boolean) - Method in class cascading.tap.TrapProps
Method setRecordElementTrace will enable recording the element trace value if set to true.
setRecordThrowableMessage(boolean) - Method in class cascading.tap.TrapProps
Method setRecordThrowableMessage will enable recording the Throwable message value if set to true.
setRecordThrowableStackTrace(boolean) - Method in class cascading.tap.TrapProps
Method setRecordThrowableStackTrace will enable recording the Throwable stacktrace value if set to true.
setResolved(boolean) - Method in class cascading.flow.planner.graph.FlowElementGraph
 
setResolveElementsEnabled(boolean) - Method in class cascading.flow.planner.rule.RuleRegistry
 
setRetainValues(boolean) - Method in interface cascading.operation.BufferCall
Set to false if at the end of all values iterated over in the argumentsIterator, the last seen argument tuple values should not be nulled out.
setRetainValues(boolean) - Method in class cascading.operation.ConcreteCall
 
setRhs(Rhs) - Method in class cascading.util.Pair
 
setRuleDuration(Rule, long, long) - Method in class cascading.flow.planner.rule.RuleResult
 
setRuleExpression(RuleExpression) - Method in class cascading.flow.planner.rule.partitioner.ExpressionRulePartitioner
 
setRulePartitioner(RulePartitioner) - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
setRunID(String) - Method in class cascading.flow.FlowDef
Method setRunID sets the checkpoint run or execution ID to be used to find prior failed runs against this runID.
setScheme(Scheme<Config, Input, Output, ?, ?>) - Method in class cascading.tap.Tap
 
setScopes() - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
setSelect(RuleRegistrySet.Select) - Method in class cascading.flow.planner.rule.RuleRegistrySet
Sets the result selection type.
setShort(int, short) - Method in class cascading.tuple.Tuple
Method setShort sets the given value to the given index position in this instance.
setShort(Comparable, short) - Method in class cascading.tuple.TupleEntry
Method setShort sets the value in the given field or position.
setSinkFields(Fields) - Method in class cascading.scheme.Scheme
Method setSinkFields sets the sinkFields of this Scheme object.
setSinkFields(Fields) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
setSinks(Map<String, Tap>) - Method in class cascading.flow.BaseFlow
 
setSourceFields(Fields) - Method in class cascading.scheme.Scheme
Method setSourceFields sets the sourceFields of this Scheme object.
setSourceFields(Fields) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
setSources(Map<String, Tap>) - Method in class cascading.flow.BaseFlow
 
setSpawnStrategy(UnitOfWorkSpawnStrategy) - Method in class cascading.cascade.BaseCascade
 
setSpawnStrategy(UnitOfWorkSpawnStrategy) - Method in class cascading.flow.BaseFlow
 
setSpawnStrategy(UnitOfWorkSpawnStrategy) - Method in interface cascading.management.UnitOfWork
 
setSpillListener(Spillable.SpillListener) - Method in interface cascading.tuple.collect.Spillable
 
setSpillListener(Spillable.SpillListener) - Method in class cascading.tuple.collect.SpillableTupleList
 
setSpillListener(Spillable.SpillListener) - Method in class cascading.tuple.collect.SpillableTupleMap
 
setSpillStrategy(Spillable.SpillStrategy) - Method in interface cascading.tuple.collect.Spillable
 
setSpillStrategy(Spillable.SpillStrategy) - Method in class cascading.tuple.collect.SpillableTupleList
 
setSpillStrategy(Spillable.SpillStrategy) - Method in class cascading.tuple.collect.SpillableTupleMap
 
setStackTraceLineDelimiter(String) - Method in class cascading.tap.TrapProps
Method setStackTraceLineDelimiter will set the text delimiter used to denote stacktrace lines.
setStackTraceTrimLine(boolean) - Method in class cascading.tap.TrapProps
Method setStackTraceTrimLine will disable trimming of whitespace on every recorded stacktrace line if set to false.
setStatsStoreInterval(Map<Object, Object>, long) - Static method in class cascading.stats.CascadingStats
Method setStatsStoreInterval sets the interval time between store operations against the underlying document storage services.
setStatus(String) - Method in class cascading.flow.FlowProcess.NullFlowProcess
 
setStatus(String) - Method in class cascading.flow.FlowProcess
Method setStatus is used to set the status of the current operation.
setStatus(String) - Method in class cascading.flow.FlowProcessWrapper
 
setStatus(Enum, long) - Method in class cascading.management.state.ClientState
 
setStopJobsOnExit(Map<Object, Object>, boolean) - Static method in class cascading.flow.FlowProps
Property stopJobsOnExit will tell the Flow to add a JVM shutdown hook that will kill all running processes if the underlying computing system supports it.
setStopJobsOnExit(boolean) - Method in class cascading.flow.FlowProps
Property stopJobsOnExit will tell the Flow to add a JVM shutdown hook that will kill all running processes if the underlying computing system supports it.
setString(int, String) - Method in class cascading.tuple.Tuple
Method setString sets the given value to the given index position in this instance.
setString(Comparable, String) - Method in class cascading.tuple.TupleEntry
Method setString sets the value in the given field or position.
setSubmitPriority(int) - Method in class cascading.flow.BaseFlow
 
setSubmitPriority(int) - Method in interface cascading.flow.Flow
Method setSubmitPriority sets the submitPriority of this Flow object.
setSubmitPriority(int) - Method in interface cascading.flow.FlowStep
Method setSubmitPriority sets the submitPriority of this FlowStep object.
setSubmitPriority(int) - Method in class cascading.flow.planner.BaseFlowStep
 
setTails(Pipe...) - Method in class cascading.pipe.SubAssembly
Must be called by subclasses to set the final end points of the assembly the subclass represents.
setTapFromProcess() - Method in class cascading.flow.process.ProcessFlow
Method setTapFromProcess build Tap instance for the give process incoming and outgoing dependencies.
setTemporaryTapDecoratorClass(Map<Object, Object>, String) - Static method in class cascading.flow.FlowConnectorProps
Method temporaryTapDecoratorClassName is used for wrapping a intermediate temporary Tap.
setTemporaryTapDecoratorClassName(String) - Method in class cascading.flow.FlowConnectorProps
Method setTemporaryTapDecoratorClassName sets the class of a DecoratorTap to use to wrap an intermediate temporary Tap instance internal to the Flow.
setTemporaryTapDecoratorClassName(Class<DecoratorTap>) - Method in class cascading.flow.FlowConnectorProps
Method setTemporaryTapDecoratorClassName sets the class of a DecoratorTap to use to wrap an intermediate temporary Tap instance internal to the Flow.
setTrace(Object, String) - Static method in class cascading.util.TraceUtil
Allows for custom trace fields on Pipe, Tap, and Scheme types
setTrapHandler(TrapHandler) - Method in class cascading.flow.stream.element.BoundaryStage
 
setTrapHandler(TrapHandler) - Method in interface cascading.flow.stream.element.ElementDuct
 
setTrapHandler(TrapHandler) - Method in class cascading.flow.stream.element.ElementStage
 
setTrapHandler(TrapHandler) - Method in class cascading.flow.stream.element.SpliceGate
 
setTraps(Map<String, Tap>) - Method in class cascading.flow.BaseFlow
 
setTraps() - Method in class cascading.flow.stream.graph.NodeStreamGraph
 
setTuple(Tuple) - Method in class cascading.tuple.io.IndexTuple
 
setTuple(Tuple) - Method in class cascading.tuple.TupleEntry
Method setTuple sets the tuple of this TupleEntry object, no copy will be performed.
setTuple(Fields, Tuple) - Method in class cascading.tuple.TupleEntry
Method setTuple sets the values specified by the selector to the values given by the given tuple, the given values will always be copied into this TupleEntry.
setType(int, Type) - Method in class cascading.tuple.Fields
 
setUnmodifiable(T, boolean) - Static method in class cascading.tuple.Tuples
 
setUp() - Method in class cascading.CascadingTestCase
 
SetValue - Class in cascading.operation.function
Class SetValue is a utility Function that allows for a Tuple value to be returned based on the outcome of a given Filter operation.
SetValue(Fields, Filter) - Constructor for class cascading.operation.function.SetValue
Constructor SetValue creates a new SetValue instance.
SetValue(Fields, Filter, Serializable, Serializable) - Constructor for class cascading.operation.function.SetValue
Constructor SetValue creates a new SetValue instance.
setVersion(String) - Method in class cascading.property.AppProps
Method setVersion sets the application version.
shallowCopyElementGraph() - Method in class cascading.flow.planner.graph.FlowElementGraph
 
SHARED - Static variable in class cascading.flow.planner.rule.expression.SplitBeforeEveryExpression
 
SHORT - Static variable in class cascading.tuple.coerce.Coercions
 
SHORT_OBJECT - Static variable in class cascading.tuple.coerce.Coercions
 
ShortCoerce - Class in cascading.tuple.coerce
 
ShortCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.ShortCoerce
 
shortestDistance(ElementGraph, FlowElement, FlowElement) - Static method in class cascading.flow.planner.graph.ElementGraphs
Returns the number of edges found on the shortest distance between the lhs and rhs.
ShortObjectCoerce - Class in cascading.tuple.coerce
 
ShortObjectCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.ShortObjectCoerce
 
SHUTDOWN_EXECUTING - Static variable in class cascading.util.ShutdownUtil
System property set to true when we have entered shutdown
SHUTDOWN_FORCE_NON_DAEMON - Static variable in class cascading.util.ShutdownUtil
 
shutdownHook - Variable in class cascading.flow.BaseFlow
 
ShutdownUtil - Class in cascading.util
ShutdownUtil is a private helper class for registering dependent shutdown hooks to maintain internal state information reliably when a jvm is shutting down.
ShutdownUtil() - Constructor for class cascading.util.ShutdownUtil
 
ShutdownUtil.Hook - Class in cascading.util
 
ShutdownUtil.Hook() - Constructor for class cascading.util.ShutdownUtil.Hook
 
ShutdownUtil.Hook.Priority - Enum in cascading.util
 
simpleTypeNames(Type[]) - Static method in class cascading.util.Util
 
SingleCloseableInputIterator - Class in cascading.util
 
SingleCloseableInputIterator(Closeable) - Constructor for class cascading.util.SingleCloseableInputIterator
 
SingleValueCloseableIterator<Value> - Class in cascading.util
SingleValueIterator is a utility class used for quickly presenting a single value to a consumer expecting both a Closeable and an Iterator interface.
SingleValueCloseableIterator(Value) - Constructor for class cascading.util.SingleValueCloseableIterator
 
SingleValueIterator<Value> - Class in cascading.util
Class SingleValueIterator is a convenience to creating an Iterator that returns one value for use with interfaces that only accept Iterator instances.
SingleValueIterator() - Constructor for class cascading.util.SingleValueIterator
 
SingleValueIterator(Value) - Constructor for class cascading.util.SingleValueIterator
 
sink(FlowProcess<? extends Config>, SinkCall<SinkContext, Output>) - Method in class cascading.scheme.NullScheme
 
sink(FlowProcess<? extends Config>, SinkCall<SinkContext, Output>) - Method in class cascading.scheme.Scheme
Method sink writes out the given Tuple found on SinkCall.getOutgoingEntry() to the SinkCall.getOutput().
sink(FlowProcess<? extends Config>, SinkCall<Void, Output>) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
SinkCall<Context,Output> - Interface in cascading.scheme
SinkCall provides access to the current Scheme.sink(cascading.flow.FlowProcess, SinkCall) invocation arguments.
sinkCall - Variable in class cascading.tuple.TupleEntrySchemeCollector
 
sinkCleanup(FlowProcess<? extends Config>, SinkCall<SinkContext, Output>) - Method in class cascading.scheme.Scheme
Method sinkCleanup is used to destroy resources created by Scheme.sinkPrepare(cascading.flow.FlowProcess, SinkCall).
sinkCleanup(FlowProcess<? extends Config>, SinkCall<Void, Output>) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
sinkConfInit(FlowProcess<? extends Config>, Tap<Config, Input, Output>, Config) - Method in class cascading.scheme.NullScheme
 
sinkConfInit(FlowProcess<? extends Config>, Tap<Config, Input, Output>, Config) - Method in class cascading.scheme.Scheme
Method sinkInit initializes this instance as a sink.
sinkConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.DecoratorTap
 
sinkConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.MultiSinkTap
 
sinkConfInit(FlowProcess<? extends Config>, Tap<Config, Input, Output>, Config) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
sinkConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.SourceTap
 
sinkConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.Tap
Method sinkConfInit initializes this instance as a sink.
sinkElements - Variable in class cascading.flow.planner.process.BaseProcessGraph
 
SinkMode - Enum in cascading.tap
Enum SinkMode identifies supported modes a Tap may utilize when used as a sink.
sinkPrepare(FlowProcess<? extends Config>, SinkCall<SinkContext, Output>) - Method in class cascading.scheme.Scheme
Method sinkPrepare is used to initialize resources needed during each call of Scheme.sink(cascading.flow.FlowProcess, SinkCall).
sinkPrepare(FlowProcess<? extends Config>, SinkCall<Void, Output>) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
sinks - Variable in class cascading.flow.BaseFlow
Field sinks
sinks - Variable in class cascading.flow.FlowDef
 
sinks - Variable in class cascading.flow.planner.BaseFlowStep
Field sink
sinks - Variable in class cascading.flow.planner.graph.FlowElementGraph
Field sinks
SinkStage - Class in cascading.flow.stream.element
 
SinkStage(FlowProcess, Tap) - Constructor for class cascading.flow.stream.element.SinkStage
 
SinkTap<Config,Output> - Class in cascading.tap
Class SinkTap is an optional base class for sink only Taps.
SinkTap() - Constructor for class cascading.tap.SinkTap
 
SinkTap(Scheme<Config, ?, Output, ?, ?>) - Constructor for class cascading.tap.SinkTap
 
SinkTap(Scheme<Config, ?, Output, ?, ?>, SinkMode) - Constructor for class cascading.tap.SinkTap
 
sinkTaps - Variable in class cascading.flow.planner.BaseFlowNode
 
size() - Method in class cascading.flow.planner.rule.RuleRegistrySet
 
size() - Method in class cascading.flow.stream.element.MemoryCoGroupClosure
 
size - Variable in class cascading.operation.assertion.AssertGroupBase
Field size
size() - Method in class cascading.pipe.joiner.JoinerClosure
 
size() - Method in class cascading.tuple.collect.SpillableTupleList
 
size(int) - Static method in class cascading.tuple.Fields
Method size is a factory that makes new instances of Fields the given size.
size(int, Type) - Static method in class cascading.tuple.Fields
Method size is a factory that makes new instances of Fields the given size with every field of the given type.
size() - Method in class cascading.tuple.Fields
Method size returns the number of field positions in this instance.
size(int) - Static method in class cascading.tuple.Tuple
Method size returns a new Tuple instance of the given size with nulls as its element values.
size(int, Comparable) - Static method in class cascading.tuple.Tuple
Method size returns a new Tuple instance of the given size with the given Comparable as its element values.
size() - Method in class cascading.tuple.Tuple
Method size returns the number of values in this Tuple instance.
size() - Method in class cascading.tuple.TupleEntry
Method size returns the number of values in this instance.
size() - Method in class cascading.tuple.TupleListCollector
Returns the size of this collection.
size() - Method in class cascading.util.cache.DirectMappedCache
 
size() - Method in class cascading.util.cache.LRUHashMapCache
 
size() - Method in class cascading.util.cache.OrderedHashMapCache
 
skipFlow(Flow) - Method in class cascading.flow.FlowSkipIfSinkExists
 
skipFlow(Flow) - Method in class cascading.flow.FlowSkipIfSinkNotStale
 
skipFlow(Flow) - Method in interface cascading.flow.FlowSkipStrategy
 
sleepForPollingInterval() - Method in class cascading.flow.planner.FlowStepJob
 
SliceCounters - Enum in cascading.flow
 
sliceStatsMap - Variable in class cascading.stats.BaseCachedNodeStats
 
sortBuilder - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
SortedListMultiMap<K,V> - Class in cascading.util
 
SortedListMultiMap() - Constructor for class cascading.util.SortedListMultiMap
 
SortedListMultiMap(int) - Constructor for class cascading.util.SortedListMultiMap
 
SortedListMultiMap(Comparator<K>, int) - Constructor for class cascading.util.SortedListMultiMap
 
sortFields - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
sortFieldsMap - Variable in class cascading.pipe.Splice
Field sortFieldsMap
source(FlowProcess<? extends Config>, SourceCall<SourceContext, Input>) - Method in class cascading.scheme.NullScheme
 
source(FlowProcess<? extends Config>, SourceCall<SourceContext, Input>) - Method in class cascading.scheme.Scheme
Method source will read a new "record" or value from SourceCall.getInput() and populate the available Tuple via SourceCall.getIncomingEntry() and return true on success or false if no more values available.
source(FlowProcess<? extends Config>, SourceCall<Void, Input>) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
SourceCall<Context,Input> - Interface in cascading.scheme
SourceCall provides access to the current Scheme.source(cascading.flow.FlowProcess, SourceCall) invocation arguments.
sourceCleanup(FlowProcess<? extends Config>, SourceCall<SourceContext, Input>) - Method in class cascading.scheme.Scheme
Method sourceCleanup is used to destroy resources created by Scheme.sourcePrepare(cascading.flow.FlowProcess, SourceCall).
sourceCleanup(FlowProcess<? extends Config>, SourceCall<Void, Input>) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
sourceConfInit(FlowProcess<? extends Config>, Tap<Config, Input, Output>, Config) - Method in class cascading.scheme.NullScheme
 
sourceConfInit(FlowProcess<? extends Config>, Tap<Config, Input, Output>, Config) - Method in class cascading.scheme.Scheme
Method sourceInit initializes this instance as a source.
sourceConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.DecoratorTap
 
sourceConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.MultiSourceTap
 
sourceConfInit(FlowProcess<? extends Config>, Tap<Config, Input, Output>, Config) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
sourceConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.SinkTap
 
sourceConfInit(FlowProcess<? extends Config>, Config) - Method in class cascading.tap.Tap
Method sourceConfInit initializes this instance as a source.
sourceElements - Variable in class cascading.flow.planner.process.BaseProcessGraph
 
sourceFields - Variable in class cascading.scheme.util.DelimitedParser
Field sourceFields
sourcePartitionFilters - Variable in class cascading.tap.partition.BasePartitionTap
Field sourcePartitionFilters
sourcePrepare(FlowProcess<? extends Config>, SourceCall<SourceContext, Input>) - Method in class cascading.scheme.Scheme
Method sourcePrepare is used to initialize resources needed during each call of Scheme.source(cascading.flow.FlowProcess, SourceCall).
sourcePrepare(FlowProcess<? extends Config>, SourceCall<Void, Input>) - Method in class cascading.tap.partition.BasePartitionTap.PartitionScheme
 
sources - Variable in class cascading.flow.BaseFlow
Field sources
sources - Variable in class cascading.flow.FlowDef
 
sources - Variable in class cascading.flow.planner.BaseFlowStep
Field sources
sources - Variable in class cascading.flow.planner.graph.FlowElementGraph
Field sources
SourceStage - Class in cascading.flow.stream.element
 
SourceStage(FlowProcess, Tap) - Constructor for class cascading.flow.stream.element.SourceStage
 
SourceTap<Config,Input> - Class in cascading.tap
Class SourceTap is an optional base class for source only Taps.
SourceTap() - Constructor for class cascading.tap.SourceTap
 
SourceTap(Scheme<Config, Input, ?, ?, ?>) - Constructor for class cascading.tap.SourceTap
 
sourceTaps - Variable in class cascading.flow.planner.BaseFlowNode
 
SparseTupleComparator - Class in cascading.flow.stream.util
 
SparseTupleComparator(Fields, Fields) - Constructor for class cascading.flow.stream.util.SparseTupleComparator
 
SparseTupleComparator(Fields, Comparator) - Constructor for class cascading.flow.stream.util.SparseTupleComparator
 
SparseTupleComparator(Fields, Fields, Comparator) - Constructor for class cascading.flow.stream.util.SparseTupleComparator
 
SPILL_CODECS - Static variable in class cascading.tuple.collect.SpillableProps
A comma delimited list of possible codecs to try.
SPILL_COMPRESS - Static variable in class cascading.tuple.collect.SpillableProps
Whether to enable compression of the spills or not, on by default.
Spillable - Interface in cascading.tuple.collect
 
Spillable.SpillListener - Interface in cascading.tuple.collect
 
Spillable.SpillStrategy - Interface in cascading.tuple.collect
 
SpillableProps - Class in cascading.tuple.collect
Class SpillableProps is a fluent interface for building properties to be passed to a FlowConnector before creating new Flow instances.
SpillableProps() - Constructor for class cascading.tuple.collect.SpillableProps
 
spillableProps() - Static method in class cascading.tuple.collect.SpillableProps
Creates a new SpillableProps instance.
SpillableTupleList - Class in cascading.tuple.collect
Class SpillableTupleList is a simple durable Collection that can spill its contents to disk when the threshold is met.
SpillableTupleList(int) - Constructor for class cascading.tuple.collect.SpillableTupleList
 
SpillableTupleList(Spillable.SpillStrategy) - Constructor for class cascading.tuple.collect.SpillableTupleList
 
SpillableTupleMap - Class in cascading.tuple.collect
SpillableTupleMap is a HashMap that will allow for multiple values per key, and if the number of values for a given key reach a specific threshold, they will be spilled to disk using a SpillableTupleList instance.
SpillableTupleMap(int, int) - Constructor for class cascading.tuple.collect.SpillableTupleMap
 
SpillableTupleMap(int, float, int, int) - Constructor for class cascading.tuple.collect.SpillableTupleMap
 
spillCount() - Method in interface cascading.tuple.collect.Spillable
The number of times this container has spilled data to disk.
spillCount() - Method in class cascading.tuple.collect.SpillableTupleList
 
spillCount() - Method in class cascading.tuple.collect.SpillableTupleMap
 
splice - Variable in class cascading.flow.stream.element.SpliceGate
 
Splice - Class in cascading.pipe
The base class for GroupBy, CoGroup, Merge, and HashJoin.
Splice(Pipe, Fields, Pipe, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Pipe, Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Pipe, Fields, Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Pipe, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Pipe, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe...) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe[], Fields[]) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields[]) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields[], Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields[], Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe[], Fields[], Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe[], Fields[], Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields[], Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Pipe, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Pipe, Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Pipe, Fields, Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Pipe, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Pipe, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe...) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, int, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, int, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, int, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, int, Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, int, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, int) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, int, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, int, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, int, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, int, Fields, Fields, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, int, Joiner) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, int) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance where grouping occurs on Fields.ALL fields.
Splice(Pipe, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe, Fields, Fields, boolean) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe, Fields, Fields, boolean) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe[], Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe[], Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields, Fields) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(Pipe[], Fields, Fields, boolean) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
Splice(String, Pipe[], Fields, Fields, boolean) - Constructor for class cascading.pipe.Splice
Constructor Splice creates a new Splice instance.
SpliceGate<Incoming,Outgoing> - Class in cascading.flow.stream.element
 
SpliceGate(FlowProcess, Splice) - Constructor for class cascading.flow.stream.element.SpliceGate
 
SpliceGate(FlowProcess, Splice, IORole) - Constructor for class cascading.flow.stream.element.SpliceGate
 
SplicePipeExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
SplicePipeExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.SplicePipeExpressionGraph
 
split(Class<T>, String) - Static method in class cascading.util.Util
 
split(Class<T>, String, String) - Static method in class cascading.util.Util
 
SplitBeforeEveryAssert - Class in cascading.flow.planner.rule.assertion
 
SplitBeforeEveryAssert() - Constructor for class cascading.flow.planner.rule.assertion.SplitBeforeEveryAssert
 
SplitBeforeEveryExpression - Class in cascading.flow.planner.rule.expression
 
SplitBeforeEveryExpression() - Constructor for class cascading.flow.planner.rule.expression.SplitBeforeEveryExpression
 
splitPattern - Variable in class cascading.scheme.util.DelimitedParser
Field splitPattern
STACK_TRACE_LINE_DELIMITER - Static variable in class cascading.tap.TrapProps
 
STACK_TRACE_LINE_TRIM - Static variable in class cascading.tap.TrapProps
 
stackTraceLineDelimiter - Variable in class cascading.tap.TrapProps
 
stackTraceTrimLine - Variable in class cascading.tap.TrapProps
 
Stage<Incoming,Outgoing> - Class in cascading.flow.stream.duct
 
Stage() - Constructor for class cascading.flow.stream.duct.Stage
 
start() - Method in class cascading.cascade.BaseCascade
 
start() - Method in interface cascading.cascade.Cascade
Method start begins the current Cascade process.
start() - Method in class cascading.flow.BaseFlow
 
start() - Method in interface cascading.flow.Flow
Method start begins the execution of this Flow instance.
start() - Method in class cascading.flow.planner.FlowStepJob
 
start() - Method in class cascading.flow.process.ProcessFlow
 
start(Duct) - Method in class cascading.flow.stream.duct.Duct
 
start(Duct) - Method in class cascading.flow.stream.duct.Fork
 
start(Duct) - Method in class cascading.flow.stream.duct.OpenDuct
 
start(Duct) - Method in class cascading.flow.stream.element.BufferEveryWindow
 
start(Duct) - Method in class cascading.flow.stream.element.MemoryCoGroupGate
 
start(Duct) - Method in class cascading.flow.stream.element.MergeStage
 
start(Duct) - Method in class cascading.flow.stream.element.SinkStage
 
start(long) - Method in class cascading.management.state.ClientState
 
start() - Method in interface cascading.management.UnitOfWork
 
start(UnitOfWork, int, Collection<Callable<Throwable>>) - Method in class cascading.management.UnitOfWorkExecutorStrategy
 
start(UnitOfWork, int, Collection<Callable<Throwable>>) - Method in interface cascading.management.UnitOfWorkSpawnStrategy
 
start(FlowProcess, AggregatorCall<Average.Context>) - Method in class cascading.operation.aggregator.Average
 
start(FlowProcess, AggregatorCall<Pair<Long[], Tuple>>) - Method in class cascading.operation.aggregator.Count
 
start(FlowProcess, AggregatorCall<Tuple[]>) - Method in class cascading.operation.aggregator.ExtentBase
 
start(FlowProcess, AggregatorCall<ExtremaValueBase.Context>) - Method in class cascading.operation.aggregator.ExtremaValueBase
 
start(FlowProcess, AggregatorCall<Context>) - Method in interface cascading.operation.Aggregator
Method start initializes the aggregation procedure and is called for every unique grouping.
start(FlowProcess, AggregatorCall<Pair<Double[], Tuple>>) - Method in class cascading.operation.aggregator.Sum
 
start(FlowProcess, GroupAssertionCall<AssertGroupBase.Context>) - Method in class cascading.operation.assertion.AssertGroupBase
 
start(FlowProcess, GroupAssertionCall<C>) - Method in interface cascading.operation.GroupAssertion
Method start initializes the aggregation procedure and is called for every unique grouping.
start(FlowProcess, AggregatorCall<AverageBy.AverageFinal.Context>) - Method in class cascading.pipe.assembly.AverageBy.AverageFinal
 
startGroup(Duct, Group) - Method in class cascading.flow.stream.duct.CloseReducingDuct
 
startGroup(Duct, Group) - Method in interface cascading.flow.stream.duct.Reducing
 
startGroup(Duct, TupleEntry) - Method in class cascading.flow.stream.element.AggregatorEveryStage
 
startGroup(Duct, TupleEntry) - Method in class cascading.flow.stream.element.GroupAssertionEveryStage
 
startService() - Method in class cascading.management.CascadingServices.NullDocumentService
 
startService() - Method in class cascading.management.CascadingServices.NullMetricsService
 
startService() - Method in class cascading.management.state.BaseState
May be called more than once.
startService() - Method in interface cascading.provider.CascadingService
May be called more than once, but only the first invocation will start the service.
startTime - Variable in class cascading.stats.CascadingStats
Field startTime
STATE_SERVICE_CLASS_PROPERTY - Static variable in class cascading.management.state.ClientState
 
STATEMENT_TYPES - Static variable in interface cascading.flow.FlowDescriptors
Denotes the type of statement in the current flow.
STATEMENTS - Static variable in interface cascading.flow.FlowDescriptors
Denotes a collection of statements like SQL or similar.
STATS_COMPLETE_CHILD_DETAILS_BLOCK_DURATION - Static variable in class cascading.stats.CascadingStats
 
STATS_STORE_INTERVAL - Static variable in class cascading.stats.CascadingStats
 
StatsListener - Interface in cascading.stats
For internal use to track status transitions
statsStoreInterval - Variable in class cascading.flow.planner.FlowStepJob
Field recordStatsInterval
Status - Class in cascading.operation.state
Class Status is a Filter that sets the current FlowProcess 'status' on the first Tuple it sees.
Status(String) - Constructor for class cascading.operation.state.Status
Constructor Status creates a new Status instance.
status - Variable in class cascading.stats.CascadingStats
Field status
stepConfigDef - Variable in class cascading.pipe.Pipe
 
StepCounters - Enum in cascading.flow
Enum StepCounters lists all counters
stepName - Variable in class cascading.flow.planner.FlowStepJob
Field stepName
steps - Variable in class cascading.flow.BaseFlow
Field steps
stepsAreLocal() - Method in interface cascading.flow.Flow
Method jobsAreLocal returns true if all jobs are executed in-process as a single map and reduce task.
stepsAreLocal() - Method in class cascading.flow.process.ProcessFlow
 
stop() - Method in class cascading.cascade.BaseCascade.CascadeJob
 
stop() - Method in class cascading.cascade.BaseCascade
 
stop() - Method in interface cascading.cascade.Cascade
 
stop - Variable in class cascading.flow.BaseFlow
Field stop
stop() - Method in class cascading.flow.BaseFlow
 
stop() - Method in interface cascading.flow.Flow
Method stop stops all running jobs, killing any currently executing.
stop() - Method in class cascading.flow.planner.FlowStepJob
 
stop() - Method in class cascading.flow.process.ProcessFlow
 
stop(long) - Method in class cascading.management.state.ClientState
 
stop() - Method in interface cascading.management.UnitOfWork
 
STOP_JOBS_ON_EXIT - Static variable in class cascading.flow.FlowProps
 
stopJobsOnExit - Variable in class cascading.flow.BaseFlow
Field stopJobsOnExit
stopService() - Method in class cascading.management.CascadingServices.NullDocumentService
 
stopService() - Method in class cascading.management.CascadingServices.NullMetricsService
 
stopService() - Method in class cascading.management.state.BaseState
 
stopService() - Method in interface cascading.provider.CascadingService
May be called more than once, but only the first invocation will stop the service.
store(String, Object) - Method in class cascading.management.state.BaseState
 
StreamComparator<T extends InputStream> - Interface in cascading.tuple
The StreamComparator interface allows for two InputStream instances to be compared, typically bit-wise.
streamedSource - Variable in class cascading.flow.stream.graph.NodeStreamGraph
 
StreamGraph - Class in cascading.flow.stream.graph
Class StreamGraph is the operation pipeline used during processing.
StreamGraph() - Constructor for class cascading.flow.stream.graph.StreamGraph
 
StreamMode - Enum in cascading.flow.stream.annotations
 
strict - Variable in class cascading.scheme.util.DelimitedParser
Field strict
STRING - Static variable in class cascading.tuple.coerce.Coercions
 
StringCoerce - Class in cascading.tuple.coerce
 
StringCoerce(Map<Type, Coercions.Coerce>) - Constructor for class cascading.tuple.coerce.StringCoerce
 
StringEdgeNameProvider<E> - Class in cascading.util.jgrapht
 
StringEdgeNameProvider() - Constructor for class cascading.util.jgrapht.StringEdgeNameProvider
 
stringifyStackTrace(Throwable, String, boolean, int) - Static method in class cascading.util.TraceUtil
 
StringNameProvider<V> - Class in cascading.util.jgrapht
 
StringNameProvider() - Constructor for class cascading.util.jgrapht.StringNameProvider
 
SubAssembly - Class in cascading.pipe
Subclasses of SubAssembly encapsulate complex assemblies of Pipes so they my be reused in the same manner a Pipe is used.
SubAssembly() - Constructor for class cascading.pipe.SubAssembly
 
SubAssembly(Pipe...) - Constructor for class cascading.pipe.SubAssembly
 
SubAssembly(String, Pipe[]) - Constructor for class cascading.pipe.SubAssembly
 
SubGraphIterator - Interface in cascading.flow.planner.iso.subgraph
 
SubGraphTransformer - Class in cascading.flow.planner.iso.transformer
Class SubGraphTransformer will return a bounded sub-graph after matching a sub-graph within a contracted graph.
SubGraphTransformer(GraphTransformer, ExpressionGraph) - Constructor for class cascading.flow.planner.iso.transformer.SubGraphTransformer
 
subGraphTransformer - Variable in class cascading.flow.planner.rule.RuleTransformer
 
submit(long) - Method in class cascading.management.state.ClientState
 
submitCallables(List<Callable<RuleResult>>) - Method in class cascading.flow.planner.rule.RuleSetExec
 
submitTime - Variable in class cascading.stats.CascadingStats
Field submitTime
submitWithTimeout(Callable<Boolean>, int, TimeUnit) - Static method in class cascading.util.Util
 
subtract(Fields) - Method in class cascading.tuple.Fields
Method subtract returns the difference between this instance and the given fields instance.
successorListOf(FlowElement) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
successorListOf(FlowElement) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
successorListOf(FlowElement) - Method in interface cascading.flow.planner.graph.ElementGraph
 
Sum - Class in cascading.operation.aggregator
Class Sum is an Aggregator that returns the sum of all numeric values in the current group.
Sum() - Constructor for class cascading.operation.aggregator.Sum
Constructor Sum creates a new Sum instance that accepts one argument and returns a single field named "sum".
Sum(Fields) - Constructor for class cascading.operation.aggregator.Sum
Constructs a new instance that returns the fields declared in fieldDeclaration and accepts only 1 argument.
Sum(Fields, Class) - Constructor for class cascading.operation.aggregator.Sum
Constructs a new instance that returns the fields declared in fieldDeclaration and accepts only 1 argument.
SumBy - Class in cascading.pipe.assembly
Class SumBy is used to sum values associated with duplicate keys in a tuple stream.
SumBy(Fields, Fields) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe, Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe, Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe[], Fields, Fields, Fields) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe[], Fields, Fields, Fields, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Fields, Fields, Class) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe, Fields, Fields, Fields, Class) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe, Fields, Fields, Fields, Class, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe, Fields, Fields, Fields, Class) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe, Fields, Fields, Fields, Class, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe[], Fields, Fields, Fields, Class) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(Pipe[], Fields, Fields, Fields, Class, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe[], Fields, Fields, Fields, Class) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy(String, Pipe[], Fields, Fields, Fields, Class, int) - Constructor for class cascading.pipe.assembly.SumBy
Constructor SumBy creates a new SumBy instance.
SumBy.SumPartials - Class in cascading.pipe.assembly
Class SumPartials is a AggregateBy.Functor that is used to sum observed duplicates from the tuple stream.
SumBy.SumPartials(Fields) - Constructor for class cascading.pipe.assembly.SumBy.SumPartials
Constructor SumPartials creates a new SumPartials instance.
SumBy.SumPartials(Fields, Class) - Constructor for class cascading.pipe.assembly.SumBy.SumPartials
 
supportsFind() - Method in class cascading.management.CascadingServices.NullDocumentService
 
supportsFind() - Method in interface cascading.management.DocumentService
 
supportsNonRecursiveMatch() - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
supportsPlannerLevel(PlannerLevel) - Method in class cascading.operation.assertion.AssertMatches
 
supportsPlannerLevel(PlannerLevel) - Method in class cascading.operation.assertion.AssertMatchesAll
 
supportsPlannerLevel(PlannerLevel) - Method in class cascading.operation.assertion.BaseAssertion
 
supportsPlannerLevel(PlannerLevel) - Method in class cascading.operation.Debug
 
supportsPlannerLevel(PlannerLevel) - Method in interface cascading.operation.PlannedOperation
 
SWAP - Static variable in class cascading.tuple.Fields
Field SWAP represents all fields not used as arguments for the current operation and the operations results.
SyncPipeExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
SyncPipeExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.SyncPipeExpressionGraph
 

T

tags - Variable in class cascading.property.AppProps
 
tags - Variable in class cascading.property.UnitOfWorkDef
 
tails - Variable in class cascading.flow.FlowDef
 
Tap<Config,Input,Output> - Class in cascading.tap
A Tap represents the physical data source or sink in a connected Flow.
Tap() - Constructor for class cascading.tap.Tap
 
Tap(Scheme<Config, Input, Output, ?, ?>) - Constructor for class cascading.tap.Tap
 
Tap(Scheme<Config, Input, Output, ?, ?>, SinkMode) - Constructor for class cascading.tap.Tap
 
TapException - Exception in cascading.tap
Class TapException is thrown from Tap and Scheme subclasses.
TapException() - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapException(String) - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapException(String, Throwable) - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapException(String, Throwable, Tuple) - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapException(String, Tuple) - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapException(Throwable) - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapException(Tap, Fields, Fields, Throwable) - Constructor for exception cascading.tap.TapException
Constructor TapException creates a new TapException instance.
TapGraph - Class in cascading.cascade.planner
 
TapGraph(Collection<Flow>) - Constructor for class cascading.cascade.planner.TapGraph
 
TapGraph(Flow...) - Constructor for class cascading.cascade.planner.TapGraph
 
TapGroupTapExpressionGraph - Class in cascading.flow.planner.rule.expressiongraph
 
TapGroupTapExpressionGraph() - Constructor for class cascading.flow.planner.rule.expressiongraph.TapGroupTapExpressionGraph
 
TapOrBoundaryElementExpression - Class in cascading.flow.planner.rule.elementexpression
 
TapOrBoundaryElementExpression() - Constructor for class cascading.flow.planner.rule.elementexpression.TapOrBoundaryElementExpression
 
TapOrBoundaryElementExpression(TypeExpression.Topo) - Constructor for class cascading.flow.planner.rule.elementexpression.TapOrBoundaryElementExpression
 
TapOrBoundaryElementExpression(ElementCapture) - Constructor for class cascading.flow.planner.rule.elementexpression.TapOrBoundaryElementExpression
 
TapOrBoundaryElementExpression(ElementCapture, TypeExpression.Topo) - Constructor for class cascading.flow.planner.rule.elementexpression.TapOrBoundaryElementExpression
 
taps - Variable in class cascading.tap.MultiSourceTap
 
taps(Tap...) - Static method in class cascading.tap.Tap
Convenience function to make an array of Tap instances.
tapsMap(String, Tap) - Static method in class cascading.cascade.Cascades
Method tapsMap creates a new Map for the given name and tap.
tapsMap(String[], Tap[]) - Static method in class cascading.cascade.Cascades
Method tapsMap creates a new Map for each name and tap.
tapsMap(Pipe, Tap) - Static method in class cascading.cascade.Cascades
Method tapsMap creates a new Map using the given Pipe name and tap.
tapsMap(Pipe[], Tap[]) - Static method in class cascading.cascade.Cascades
Method tapsMap creates a new Map using the given pipes and taps.
tearDown() - Method in class cascading.CascadingTestCase
 
TEMP_TAP - Static variable in class cascading.flow.planner.rule.transformer.IntermediateTapElementFactory
 
TEMPORARY_TAP_DECORATOR_CLASS - Static variable in class cascading.flow.FlowConnectorProps
 
tempSink - Variable in class cascading.flow.planner.BaseFlowStep
Field tempSink
TEST_TRACEPLAN_ENABLED - Static variable in class cascading.CascadingTestCase
 
thread - Variable in class cascading.flow.BaseFlow
Field thread
THRESHOLD_SECONDS - Static variable in class cascading.flow.planner.rule.RuleResult
 
throwable - Variable in class cascading.flow.planner.FlowStepJob
Field throwable
throwable - Variable in class cascading.stats.CascadingStats
Field throwable
throwableTrace - Variable in class cascading.stats.CascadingStats
Field throwableTrace
throwFail(String) - Static method in class cascading.operation.assertion.BaseAssertion
Static method throwFail should be used to throw an AssertionException.
throwFail(String, Object...) - Static method in class cascading.operation.assertion.BaseAssertion
Static method throwFail should be used to throw an AssertionException.
timeout - Variable in class cascading.stats.CounterCache
 
toArray() - Method in class cascading.tuple.collect.SpillableTupleList
 
toArray(T[]) - Method in class cascading.tuple.collect.SpillableTupleList
 
toNull(Object) - Static method in class cascading.util.Util
This method returns the Object.toString() of the given object, or an empty String if the object is null.
toPartition(TupleEntry) - Method in class cascading.tap.partition.DelimitedPartition
 
toPartition(TupleEntry) - Method in interface cascading.tap.partition.Partition
Converts the given tupleEntry into a partition string.
TopologyGraph<Vertex> - Class in cascading.cascade.planner
 
TopologyGraph(Flow...) - Constructor for class cascading.cascade.planner.TopologyGraph
 
toString() - Method in class cascading.cascade.BaseCascade
 
toString() - Method in class cascading.flow.BaseFlow
 
toString() - Method in class cascading.flow.planner.BaseFlowStep
 
toString() - Method in enum cascading.flow.planner.graph.Extent
 
toString() - Method in class cascading.flow.planner.iso.expression.AndElementExpression
 
toString() - Method in class cascading.flow.planner.iso.expression.AnnotationExpression
 
toString() - Method in class cascading.flow.planner.iso.expression.ElementExpression
 
toString() - Method in class cascading.flow.planner.iso.expression.NotElementExpression
 
toString() - Method in class cascading.flow.planner.iso.expression.OrElementExpression
 
toString() - Method in class cascading.flow.planner.iso.expression.PathScopeExpression
 
toString() - Method in class cascading.flow.planner.iso.expression.TypeExpression
 
toString() - Method in class cascading.flow.planner.iso.finder.Match
 
toString() - Method in class cascading.flow.planner.PlannerInfo
 
toString() - Method in class cascading.flow.planner.PlatformInfo
 
toString() - Method in class cascading.flow.planner.rule.RuleAssert
 
toString() - Method in class cascading.flow.planner.rule.RulePartitioner
 
toString() - Method in class cascading.flow.planner.rule.RuleTransformer
 
toString() - Method in class cascading.flow.planner.Scope
 
toString() - Method in class cascading.flow.process.ProcessFlow
 
toString() - Method in class cascading.flow.stream.duct.Duct
 
toString() - Method in class cascading.flow.stream.duct.DuctGraph.Ordinal
 
toString() - Method in class cascading.flow.stream.element.ElementStage
 
toString() - Method in class cascading.flow.stream.element.GroupingSpliceGate
 
toString() - Method in class cascading.operation.BaseOperation
 
toString() - Method in class cascading.pipe.Operator
 
toString() - Method in class cascading.pipe.Pipe
 
toString() - Method in class cascading.pipe.Splice
 
toString() - Method in class cascading.scheme.NullScheme
 
toString() - Method in class cascading.scheme.Scheme
 
toString() - Method in class cascading.stats.CascadeStats
 
toString() - Method in class cascading.stats.CascadingStats
 
toString() - Method in class cascading.stats.FlowNodeStats
 
toString() - Method in class cascading.stats.FlowStats
 
toString() - Method in class cascading.stats.FlowStepStats
 
toString() - Method in class cascading.tap.DecoratorTap
 
toString() - Method in class cascading.tap.MultiSinkTap
 
toString() - Method in class cascading.tap.MultiSourceTap
 
toString() - Method in class cascading.tap.partition.BasePartitionTap
 
toString() - Method in class cascading.tap.Tap
 
toString() - Method in class cascading.tuple.Fields
 
toString() - Method in class cascading.tuple.io.IndexTuple
 
toString() - Method in class cascading.tuple.io.TuplePair
 
toString() - Method in class cascading.tuple.Tuple
 
toString(String) - Method in class cascading.tuple.Tuple
Method toString writes this Tuple instance values out to a String delimited by the given String value.
toString(String, boolean) - Method in class cascading.tuple.Tuple
Method toString writes this Tuple instance values out to a String delimited by the given String value.
toString() - Method in class cascading.tuple.TupleEntry
 
toString() - Method in class cascading.tuple.type.DateType
 
toString() - Method in class cascading.util.MultiMap
 
toString() - Method in class cascading.util.Pair
 
toStringInternal(Operation) - Static method in class cascading.operation.BaseOperation
 
toTuple(String, TupleEntry) - Method in class cascading.tap.partition.DelimitedPartition
 
toTuple(String, TupleEntry) - Method in interface cascading.tap.partition.Partition
Converts the given partition String to a TupleEntry using the given TupleEntry instance for re-use.
TRACE - Static variable in interface cascading.flow.FlowNodeDescriptors
Code or line numbers to identify the code this node is executing
trace - Variable in class cascading.operation.BaseOperation
Field trace
TRACE_PLAN_PATH - Static variable in class cascading.flow.planner.FlowPlanner
Enables the planner to write out basic planner information including the initial element-graph, completed element-graph, and the completed step-graph dot files.
TRACE_PLAN_TRANSFORM_PATH - Static variable in class cascading.flow.planner.FlowPlanner
Enables the planner to write out detail level planner information for each rule, including recursive transforms.
TRACE_STATS_PATH - Static variable in class cascading.flow.planner.FlowPlanner
Enables the planner to write out planner statistics for each planner phase and rule.
Traceable - Interface in cascading.util
Indicates that a class has trace fields usable from TraceUtil
TraceUtil - Class in cascading.util
 
TraceUtil() - Constructor for class cascading.util.TraceUtil
 
TraceWriter - Class in cascading.flow.planner.rule.util
 
TraceWriter() - Constructor for class cascading.flow.planner.rule.util.TraceWriter
 
TraceWriter(Flow) - Constructor for class cascading.flow.planner.rule.util.TraceWriter
 
transform(PlannerContext, E) - Method in class cascading.flow.planner.iso.assertion.GraphAssert
 
transform(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.transformer.ContractedTransformer
 
transform(In) - Method in class cascading.flow.planner.iso.transformer.GraphTransformer
 
transform(PlannerContext, In) - Method in class cascading.flow.planner.iso.transformer.GraphTransformer
 
transform(PlannerContext, E) - Method in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
transform(ProcessLogger, Transformed<E>, E, int, int) - Method in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
transform(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.iso.transformer.SubGraphTransformer
 
transform(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.rule.RuleAssert
 
transform(PlannerContext, ElementGraph) - Method in class cascading.flow.planner.rule.RuleTransformer
 
TRANSFORM_RECURSION_DEPTH_MAX - Static variable in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
Graphs must be transformed iteratively.
Transformed<E extends ElementGraph> - Class in cascading.flow.planner.iso.transformer
 
Transformed(PlannerContext, GraphTransformer, ElementGraph) - Constructor for class cascading.flow.planner.iso.transformer.Transformed
 
Transformed(PlannerContext, GraphTransformer, ExpressionGraph, ElementGraph) - Constructor for class cascading.flow.planner.iso.transformer.Transformed
 
transformGraphInPlaceUsing(Transformed<ElementGraph>, ElementGraph, Match) - Method in class cascading.flow.planner.iso.transformer.AnnotateGraphTransformer
 
transformGraphInPlaceUsing(Transformed<ElementGraph>, ElementGraph, Match) - Method in class cascading.flow.planner.iso.transformer.ContractedGraphTransformer
 
transformGraphInPlaceUsing(Transformed<ElementGraph>, ElementGraph, Match) - Method in class cascading.flow.planner.iso.transformer.ContractedTransformer
 
transformGraphInPlaceUsing(Transformed<ElementGraph>, ElementGraph, Match) - Method in class cascading.flow.planner.iso.transformer.InsertionGraphTransformer
 
transformGraphInPlaceUsing(Transformed<E>, E, Match) - Method in class cascading.flow.planner.iso.transformer.RecursiveGraphTransformer
 
transformGraphInPlaceUsing(Transformed<ElementGraph>, ElementGraph, Match) - Method in class cascading.flow.planner.iso.transformer.RemoveBranchGraphTransformer
 
transformGraphInPlaceUsing(Transformed<ElementGraph>, ElementGraph, Match) - Method in class cascading.flow.planner.iso.transformer.ReplaceGraphTransformer
 
TrapException - Exception in cascading.flow.stream
TrapException is a pass through exception allowing trap io failures to propagate past upstream traps.
TrapException(String, Throwable) - Constructor for exception cascading.flow.stream.TrapException
 
trapHandler - Variable in class cascading.flow.stream.element.ElementStage
 
TrapHandler - Class in cascading.flow.stream.element
 
TrapHandler(FlowProcess) - Constructor for class cascading.flow.stream.element.TrapHandler
 
TrapHandler(FlowProcess, FlowElement, Tap, String) - Constructor for class cascading.flow.stream.element.TrapHandler
 
TrapProps - Class in cascading.tap
Class TrapProps is a fluent helper class to set properties which control the behaviour of Tap instances used as traps on a given Flow.
TrapProps() - Constructor for class cascading.tap.TrapProps
 
trapProps() - Static method in class cascading.tap.TrapProps
 
traps - Variable in class cascading.flow.FlowDef
 
traps - Variable in class cascading.flow.planner.graph.FlowElementGraph
Field traps
trapsMap - Variable in class cascading.flow.planner.process.BaseProcessGraph
 
truncate(String, int) - Static method in class cascading.util.Util
This method truncates the given String value to the given size, but appends an ellipse ("...") if the String is larger than maxSize.
Tuple - Class in cascading.tuple
A Tuple represents a set of values.
Tuple(List<Object>) - Constructor for class cascading.tuple.Tuple
 
Tuple() - Constructor for class cascading.tuple.Tuple
Constructor Tuple creates a new Tuple instance.
Tuple(Tuple) - Constructor for class cascading.tuple.Tuple
Copy constructor.
Tuple(Object...) - Constructor for class cascading.tuple.Tuple
Constructor Tuple creates a new Tuple instance with all the given values.
tuple(Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object, Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object, Object, Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object, Object, Object, Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object, Object, Object, Object, Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
tuple(Object, Object, Object, Object, Object, Object, Object, Object) - Static method in class cascading.tuple.Tuples
A utility function for use with Janino expressions to get around its lack of support for varargs.
TUPLE_COLLECTION_FACTORY - Static variable in interface cascading.tuple.collect.TupleCollectionFactory
 
TUPLE_MAP_FACTORY - Static variable in interface cascading.tuple.collect.TupleMapFactory
 
TupleBuilder - Class in cascading.tuple.util
 
TupleBuilder() - Constructor for class cascading.tuple.util.TupleBuilder
 
TupleChainIterable - Class in cascading.tuple
TupleChainIterator chains the given Iterators into a single Iterator.
TupleChainIterable(Iterable<Tuple>, Iterable<Tuple>...) - Constructor for class cascading.tuple.TupleChainIterable
 
TupleChainIterator - Class in cascading.tuple
TupleChainIterator chains the given Iterators into a single Iterator.
TupleChainIterator(Iterator<Tuple>...) - Constructor for class cascading.tuple.TupleChainIterator
 
TupleCollectionFactory<Config> - Interface in cascading.tuple.collect
Interface TupleCollectionFactory allows developers to plugin alternative implementations of a "tuple collection" used to back in memory "join" and "co-group" operations.
TupleEntry - Class in cascading.tuple
Class TupleEntry allows a Tuple instance and its declaring Fields instance to be used as a single object.
TupleEntry() - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
TupleEntry(boolean) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
TupleEntry(Fields) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
TupleEntry(Fields, boolean) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
TupleEntry(Fields, Tuple, boolean) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
TupleEntry(Fields, Tuple) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
TupleEntry(TupleEntry) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance that is a safe copy of the given tupleEntry.
TupleEntry(Tuple) - Constructor for class cascading.tuple.TupleEntry
Constructor TupleEntry creates a new TupleEntry instance.
tupleEntry - Variable in class cascading.tuple.TupleEntryCollector
 
TupleEntryChainIterator - Class in cascading.tuple
TupleEntryChainIterator chains the given Iterators into a single Iterator.
TupleEntryChainIterator(Fields) - Constructor for class cascading.tuple.TupleEntryChainIterator
 
TupleEntryChainIterator(Fields, Iterator<Tuple>) - Constructor for class cascading.tuple.TupleEntryChainIterator
 
TupleEntryChainIterator(Fields, Iterator<Tuple>[]) - Constructor for class cascading.tuple.TupleEntryChainIterator
 
TupleEntryCollector - Class in cascading.tuple
Interface TupleEntryCollector is used to allow BaseOperation instances to emit one or more result Tuple values.
TupleEntryCollector() - Constructor for class cascading.tuple.TupleEntryCollector
 
TupleEntryCollector(Fields) - Constructor for class cascading.tuple.TupleEntryCollector
Constructor TupleCollector creates a new TupleCollector instance.
TupleEntryIterableChainIterator - Class in cascading.tuple
TupleEntryChainIterator chains the given Iterators into a single Iterator.
TupleEntryIterableChainIterator(Fields) - Constructor for class cascading.tuple.TupleEntryIterableChainIterator
 
TupleEntryIterableChainIterator(Fields, Iterable<Iterator<Tuple>>) - Constructor for class cascading.tuple.TupleEntryIterableChainIterator
 
tupleEntryIterator - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
TupleEntryIterator - Class in cascading.tuple
Class TupleEntryIterator provides an efficient Iterator for returning TupleEntry elements in an underlying Tuple collection.
TupleEntryIterator(Fields) - Constructor for class cascading.tuple.TupleEntryIterator
Constructor TupleEntryIterator creates a new TupleEntryIterator instance.
TupleEntrySchemeCollector<Config,Output> - Class in cascading.tuple
Class TupleEntrySchemeCollector is a helper class for wrapping a Scheme instance, calling Scheme.sink(cascading.flow.FlowProcess, cascading.scheme.SinkCall) on every call to TupleEntrySchemeCollector.add(TupleEntry) or TupleEntrySchemeCollector.add(Tuple).
TupleEntrySchemeCollector(FlowProcess<? extends Config>, Scheme) - Constructor for class cascading.tuple.TupleEntrySchemeCollector
 
TupleEntrySchemeCollector(FlowProcess<? extends Config>, Scheme, String) - Constructor for class cascading.tuple.TupleEntrySchemeCollector
 
TupleEntrySchemeCollector(FlowProcess<? extends Config>, Scheme, Output) - Constructor for class cascading.tuple.TupleEntrySchemeCollector
 
TupleEntrySchemeCollector(FlowProcess<? extends Config>, Tap, Output) - Constructor for class cascading.tuple.TupleEntrySchemeCollector
 
TupleEntrySchemeCollector(FlowProcess<? extends Config>, Scheme, Output, String) - Constructor for class cascading.tuple.TupleEntrySchemeCollector
 
TupleEntrySchemeIterator<Config,Input> - Class in cascading.tuple
Class TupleEntrySchemeIterator is a helper class for wrapping a Scheme instance, calling Scheme.source(cascading.flow.FlowProcess, cascading.scheme.SourceCall) on every call to TupleEntrySchemeIterator.next().
TupleEntrySchemeIterator(FlowProcess<? extends Config>, Scheme, Input) - Constructor for class cascading.tuple.TupleEntrySchemeIterator
 
TupleEntrySchemeIterator(FlowProcess<? extends Config>, Scheme, Input, String) - Constructor for class cascading.tuple.TupleEntrySchemeIterator
 
TupleEntrySchemeIterator(FlowProcess<? extends Config>, Scheme, CloseableIterator<Input>) - Constructor for class cascading.tuple.TupleEntrySchemeIterator
 
TupleEntrySchemeIterator(FlowProcess<? extends Config>, Scheme, CloseableIterator<Input>, String) - Constructor for class cascading.tuple.TupleEntrySchemeIterator
 
TupleEntrySchemeIteratorProps - Class in cascading.tuple
Class TupleEntrySchemeIteratorProps is a fluent helper class to set properties which control the behavior of the TupleEntrySchemeIterator.
TupleEntrySchemeIteratorProps() - Constructor for class cascading.tuple.TupleEntrySchemeIteratorProps
Constructs a new TupleEntrySchemeIteratorProps instance.
tupleEntrySchemeIteratorProps() - Static method in class cascading.tuple.TupleEntrySchemeIteratorProps
Creates a new TupleEntrySchemeIteratorProps instance.
TupleException - Exception in cascading.tuple
Class TupleException is thrown by the Tuple, Fields and TupleEntry classes.
TupleException() - Constructor for exception cascading.tuple.TupleException
Constructor TupleException creates a new TupleException instance.
TupleException(String) - Constructor for exception cascading.tuple.TupleException
Constructor TupleException creates a new TupleException instance.
TupleException(String, Throwable) - Constructor for exception cascading.tuple.TupleException
Constructor TupleException creates a new TupleException instance.
TupleException(Throwable) - Constructor for exception cascading.tuple.TupleException
Constructor TupleException creates a new TupleException instance.
TupleHasher - Class in cascading.tuple.util
 
TupleHasher() - Constructor for class cascading.tuple.util.TupleHasher
 
TupleHasher(Comparator, Comparator[]) - Constructor for class cascading.tuple.util.TupleHasher
 
TupleHasher.HashFunction - Class in cascading.tuple.util
 
TupleHasher.HashFunction() - Constructor for class cascading.tuple.util.TupleHasher.HashFunction
 
TupleInputStream - Class in cascading.tuple.io
Class TupleInputStream is used internally to read Tuples from storage.
TupleInputStream(InputStream, TupleInputStream.ElementReader) - Constructor for class cascading.tuple.io.TupleInputStream
 
TupleInputStream.ElementReader - Interface in cascading.tuple.io
 
TupleInputStream.TupleElementReader<T extends TupleInputStream> - Interface in cascading.tuple.io
 
TupleListCollector - Class in cascading.tuple
TupleEntryCollector is a convenience class for managing a list of tuples.
TupleListCollector(Fields, Tuple...) - Constructor for class cascading.tuple.TupleListCollector
Constructor TupleEntryCollector creates a new TupleEntryCollector instance.
TupleListCollector(Fields, boolean) - Constructor for class cascading.tuple.TupleListCollector
Constructor TupleListCollector creates a new TupleListCollector instance.
TupleMapFactory<Config> - Interface in cascading.tuple.collect
Interface TupleMapFactory allows developers to plugin alternative implementations of a "tuple map" used to back in memory "join" and "co-group" operations.
TupleOutputStream - Class in cascading.tuple.io
Class TupleOutputStream is used internally to write Tuples to storage.
TupleOutputStream(Map<Class, TupleOutputStream.TupleElementWriter>, Map<Class, TupleOutputStream.TupleElementWriter>, OutputStream, TupleOutputStream.ElementWriter) - Constructor for class cascading.tuple.io.TupleOutputStream
 
TupleOutputStream.ElementWriter - Interface in cascading.tuple.io
 
TupleOutputStream.TupleElementWriter - Interface in cascading.tuple.io
 
TuplePair - Class in cascading.tuple.io
Class TuplePair is a utility class that is optimized to hold two Tuple instances for sorting and hashing of each part independently.
TuplePair() - Constructor for class cascading.tuple.io.TuplePair
Constructor Tuple creates a new Tuple instance.
TuplePair(Tuple, Tuple) - Constructor for class cascading.tuple.io.TuplePair
Constructor TuplePair creates a new TuplePair instance.
tuples(TuplePair) - Static method in class cascading.tuple.io.TuplePair
Returns a reference to the private tuples of the given TuplePark
Tuples - Class in cascading.tuple
Class Tuples is a helper class providing common methods to manipulate Tuple and TupleEntry instances.
Tuples() - Constructor for class cascading.tuple.Tuples
 
TupleViews - Class in cascading.tuple.util
This class is experimental and for internal use only.
TupleViews() - Constructor for class cascading.tuple.util.TupleViews
 
TypeExpression<Type> - Class in cascading.flow.planner.iso.expression
 
TypeExpression(ElementCapture, boolean, Class<? extends Type>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(ElementCapture, boolean, Class<? extends Type>) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(ElementCapture, Class<? extends Type>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(ElementCapture, Class<? extends Type>) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(boolean, Class<? extends Type>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(boolean, Class<? extends Type>) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(Class<? extends Type>, TypeExpression.Topo) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression(Class<? extends Type>) - Constructor for class cascading.flow.planner.iso.expression.TypeExpression
 
TypeExpression.Topo - Enum in cascading.flow.planner.iso.expression
 
typeNames(Type[]) - Static method in class cascading.util.Util
 
types - Variable in class cascading.scheme.util.DelimitedParser
Field types
types - Static variable in class cascading.tuple.coerce.Coercions
 
types(Type...) - Static method in class cascading.tuple.Fields
 

U

undelegate(FlowProcess) - Static method in class cascading.flow.FlowProcessWrapper
 
UnGroup - Class in cascading.operation.function
Class UnGroup is a Function that will 'un-group' data from a given dataset.
UnGroup(Fields, Fields[]) - Constructor for class cascading.operation.function.UnGroup
Constructor UnGroup creates a new UnGroup instance.
UnGroup(Fields, Fields, Fields[]) - Constructor for class cascading.operation.function.UnGroup
Constructor UnGroup creates a new UnGroup instance.
UnGroup(Fields, Fields, int) - Constructor for class cascading.operation.function.UnGroup
Constructor UnGroup creates a new UnGroup instance.
Unique - Class in cascading.pipe.assembly
Class Unique SubAssembly is used to filter all duplicates out of a tuple stream.
Unique(Pipe, Fields) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe, Fields, Unique.Include) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe, Fields, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe, Fields, Unique.Include, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe, Fields) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe, Fields, Unique.Include) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe, Fields, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe, Fields, Unique.Include, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe[], Fields) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe[], Fields, Unique.Include) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe[], Fields, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(Pipe[], Fields, Unique.Include, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe[], Fields) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe[], Fields, Unique.Include) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe[], Fields, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
Unique(String, Pipe[], Fields, Unique.Include, int) - Constructor for class cascading.pipe.assembly.Unique
Constructor Unique creates a new Unique instance.
unique(String, String) - Static method in class cascading.util.Util
 
Unique.Cache - Enum in cascading.pipe.assembly
 
Unique.FilterPartialDuplicates - Class in cascading.pipe.assembly
Class FilterPartialDuplicates is a Filter that is used to remove observed duplicates from the tuple stream.
Unique.FilterPartialDuplicates() - Constructor for class cascading.pipe.assembly.Unique.FilterPartialDuplicates
Constructor FilterPartialDuplicates creates a new FilterPartialDuplicates instance.
Unique.FilterPartialDuplicates(int) - Constructor for class cascading.pipe.assembly.Unique.FilterPartialDuplicates
Constructor FilterPartialDuplicates creates a new FilterPartialDuplicates instance.
Unique.FilterPartialDuplicates(Unique.Include, int) - Constructor for class cascading.pipe.assembly.Unique.FilterPartialDuplicates
Constructor FilterPartialDuplicates creates a new FilterPartialDuplicates instance.
Unique.FilterPartialDuplicates(Unique.Include, int, TupleHasher) - Constructor for class cascading.pipe.assembly.Unique.FilterPartialDuplicates
Constructor FilterPartialDuplicates creates a new FilterPartialDuplicates instance.
Unique.Include - Enum in cascading.pipe.assembly
 
UNIQUE_CACHE_CAPACITY - Static variable in class cascading.pipe.assembly.UniqueProps
property to control the capacity of the cache to use.
UNIQUE_CACHE_FACTORY - Static variable in class cascading.pipe.assembly.UniqueProps
property to control the cache factory used in Unique.
UNIQUE_DEFAULT_CAPACITY - Static variable in class cascading.pipe.assembly.UniqueProps
default capacity of caches used in Unique.
UniquePathGraphPartitioner - Class in cascading.flow.planner.iso.subgraph.partitioner
 
UniquePathGraphPartitioner(ExpressionGraph, ExpressionGraph, ElementAnnotation...) - Constructor for class cascading.flow.planner.iso.subgraph.partitioner.UniquePathGraphPartitioner
 
UniquePathGraphPartitioner(ExpressionGraph, ExpressionGraph, boolean, ElementAnnotation...) - Constructor for class cascading.flow.planner.iso.subgraph.partitioner.UniquePathGraphPartitioner
 
UniquePathRulePartitioner - Class in cascading.flow.planner.rule.partitioner
Class UniquePathRulePartitioner relies on a RuleExpression to identify sub-graphs as initial partitions, then will partition the resulting graph into a unique sub-graph for each unique path between the head and tail of the graph.
UniquePathRulePartitioner(PlanPhase, RuleExpression) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase, RuleExpression, ElementAnnotation...) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase, RuleExpression, Enum...) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase, RulePartitioner.PartitionSource, RuleExpression) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase, RulePartitioner.PartitionSource, RuleExpression, ElementAnnotation...) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase, RulePartitioner.PartitionSource, RuleExpression, Enum...) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase, GraphPartitioner) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner(PlanPhase) - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathRulePartitioner() - Constructor for class cascading.flow.planner.rule.partitioner.UniquePathRulePartitioner
 
UniquePathSubGraphIterator - Class in cascading.flow.planner.iso.subgraph.iterator
 
UniquePathSubGraphIterator(SubGraphIterator, boolean) - Constructor for class cascading.flow.planner.iso.subgraph.iterator.UniquePathSubGraphIterator
 
UniqueProps - Class in cascading.pipe.assembly
Class UniqueProps is a fluent helper for setting various properties related to the cache used in Unique.
UniqueProps() - Constructor for class cascading.pipe.assembly.UniqueProps
 
uniqueProps() - Static method in class cascading.pipe.assembly.UniqueProps
 
UnitOfWork<Stats extends CascadingStats> - Interface in cascading.management
Interface UnitOfWork is a common interface for Flow and Cascade allowing them to be used interchangeably.
UnitOfWorkDef<T> - Class in cascading.property
Class UnitOfWorkDef is the base class for framework specific fluent definition interfaces.
UnitOfWorkDef() - Constructor for class cascading.property.UnitOfWorkDef
 
UnitOfWorkDef(UnitOfWorkDef<T>) - Constructor for class cascading.property.UnitOfWorkDef
 
UnitOfWorkExecutorStrategy - Class in cascading.management
Class UnitOfWorkExecutorStrategy uses a simple Executors.newFixedThreadPool(int) ExecutorService to spawn threads.
UnitOfWorkExecutorStrategy() - Constructor for class cascading.management.UnitOfWorkExecutorStrategy
 
UnitOfWorkSpawnStrategy - Interface in cascading.management
The interface UnitOfWorkSpawnStrategy is a strategy for allowing pluggable thread management services into any UnitOfWork class.
UNKNOWN - Static variable in class cascading.tuple.Fields
Field UNKNOWN
unregisterApiBoundary(String) - Static method in class cascading.util.TraceUtil
Remove a regex as a boundary for tracing.
UnsupportedPlanException - Exception in cascading.flow.planner.rule
 
UnsupportedPlanException() - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(FlowElement, String) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(FlowElement, String, Throwable) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(FlowElement, String, Throwable, ElementGraph) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(String) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(String, Throwable) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(Throwable) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(String, ElementGraph) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(String, Throwable, ElementGraph) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
UnsupportedPlanException(Rule, Exception) - Constructor for exception cascading.flow.planner.rule.UnsupportedPlanException
 
unwind(ScopeExpression) - Static method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
unwind(Pipe...) - Static method in class cascading.pipe.SubAssembly
Is responsible for unwinding nested SubAssembly instances.
update(String, String) - Method in interface cascading.property.ConfigDef.Getter
 
update(String, String) - Method in interface cascading.property.ConfigDef.Setter
 
Update - Class in cascading.util
 
Update() - Constructor for class cascading.util.Update
 
UPDATE_CHECK_SKIP - Static variable in class cascading.util.Update
 
UPDATE_URL - Static variable in class cascading.util.Update
 
updateNodeStatus(FlowNodeStats) - Method in class cascading.flow.planner.FlowStepJob
 
updateSchemes(FlowElementGraph) - Method in class cascading.flow.BaseFlow
 
URISanitizer - Class in cascading.management.annotation
URISanitizer is an implementation of the Sanitizer interface to sanitize URIs of different kinds (file, HTTP, HDFS, JDBC etc.) Depending on the visibility, the Sanitizer will return different values:

For hierarchical URIs (jdbc://...): PUBLIC: Only return the path of the URI PROTECTED: Same as PUBLIC + query parameters PRIVATE: Same as PROTECTED + URI scheme and authority (host/port)

For opaque URIs (mailto:someone@email.com): PUBLIC: Only return the scheme of the URI, 'mailto:' etc PROTECTED: Same as PUBLIC PRIVATE: The whole URI

URISanitizer() - Constructor for class cascading.management.annotation.URISanitizer
 
USE_DEFAULT_THRESHOLD - Static variable in class cascading.pipe.assembly.AggregateBy
 
Util - Class in cascading.util
Class Util provides reusable operations.
Util() - Constructor for class cascading.util.Util
 
Util.RetryOperator<T> - Interface in cascading.util
 

V

validateLength(Flow, int) - Static method in class cascading.CascadingTestCase
 
validateLength(Flow, int, String) - Static method in class cascading.CascadingTestCase
 
validateLength(Flow, int, int) - Static method in class cascading.CascadingTestCase
 
validateLength(Flow, int, int, Pattern) - Static method in class cascading.CascadingTestCase
 
validateLength(Flow, int, Pattern, String) - Static method in class cascading.CascadingTestCase
 
validateLength(Flow, int, int, Pattern, String) - Static method in class cascading.CascadingTestCase
 
validateLength(TupleEntryIterator, int) - Static method in class cascading.CascadingTestCase
 
validateLength(TupleEntryIterator, int, int) - Static method in class cascading.CascadingTestCase
 
validateLength(TupleEntryIterator, int, Pattern) - Static method in class cascading.CascadingTestCase
 
validateLength(TupleEntryIterator, int, int, Pattern) - Static method in class cascading.CascadingTestCase
 
value - Variable in class cascading.util.SingleValueIterator
 
VALUE_SEPARATOR - Static variable in interface cascading.flow.FlowDescriptors
String that can be used as a record separator.
VALUE_SEPARATOR - Static variable in interface cascading.flow.FlowNodeDescriptors
String that can be used as a record separator.
VALUE_SEPARATOR - Static variable in interface cascading.flow.FlowStepDescriptors
String that can be used as a record separator.
ValueAssertion<C> - Interface in cascading.operation
Class ValueAssertion is a kind of Assertion used with the Each pipe Operator.
ValueAssertionCall<C> - Interface in cascading.operation
Interface ValueAssertionCall provides access to the current ValueAssertion invocation arguments.
ValueAssertionEachStage - Class in cascading.flow.stream.element
 
ValueAssertionEachStage(FlowProcess, Each) - Constructor for class cascading.flow.stream.element.ValueAssertionEachStage
 
valueComparators - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
valueFields - Variable in class cascading.pipe.joiner.JoinerClosure
 
ValueIndexTuple - Class in cascading.tuple.io
 
ValueIndexTuple() - Constructor for class cascading.tuple.io.ValueIndexTuple
 
ValueIndexTuple(int, Tuple) - Constructor for class cascading.tuple.io.ValueIndexTuple
 
valueOf(String) - Static method in enum cascading.flow.planner.graph.Extent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.assertion.GraphAssert.AssertionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.expression.ElementCapture
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.expression.PathScopeExpression.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.expression.ScopeExpression.Applies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.expression.TypeExpression.Topo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.finder.SearchOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.iso.transformer.InsertionGraphTransformer.Insertion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.ExecAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.PlanPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.ProcessLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.RuleMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.RulePartitioner.PartitionSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.RuleRegistrySet.Select
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.rule.RuleResult.ResultStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.planner.Scope.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.SliceCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.StepCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.stream.annotations.BlockingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.stream.annotations.StreamMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.flow.stream.graph.IORole
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.management.annotation.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.management.annotation.Visibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.operation.AssertionLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.operation.Debug.Output
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.operation.DebugLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.pipe.assembly.AggregateBy.Cache
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.pipe.assembly.AverageBy.Include
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.pipe.assembly.CountBy.Include
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.pipe.assembly.Unique.Cache
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.pipe.assembly.Unique.Include
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.property.ConfigDef.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.stats.CascadingStats.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.stats.CascadingStats.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.tap.partition.BasePartitionTap.Counters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.tap.SinkMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cascading.util.ShutdownUtil.Hook.Priority
Returns the enum constant of this type with the specified name.
values() - Static method in enum cascading.flow.planner.graph.Extent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.assertion.GraphAssert.AssertionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.expression.ElementCapture
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.expression.PathScopeExpression.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.expression.ScopeExpression.Applies
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.expression.TypeExpression.Topo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.finder.SearchOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.iso.transformer.InsertionGraphTransformer.Insertion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.ExecAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.PlanPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.ProcessLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.RuleMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.RulePartitioner.PartitionSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.RuleRegistrySet.Select
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.rule.RuleResult.ResultStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.planner.Scope.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.SliceCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.StepCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.stream.annotations.BlockingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.stream.annotations.StreamMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.flow.stream.graph.IORole
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.management.annotation.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.management.annotation.Visibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.operation.AssertionLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.operation.Debug.Output
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.operation.DebugLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.pipe.assembly.AggregateBy.Cache
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.pipe.assembly.AverageBy.Include
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.pipe.assembly.CountBy.Include
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.pipe.assembly.Unique.Cache
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.pipe.assembly.Unique.Include
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.property.ConfigDef.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.stats.CascadingStats.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.stats.CascadingStats.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.tap.partition.BasePartitionTap.Counters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cascading.tap.SinkMode
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in class cascading.tuple.Fields
Field VALUES represents all fields used as values for the last grouping
values() - Method in class cascading.util.cache.DirectMappedCache
 
values() - Method in class cascading.util.cache.LRUHashMapCache
 
values() - Method in class cascading.util.cache.OrderedHashMapCache
 
values() - Static method in enum cascading.util.ShutdownUtil.Hook.Priority
Returns an array containing the constants of this enum type, in the order they are declared.
valuesBuilder - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
valuesFields - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
valueTuple - Variable in class cascading.flow.stream.element.GroupingSpliceGate
 
ValueTuple - Class in cascading.tuple.io
 
ValueTuple(List<Object>) - Constructor for class cascading.tuple.io.ValueTuple
 
ValueTuple(Fields, List<Object>) - Constructor for class cascading.tuple.io.ValueTuple
 
ValueTuple() - Constructor for class cascading.tuple.io.ValueTuple
 
ValueTuple(Tuple) - Constructor for class cascading.tuple.io.ValueTuple
 
ValueTuple(Object...) - Constructor for class cascading.tuple.io.ValueTuple
 
vendor - Variable in class cascading.flow.planner.PlatformInfo
 
verify() - Method in class cascading.operation.filter.Logic
 
verify() - Method in class cascading.pipe.assembly.AggregateBy
Method verify should be overridden by sub-classes if any values must be tested before the calling constructor returns.
verifyAllTaps(FlowDef) - Method in class cascading.flow.planner.FlowPlanner
 
verifyAssembly(FlowDef, Pipe[]) - Method in class cascading.flow.planner.FlowPlanner
 
verifyCheckpoints(FlowDef, Pipe[]) - Method in class cascading.flow.planner.FlowPlanner
 
verifyContains(Fields) - Method in class cascading.tuple.Fields
Method verifyContains tests if this instance contains the field names and positions specified in the given fields instance.
verifyOperation() - Method in class cascading.pipe.Each
 
verifyOperation() - Method in class cascading.pipe.Operator
 
verifyPipeAssemblyEndPoints(FlowDef, Pipe[]) - Method in class cascading.flow.planner.FlowPlanner
Method verifyEndPoints verifies

there aren't dupe names in heads or tails.

verifyResult(RuleResult) - Method in class cascading.flow.planner.FlowPlanner
If there are rules for a given ProcessLevel on the current platform there must be sub-graphs partitioned at that level.
verifyResultInternal(RuleResult) - Method in class cascading.flow.planner.FlowPlanner
 
verifySourceNotSinks(Map<String, Tap>, Map<String, Tap>) - Method in class cascading.flow.planner.FlowPlanner
 
verifyTaps(Map<String, Tap>, boolean, boolean) - Method in class cascading.flow.planner.FlowPlanner
Method verifyTaps ...
verifyTraps(FlowDef, Pipe[]) - Method in class cascading.flow.planner.FlowPlanner
 
version - Variable in class cascading.flow.planner.PlatformInfo
 
version - Variable in class cascading.property.AppProps
 
Version - Class in cascading.util
 
Version() - Constructor for class cascading.util.Version
 
versionProperties - Static variable in class cascading.util.Version
 
vertexMapping - Variable in class cascading.flow.planner.iso.finder.Match
 
VertexNameProvider<V> - Interface in cascading.util.jgrapht
 
vertexSet() - Method in class cascading.flow.planner.graph.BaseElementGraph
 
vertexSet() - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
vertexSet() - Method in interface cascading.flow.planner.graph.ElementGraph
Returns an immutable identity based Set.
vertexSet() - Method in class cascading.flow.planner.process.BaseProcessGraph
 
vertexSet() - Method in interface cascading.flow.planner.process.ProcessGraph
 
vertexSetCopy() - Method in class cascading.flow.planner.graph.BaseElementGraph
 
vertexSetCopy() - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
vertexSetCopy() - Method in interface cascading.flow.planner.graph.ElementGraph
Returns a copy of ElementGraph.vertexSet() as an identity based Set suitable for modifying.
Visibility - Enum in cascading.management.annotation
Visibility controls whether a certain Property is visible to a certain audience.

W

waitOnLatch() - Method in class cascading.flow.stream.element.MemoryHashJoinGate
 
WholeGraphNodePartitioner - Class in cascading.flow.planner.rule.partitioner
 
WholeGraphNodePartitioner() - Constructor for class cascading.flow.planner.rule.partitioner.WholeGraphNodePartitioner
 
WholeGraphPartitioner - Class in cascading.flow.planner.iso.subgraph.partitioner
 
WholeGraphPartitioner() - Constructor for class cascading.flow.planner.iso.subgraph.partitioner.WholeGraphPartitioner
 
WholeGraphRulePartitioner - Class in cascading.flow.planner.rule.partitioner
 
WholeGraphRulePartitioner(PlanPhase) - Constructor for class cascading.flow.planner.rule.partitioner.WholeGraphRulePartitioner
 
WholeGraphStepPartitioner - Class in cascading.flow.planner.rule.partitioner
 
WholeGraphStepPartitioner() - Constructor for class cascading.flow.planner.rule.partitioner.WholeGraphStepPartitioner
 
Window - Interface in cascading.flow.stream.duct
 
wrapInput(Input) - Method in class cascading.tuple.TupleEntrySchemeIterator
 
wrapIterator(ExpressionSubGraphIterator) - Method in class cascading.flow.planner.iso.subgraph.partitioner.ExpressionGraphPartitioner
 
wrapIterator(ExpressionSubGraphIterator) - Method in class cascading.flow.planner.iso.subgraph.partitioner.UniquePathGraphPartitioner
 
wrapOutput(Output) - Method in class cascading.tuple.TupleEntrySchemeCollector
 
wrapTuple(TupleHasher, Tuple) - Static method in class cascading.tuple.util.TupleHasher
Wraps the given Tuple in a subtype, that uses the provided Hasher for hashCode calculations.
write(DataOutputStream, Object) - Method in interface cascading.tuple.io.TupleOutputStream.ElementWriter
 
write(DataOutputStream, Class<?>, Object) - Method in interface cascading.tuple.io.TupleOutputStream.ElementWriter
 
write(TupleOutputStream, Object) - Method in interface cascading.tuple.io.TupleOutputStream.TupleElementWriter
 
writeBeginGraph(String, int) - Method in class cascading.flow.planner.iso.GraphResult
 
writeCauseDOT(String) - Method in exception cascading.flow.planner.PlannerException
Method writeCauseDOT writes the underlying GraphFinderException intermediate graph as a DOT file.
writeDOT(String) - Method in class cascading.cascade.BaseCascade
 
writeDOT(String) - Method in interface cascading.cascade.Cascade
Method writeDOT writes this element graph to a DOT file for easy visualization and debugging.
writeDOT(String) - Method in class cascading.flow.BaseFlow
 
writeDOT(String) - Method in interface cascading.flow.Flow
Method writeDOT writes this Flow instance to the given filename as a DOT file for import into a graphics package.
writeDOT(String) - Method in class cascading.flow.planner.graph.BaseElementGraph
 
writeDOT(String) - Method in class cascading.flow.planner.graph.DecoratedElementGraph
 
writeDOT(String) - Method in interface cascading.flow.planner.graph.ElementGraph
 
writeDOT(String) - Method in class cascading.flow.planner.graph.FlowElementGraph
Method writeDOT writes this element graph to a DOT file for easy visualization and debugging.
writeDOT(String) - Method in class cascading.flow.planner.iso.expression.ExpressionGraph
 
writeDOT(String) - Method in exception cascading.flow.planner.iso.finder.GraphFinderException
 
writeDOT(String) - Method in exception cascading.flow.planner.PlannerException
Method writeDOT writes the failed Flow instance to the given filename as a DOT file for import into a graphics package.
writeDOT(String) - Method in class cascading.flow.planner.process.BaseProcessGraph
Method writeDOT writes this element graph to a DOT file for easy visualization and debugging.
writeDOT(String) - Method in interface cascading.flow.planner.process.ProcessGraph
 
writeDOT(Writer, DirectedGraph, IntegerNameProvider, VertexNameProvider, EdgeNameProvider) - Static method in class cascading.util.Util
 
writeDOT(Writer, DirectedGraph, IntegerNameProvider, VertexNameProvider, EdgeNameProvider, ComponentAttributeProvider, ComponentAttributeProvider) - Static method in class cascading.util.Util
 
writeDOTNested(String, ElementGraph) - Method in class cascading.flow.planner.process.BaseProcessGraph
 
writeDOTNested(String, ElementGraph) - Method in interface cascading.flow.planner.process.ProcessGraph
 
writeDOTs(String) - Method in class cascading.flow.planner.iso.assertion.Asserted
 
writeDOTs(String) - Method in class cascading.flow.planner.iso.GraphResult
 
writeDOTs(String) - Method in class cascading.flow.planner.iso.subgraph.Partitions
 
writeDOTs(String) - Method in class cascading.flow.planner.iso.transformer.Transformed
 
writeEdgeSet(ProcessGraph<? extends ProcessModel>, ElementGraph, ElementGraph, PrintWriter, Set<FlowElement>, boolean, Set<FlowElement>) - Method in class cascading.util.DOTProcessGraphWriter
if renderSpans == true, write edges if either side crosses a node boundary.
writeElement(Object) - Method in class cascading.tuple.io.TupleOutputStream
 
writeElementArray(Object[]) - Method in class cascading.tuple.io.TupleOutputStream
 
writeEndGraph(String, int) - Method in class cascading.flow.planner.iso.GraphResult
 
writeFinal(String, RuleResult) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeGraph(Writer, ElementGraph, ProcessGraph<? extends ProcessModel>) - Method in class cascading.util.DOTProcessGraphWriter
 
writeIndexTuple(IndexTuple) - Method in class cascading.tuple.io.TupleOutputStream
 
writeIntInternal(int) - Method in class cascading.tuple.io.TupleOutputStream
 
writePDF(String) - Static method in class cascading.util.Util
 
writeStats(PrintWriter) - Method in class cascading.flow.planner.rule.RuleResult
 
writeStats(PlannerContext, RuleResult) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeStepsDOT(String) - Method in class cascading.flow.BaseFlow
 
writeStepsDOT(String) - Method in interface cascading.flow.Flow
Method writeStepsDOT writes this Flow step graph to the given filename as a DOT file for import into a graphics package.
writeTracePlan(String, String, ElementGraph) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTracePlan(String, String, FlowStepGraph) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTracePlanSteps(String, FlowStepGraph) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTransformPlan(String, PlanPhase, Rule, int[], GraphResult) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTransformPlan(String, FlowElementGraph, String) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTransformPlan(String, List<? extends ElementGraph>, PlanPhase, String) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTransformPlan(String, Map<ElementGraph, List<? extends ElementGraph>>, Map<ElementGraph, List<? extends ElementGraph>>, PlanPhase, String) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTransformPlan(String, Map<ElementGraph, List<? extends ElementGraph>>, PlanPhase, String) - Method in class cascading.flow.planner.rule.util.TraceWriter
 
writeTuple(Tuple) - Method in class cascading.tuple.io.TupleOutputStream
 
writeTuplePair(TuplePair) - Method in class cascading.tuple.io.TupleOutputStream
 
writeTyped(Class[], Tuple) - Method in class cascading.tuple.io.TupleOutputStream
 
writeTypedElement(Class, Object) - Method in class cascading.tuple.io.TupleOutputStream
 
writeUnTyped(Tuple) - Method in class cascading.tuple.io.TupleOutputStream
 
writeVertexSet(ProcessModel, ElementGraph, ElementGraph, PrintWriter, Set<FlowElement>, boolean, Set<FlowElement>, Set<FlowElement>) - Method in class cascading.util.DOTProcessGraphWriter
 
writeWith(TupleOutputStream.TupleElementWriter[], Tuple) - Method in class cascading.tuple.io.TupleOutputStream
 

X

Xor - Class in cascading.operation.filter
Class Xor is a Filter class that will logically 'xor' (exclusive or) the results of the constructor provided Filter instances.
Xor(Filter...) - Constructor for class cascading.operation.filter.Xor
Constructor Xor creates a new Xor instance where all Filter instances receive all arguments.
Xor(Fields, Filter, Fields, Filter) - Constructor for class cascading.operation.filter.Xor
Constructor Xor creates a new Xor instance.

Z

zone - Variable in class cascading.operation.text.DateOperation
Field zone
zone - Variable in class cascading.tuple.type.DateType
Field zone
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

Copyright © 2007-2015 Concurrent, Inc. All Rights Reserved.