- CalendarCompare - Class in com.asakusafw.testdriver.rule
-
Accepts iff satisfies actual-value <compare-operator> expected-value
.
- CalendarCompare(CompareOperator) - Constructor for class com.asakusafw.testdriver.rule.CalendarCompare
-
Creates a new instance.
- CalendarRange - Class in com.asakusafw.testdriver.rule
-
Accepts iff actual calendar is in [ expected + lower-bound, expected + upper-bound ].
- CalendarRange(int, int, int) - Constructor for class com.asakusafw.testdriver.rule.CalendarRange
-
Creates a new instance.
- canAccept(String) - Method in class com.asakusafw.utils.java.parser.javadoc.AcceptableJavadocBlockParser
-
- canAccept(String) - Method in class com.asakusafw.utils.java.parser.javadoc.DefaultJavadocBlockParser
-
- canAccept(String) - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockParser
-
Returns whether this parser can accept the block with target tag name.
- canBeDeclaredIn(DeclarationKind) - Method in enum com.asakusafw.utils.java.model.syntax.ModifierKind
-
Returns whether this modifier can be explicitly declared on the target declaration or not.
- canContain(DataModelMirror) - Method in class com.asakusafw.operator.model.ConcreteDataModelMirror
-
- canContain(DataModelMirror) - Method in interface com.asakusafw.operator.model.DataModelMirror
-
Returns true
iff this data model can contain the other data model.
- canContain(DataModelMirror) - Method in class com.asakusafw.operator.model.PartialDataModelMirror
-
- canEscape(char) - Method in class com.asakusafw.runtime.io.text.tabular.EscapeSequence
-
Returns whether or not the given character can be escaped.
- canEscapeLineSeparator() - Method in class com.asakusafw.runtime.io.text.tabular.EscapeSequence
-
Returns whether or not line separator character can be escaped.
- canExecute(Object) - Method in class com.asakusafw.runtime.core.context.RuntimeContext
-
Returns whether target object is executable in current execution mode.
- canInvoke(DataModelMirror) - Method in class com.asakusafw.operator.model.ConcreteDataModelMirror
-
- canInvoke(DataModelMirror) - Method in interface com.asakusafw.operator.model.DataModelMirror
-
Returns true
iff this data model can apply the method parameter
whose type is the specified data model type.
- canInvoke(DataModelMirror) - Method in class com.asakusafw.operator.model.PartialDataModelMirror
-
- canWritePage(int, int) - Static method in class com.asakusafw.runtime.stage.temporary.TemporaryFile
-
Returns whether clients can write a content page into the current block.
- CastExpression - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents type cast expression.
- CastExpressionImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- CastExpressionImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.CastExpressionImpl
-
- castTo(Type) - Method in class com.asakusafw.utils.java.model.util.ExpressionBuilder
-
Returns a cast expression.
- castTo(Type) - Method in class com.asakusafw.utils.java.model.util.ExpressionBuilder
-
Returns a cast expression.
- CatchClause - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents catch clause.
- CatchClauseImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- CatchClauseImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.CatchClauseImpl
-
- CATEGORY - Static variable in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelEmitter
-
Category name for Hive common.
- CATEGORY - Static variable in class com.asakusafw.dmdl.directio.hive.orc.OrcFileEmitter
-
Category name for Hive ORC.
- CATEGORY - Static variable in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileEmitter
-
Category name for Hive Parquet file.
- CATEGORY_DATA_MODEL - Static variable in class com.asakusafw.dmdl.java.emitter.NameConstants
-
The package name fragment for data models.
- CATEGORY_IO - Static variable in class com.asakusafw.dmdl.java.emitter.NameConstants
-
The package name fragment for data model input/output.
- CATEGORY_JDBC - Static variable in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcSupportEmitter
-
Category name for JDBC support.
- CATEGORY_STREAM - Static variable in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatEmitter
-
Category name for CSV format.
- CATEGORY_STREAM - Static variable in class com.asakusafw.dmdl.directio.line.driver.LineFormatEmitter
-
Category name for line format.
- CATEGORY_STREAM - Static variable in class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatEmitter
-
Category name for this format.
- CATEGORY_STREAM - Static variable in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatEmitter
-
Category name for TSV format.
- CATEGORY_STREAM - Static variable in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportEmitter
-
Category name for CSV support.
- CATEGORY_STREAM - Static variable in class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportEmitter
-
Category name for JDBC support.
- CELL_SEPARATOR - Static variable in class com.asakusafw.runtime.io.tsv.TsvConstants
-
The cell separator character.
- CharInfo - Class in com.asakusafw.info.value
-
Represents a char
value.
- charLiteralOf(char) - Static method in class com.asakusafw.utils.java.internal.model.util.LiteralAnalyzer
-
Returns the literal token of target char
value.
- CharsetUtil - Class in com.asakusafw.dmdl.directio.util
-
Utilities about charset and encoding.
- CharStringOptionDriver - Class in com.asakusafw.directio.hive.serde
-
- CharStringOptionDriver(HiveCharObjectInspector) - Constructor for class com.asakusafw.directio.hive.serde.CharStringOptionDriver
-
Creates a new instance.
- CharStringOptionInspector - Class in com.asakusafw.directio.hive.serde
-
- CharStringOptionInspector() - Constructor for class com.asakusafw.directio.hive.serde.CharStringOptionInspector
-
Creates a new instance.
- CharStringOptionInspector(int) - Constructor for class com.asakusafw.directio.hive.serde.CharStringOptionInspector
-
Creates a new instance.
- charValueOf(String) - Static method in class com.asakusafw.utils.java.internal.model.util.LiteralAnalyzer
-
Analyzes a literal which represents char
value and returns it value.
- check(Type, String) - Method in enum com.asakusafw.runtime.stage.directio.StringTemplate.Format
-
Checks whether this format accepts the value type and format string.
- checkAbsentKey(Properties, String) - Static method in class com.asakusafw.windgate.core.util.PropertiesUtil
-
Checks whether the specified key is absent in the properties.
- checkAbsentKeyPrefix(Properties, String) - Static method in class com.asakusafw.windgate.core.util.PropertiesUtil
-
Checks whether keys with the specified prefix are absent in the properties.
- checkCancelled() - Method in interface com.asakusafw.yaess.core.ExecutionMonitor
-
- checkCancelled() - Method in class com.asakusafw.yaess.core.JobMonitor
-
- checkCancelled() - Method in class com.asakusafw.yaess.core.PhaseMonitor
-
- checkFieldType(DmdlSemantics, PropertyDeclaration, AstAttribute, BasicTypeKind...) - Static method in class com.asakusafw.dmdl.util.AttributeUtil
-
Checks field type and report diagnostics.
- checkOutputSpecs(JobContext) - Method in class com.asakusafw.runtime.stage.output.BridgeOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class com.asakusafw.runtime.stage.output.StageOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class com.asakusafw.runtime.stage.output.TemporaryOutputFormat
-
- checkpoint(Source<T>) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Returns a new checkpoint operator.
- checkpoint(Source<T>) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Returns a new checkpoint operator.
- Checkpoint - Annotation Type in com.asakusafw.vocabulary.operator
-
Represents checkpoint operator annotation.
- CHECKPOINT_NAME - Static variable in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
The common instance name of checkpoint operator.
- checkPresent(DmdlSemantics, AstNode, String, String) - Static method in class com.asakusafw.dmdl.util.AttributeUtil
-
Checks which string is not null and report diagnostics.
- checkRange(DmdlSemantics, AstNode, String, BigInteger, Long, Long) - Static method in class com.asakusafw.dmdl.util.AttributeUtil
-
Checks integer range and report diagnostics.
- checkSupported(TaskExecutionContext, CommandTaskInfo) - Static method in class com.asakusafw.testdriver.executor.DefaultCommandTaskExecutor
-
Checks if this executor can execute the given task, or raise an exception.
- checkSupported(TaskExecutionContext, HadoopTaskInfo) - Static method in class com.asakusafw.testdriver.executor.DefaultHadoopTaskExecutor
-
Checks if this executor can execute the given task, or raise an exception.
- CLASS_WINDGATE_FINALIZE - Static variable in class com.asakusafw.windgate.bootstrap.WindGateConstants
-
The class name of WindGate finalize command.
- CLASS_WINDGATE_PROCESS - Static variable in class com.asakusafw.windgate.bootstrap.WindGateConstants
-
The class name of WindGate process command.
- classBlock(EmitDirection) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Emits a begin or end of a class block.
- classBlock(EmitDirection) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- ClassBody - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents an anonymous class body.
- ClassBodyImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ClassBodyImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ClassBodyImpl
-
- ClassCollector - Class in com.asakusafw.directio.hive.tools.cli
-
Collects classes in class-path.
- ClassCollector(ClassLoader) - Constructor for class com.asakusafw.directio.hive.tools.cli.ClassCollector
-
Creates a new instance with a filter which accepts any classes.
- ClassCollector(ClassLoader, Predicate<? super Class<?>>) - Constructor for class com.asakusafw.directio.hive.tools.cli.ClassCollector
-
Creates a new instance.
- ClassCollector.Selector - Interface in com.asakusafw.directio.hive.tools.cli
-
- ClassDeclaration - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents class declarations.
- ClassDeclarationImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ClassDeclarationImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- ClassDescription - Class in com.asakusafw.operator.description
-
Represents a class.
- ClassDescription(String) - Constructor for class com.asakusafw.operator.description.ClassDescription
-
Creates a new instance.
- ClassInfo - Class in com.asakusafw.info.value
-
Represents a
Class
value.
- ClassInstanceCreationExpression - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents class instance creation expression.
- ClassInstanceCreationExpressionImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ClassInstanceCreationExpressionImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- ClassLiteral - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents class literals.
- ClassLiteralImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ClassLiteralImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ClassLiteralImpl
-
- ClassName - Class in com.asakusafw.dmdl.directio.util
-
Represents a class name.
- ClassName(String) - Constructor for class com.asakusafw.dmdl.directio.util.ClassName
-
Creates a new instance.
- classOf(Class<?>) - Static method in class com.asakusafw.operator.description.Descriptions
-
- Classpath - Class in com.asakusafw.windgate.bootstrap
-
Represents a classpath of WindGate bootstrap.
- Classpath() - Constructor for class com.asakusafw.windgate.bootstrap.Classpath
-
- Classpath.Session - Class in com.asakusafw.windgate.bootstrap
-
- Clean - Class in com.asakusafw.operation.tools.hadoop.fs
-
CLI for Hadoop FS cleaning tool.
- Clean() - Constructor for class com.asakusafw.operation.tools.hadoop.fs.Clean
-
Creates a new instance.
- clean() - Method in class com.asakusafw.utils.gradle.Bundle
-
Removes all files on this bundle excepts the content root directory.
- clean(String) - Method in class com.asakusafw.utils.gradle.Bundle
-
Removes target resource on the bundle only if it exists.
- cleanup(ResourceConfiguration) - Method in class com.asakusafw.runtime.core.legacy.LegacyBatchContext.Initializer
-
- cleanup(ResourceConfiguration) - Method in interface com.asakusafw.runtime.core.legacy.RuntimeResource
-
Finalizes this resource.
- cleanup(ResourceConfiguration) - Method in class com.asakusafw.runtime.core.legacy.RuntimeResource.DelegateRegisterer
-
- cleanup(ResourceConfiguration) - Method in class com.asakusafw.runtime.directio.api.legacy.LegacyDirectIo.Initializer
-
- cleanup(JobContext) - Method in interface com.asakusafw.runtime.flow.FlowResource
-
Finalizes this resource.
- cleanup() - Method in class com.asakusafw.runtime.flow.RuntimeResourceManager
-
Finalizes and releases the managed resources.
- cleanup(Mapper<Object, Writable, SortableSlot, WritableSlot>.Context) - Method in class com.asakusafw.runtime.stage.collector.SlotDirectMapper
-
- cleanup(Reducer<SortableSlot, WritableSlot, Object, Object>.Context) - Method in class com.asakusafw.runtime.stage.collector.SlotSorter
-
- cleanup(Mapper.Context) - Method in class com.asakusafw.runtime.stage.input.StageInputMapper
-
- cleanup(Mapper<Object, T, Object, T>.Context) - Method in class com.asakusafw.runtime.stage.preparator.PreparatorMapper
-
- cleanUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.basic.ProcessCommandScriptHandler
-
- cleanUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
- cleanUp(ExecutionMonitor, ExecutionContext) - Method in interface com.asakusafw.yaess.core.ExecutionScriptHandler
-
Cleanup the target environment.
- cleanUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
Cleanup the target environment.
- cleanUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.jobqueue.QueueHadoopScriptHandler
-
- cleanUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- CLEANUP_STAGE_CLASS - Static variable in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
The class name of cleanup stage client.
- CLEANUP_STAGE_CLASS - Static variable in class com.asakusafw.yaess.core.util.HadoopScriptUtil
-
This is a copy from asakusa-runtime.
- cleanupAttemptOutput(OutputAttemptContext) - Method in interface com.asakusafw.runtime.directio.DirectDataSource
-
Cleanup output on the attempt.
- cleanupAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- cleanupAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceCore
-
- cleanupAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.keepalive.KeepAliveDataSource
-
- cleanupDrain(ProcessScript<?>) - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Cleanups the drain of this resource.
- cleanupDrain(ProcessScript<?>) - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- cleanupDrain(ProcessScript<?>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- cleanupDrain(ProcessScript<?>) - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- cleanupJob(JobContext) - Method in class com.asakusafw.runtime.stage.output.LegacyBridgeOutputCommitter
-
- CleanupJob - Class in com.asakusafw.yaess.core.task
-
- CleanupJob(ExecutionScriptHandler<?>) - Constructor for class com.asakusafw.yaess.core.task.CleanupJob
-
Creates a new instance.
- cleanupSource(ProcessScript<?>) - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Cleanups the source of this resource.
- cleanupSource(ProcessScript<?>) - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- cleanupSource(ProcessScript<?>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- cleanupSource(ProcessScript<?>) - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- cleanUpTemporaryResources() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Removes all temporary resources generated in this context.
- cleanupTransactionOutput(OutputTransactionContext) - Method in interface com.asakusafw.runtime.directio.DirectDataSource
-
Cleanup output on the transaction.
- cleanupTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- cleanupTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceCore
-
- cleanupTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.keepalive.KeepAliveDataSource
-
- clear() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Clears all properties.
- clear() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Clears all properties.
- clear(T) - Method in interface com.asakusafw.runtime.io.text.driver.FieldAdapter
-
Clears the given property.
- clear(T) - Method in class com.asakusafw.runtime.io.text.value.ValueOptionFieldAdapter
-
- clear() - Method in interface com.asakusafw.utils.graph.Graph
-
Removes the all vertices and edges in this graph.
- clear() - Method in class com.asakusafw.utils.graph.HashGraph
-
- CLIENT_ERROR - Static variable in class com.asakusafw.runtime.stage.launcher.ApplicationLauncher
-
Exception occurred in the application.
- CLIENT_ERROR - Static variable in class com.asakusafw.runtime.stage.ToolLauncher
-
The exit status value for client errors.
- close() - Method in class com.asakusafw.directio.hive.orc.OrcFileInput
-
- close() - Method in class com.asakusafw.directio.hive.orc.OrcFileOutput
-
- close() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileInput
-
- close() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput
-
- close() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileInput
-
- close() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput
-
- close() - Method in class com.asakusafw.runtime.core.api.ApiStub.Reference
-
- close() - Method in class com.asakusafw.runtime.directio.FilteredModelInput
-
- close() - Method in class com.asakusafw.runtime.directio.util.CountInputStream
-
- close() - Method in class com.asakusafw.runtime.directio.util.CountOutputStream
-
- close() - Method in class com.asakusafw.runtime.directio.util.DelimiterRangeInputStream
-
Deprecated.
- close() - Method in class com.asakusafw.runtime.flow.ResultOutput
-
Finalizes and closes this output.
- close() - Method in class com.asakusafw.runtime.io.csv.CsvEmitter
-
- close() - Method in class com.asakusafw.runtime.io.csv.CsvParser
-
- close() - Method in class com.asakusafw.runtime.io.line.BasicLineInput
-
- close() - Method in class com.asakusafw.runtime.io.line.BasicLineOutput
-
- close() - Method in class com.asakusafw.runtime.io.line.Utf8LineInput
-
- close() - Method in class com.asakusafw.runtime.io.line.Utf8LineOutput
-
- close() - Method in class com.asakusafw.runtime.io.sequencefile.SequenceFileModelInput
-
- close() - Method in class com.asakusafw.runtime.io.sequencefile.SequenceFileModelOutput
-
- close() - Method in class com.asakusafw.runtime.io.text.csv.CsvFieldReader
-
- close() - Method in class com.asakusafw.runtime.io.text.csv.CsvFieldWriter
-
- close() - Method in class com.asakusafw.runtime.io.text.tabular.TabularFieldReader
-
- close() - Method in class com.asakusafw.runtime.io.text.tabular.TabularFieldWriter
-
- close() - Method in class com.asakusafw.runtime.io.tsv.DelimiterRangeInputStream
-
- close() - Method in class com.asakusafw.runtime.io.tsv.TsvEmitter
-
- close() - Method in class com.asakusafw.runtime.io.tsv.TsvParser
-
- close() - Method in class com.asakusafw.runtime.io.util.BufferedFileInput
-
- close() - Method in class com.asakusafw.runtime.io.util.BufferedFileOutput
-
- close() - Method in class com.asakusafw.runtime.io.util.LineFeedDelimitedInputStream
-
- close() - Method in class com.asakusafw.runtime.io.util.VoidModelInput
-
- close() - Method in class com.asakusafw.runtime.io.util.VoidModelOutput
-
- close() - Method in class com.asakusafw.runtime.io.util.ZipEntryInputStream
-
- close() - Method in class com.asakusafw.runtime.io.util.ZipEntryOutputStream
-
- close() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter
-
- close() - Method in class com.asakusafw.runtime.mapreduce.simple.ShuffleReader
-
- close(TaskAttemptContext) - Method in class com.asakusafw.runtime.mapreduce.simple.ShuffleWriter
-
- close() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullRecordReader
-
- close() - Method in class com.asakusafw.runtime.stage.input.StageInputRecordReader
-
- close() - Method in class com.asakusafw.runtime.stage.output.StageOutputDriver
-
Closes this driver and finalizes all result sinks.
- close() - Method in class com.asakusafw.runtime.stage.resource.StageResourceDriver
-
- close() - Method in class com.asakusafw.runtime.stage.temporary.TemporaryFileInput
-
- close() - Method in class com.asakusafw.runtime.stage.temporary.TemporaryFileOutput
-
- close() - Method in class com.asakusafw.runtime.util.lock.LocalFileLockObject
-
- close() - Method in class com.asakusafw.testdriver.core.IteratorDataModelSource
-
- close() - Method in class com.asakusafw.testdriver.core.SourceDataModelSource
-
- close() - Method in class com.asakusafw.testdriver.core.VerifyRuleVerifier
-
- close() - Method in class com.asakusafw.testdriver.excel.ExcelSheetDataModelSource
-
- close() - Method in class com.asakusafw.testdriver.excel.ExcelSheetSink
-
- close() - Method in class com.asakusafw.testdriver.html.HtmlDifferenceSink
-
- close() - Method in class com.asakusafw.testdriver.json.JsonDataModelSource
-
- close() - Method in class com.asakusafw.testdriver.windgate.WindGateOutput
-
- close() - Method in class com.asakusafw.testdriver.windgate.WindGateSource
-
- close() - Method in class com.asakusafw.utils.io.csv.CsvReader
-
- close() - Method in class com.asakusafw.utils.io.csv.CsvWriter
-
- close() - Method in class com.asakusafw.utils.io.DefaultSerialization.ObjectSink
-
- close() - Method in class com.asakusafw.utils.io.DefaultSerialization.ObjectSource
-
- close() - Method in class com.asakusafw.utils.io.FileInputStreamProvider
-
- close() - Method in class com.asakusafw.utils.io.ReaderProvider
-
- close() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
- close() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileCompiler
-
- close() - Method in class com.asakusafw.windgate.bootstrap.Classpath.Session
-
- close() - Method in class com.asakusafw.windgate.core.GateTask
-
- close() - Method in interface com.asakusafw.windgate.core.resource.DrainDriver
-
Disposes this object.
- close() - Method in interface com.asakusafw.windgate.core.resource.SourceDriver
-
Disposes this object.
- close() - Method in class com.asakusafw.windgate.core.session.SessionMirror
-
Closes this session.
- close() - Method in class com.asakusafw.windgate.core.session.SessionMirror.Null
-
- close() - Method in class com.asakusafw.windgate.core.util.SafeCloser
-
- close() - Method in class com.asakusafw.windgate.core.util.VoidDrainDriver
-
- close() - Method in class com.asakusafw.windgate.core.util.VoidSourceDriver
-
- close() - Method in class com.asakusafw.windgate.file.resource.FileResourceMirror
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsMirror
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.ssh.AbstractSshHadoopFsMirror
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.ssh.FileList.Reader
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.ssh.FileList.Writer
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.ssh.FileListModelInputProvider
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.ssh.ZipEntryInputStream
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.ssh.ZipEntryOutputStream
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.temporary.FileSystemModelInputProvider
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.temporary.ModelInputSourceDriver
-
- close() - Method in class com.asakusafw.windgate.hadoopfs.temporary.ModelOutputDrainDriver
-
- close() - Method in class com.asakusafw.windgate.jdbc.JdbcDrainDriver
-
- close() - Method in class com.asakusafw.windgate.jdbc.JdbcResourceMirror
-
- close() - Method in class com.asakusafw.windgate.jdbc.JdbcSourceDriver
-
- close() - Method in class com.asakusafw.windgate.stream.CountingInputStream
-
- close() - Method in class com.asakusafw.windgate.stream.CountingOutputStream
-
- close() - Method in class com.asakusafw.windgate.stream.file.FileInputStreamProvider
-
- close() - Method in class com.asakusafw.windgate.stream.file.FileOutputStreamProvider
-
- close() - Method in class com.asakusafw.windgate.stream.file.FileResourceMirror
-
- close() - Method in class com.asakusafw.windgate.stream.StreamDrainDriver
-
- close() - Method in class com.asakusafw.windgate.stream.StreamSourceDriver
-
- close() - Method in class com.asakusafw.yaess.basic.BasicExtension
-
- close() - Method in class com.asakusafw.yaess.basic.LoggingExecutionMonitor
-
- close() - Method in interface com.asakusafw.yaess.core.ExecutionMonitor
-
Ends the current task and notify this event to the corresponding receiver.
- close() - Method in class com.asakusafw.yaess.core.JobMonitor
-
- close() - Method in class com.asakusafw.yaess.core.util.TemporaryFiles
-
- close() - Method in class com.asakusafw.yaess.flowlog.FlowLogger
-
- code(String, Object...) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Appends a @code
inline block into this builder.
- code(Object) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder.DocElementFactory
-
Appends a @code
inline block into this builder.
- code(String, Object...) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder.DocElementFactory
-
Appends a @code
inline block into this builder.
- CodecNames - Class in com.asakusafw.dmdl.directio.util
-
Utilities for Hadoop codec names.
- CoGroup - Annotation Type in com.asakusafw.vocabulary.operator
-
グループ結合演算子を表すメソッドに付与する注釈。
- CoGroupOperatorDriver - Class in com.asakusafw.operator.builtin
-
- CoGroupOperatorDriver() - Constructor for class com.asakusafw.operator.builtin.CoGroupOperatorDriver
-
- collect() - Method in class com.asakusafw.info.cli.generate.ddl.HiveTableParameter
-
Returns the target tables and their locations.
- collect(CompileEnvironment, TypeMirror, List<TypeElement>) - Method in class com.asakusafw.operator.dmdl.DmdlDataModelMirrorRepository
-
- collect(CompileEnvironment, TypeMirror, List<TypeElement>) - Method in interface com.asakusafw.operator.model.PropertyMirrorCollector
-
Creates and returns the set of properties.
- collect(ExporterDescription, String) - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
Collects jobflow output.
- collect(ExporterDescription, DataModelSinkFactory) - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
Collects jobflow output.
- collectAllConnected(Graph<? extends V>, Collection<? extends V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Returns the transitively connected all vertices from the starting vertices.
- collectHeads(Graph<? extends V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Returns each head vertex in the graph, which has no preceding vertices.
- collectionItemsTerminatedBy(char) - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo.Builder
-
COLLECTION ITEMS TERMINATED BY <c>
.
- CollectionType - Class in com.asakusafw.dmdl.semantics.type
-
Collection type of properties.
- CollectionType(AstCollectionType, CollectionType.CollectionKind, Type) - Constructor for class com.asakusafw.dmdl.semantics.type.CollectionType
-
Creates a new instance.
- CollectionType.CollectionKind - Enum in com.asakusafw.dmdl.semantics.type
-
Returns the kind of this type.
- CollectionTypeDriver - Class in com.asakusafw.dmdl.analyzer.driver
-
- CollectionTypeDriver() - Constructor for class com.asakusafw.dmdl.analyzer.driver.CollectionTypeDriver
-
- collectNearest(Graph<? extends V>, Collection<? extends V>, Predicate<? super V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Returns the succeeding nearest vertices which match the condition, from the starting vertices,
and vertices on their routes.
- collectPropertyMap(OrcFormatConfiguration) - Method in class com.asakusafw.directio.hive.orc.Compatibility
-
returns extra table property map from the format configuration.
- collectPropertyMap(OrcFormatConfiguration) - Method in class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
returns extra table property map from the format configuration.
- collectPropertyMap(OrcFormatConfiguration) - Method in class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
returns extra table property map from the format configuration.
- collectTails(Graph<? extends V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Returns each tail vertex in the graph, which has no succeeding vertices.
- collectVariableNames(String) - Static method in class com.asakusafw.runtime.util.VariableTable
-
Collects variable names in the target string.
- ColumnDriver - Class in com.asakusafw.dmdl.windgate.jdbc.driver
-
Processes @windgate.column
attributes (deprecated).
- ColumnDriver() - Constructor for class com.asakusafw.dmdl.windgate.jdbc.driver.ColumnDriver
-
- ColumnInfo - Class in com.asakusafw.info.hive
-
Represents a Hive column.
- ColumnInfo(String, FieldType, String) - Constructor for class com.asakusafw.info.hive.ColumnInfo
-
Creates a new instance.
- ColumnInfo(String, FieldType) - Constructor for class com.asakusafw.info.hive.ColumnInfo
-
Creates a new instance.
- ColumnMatchingCondition - Enum in com.asakusafw.testdriver.excel.legacy
-
Represents a kind of column verification rule.
- com.asakusafw.directio.hive.orc - package com.asakusafw.directio.hive.orc
-
ORCFile format bridge between Asakusa and Hive.
- com.asakusafw.directio.hive.orc.v1 - package com.asakusafw.directio.hive.orc.v1
-
ORCFile format bridge for Hive v1.
- com.asakusafw.directio.hive.orc.v2 - package com.asakusafw.directio.hive.orc.v2
-
ORCFile format bridge for Hive v2.
- com.asakusafw.directio.hive.parquet - package com.asakusafw.directio.hive.parquet
-
Parquet file format bridge between Asakusa and Hive.
- com.asakusafw.directio.hive.parquet.v1 - package com.asakusafw.directio.hive.parquet.v1
-
Parquet format bridge for Hive v1.
- com.asakusafw.directio.hive.parquet.v2 - package com.asakusafw.directio.hive.parquet.v2
-
Parquet format bridge for Hive v2.
- com.asakusafw.directio.hive.serde - package com.asakusafw.directio.hive.serde
-
Data serialization format bridge between Asakusa and Hive.
- com.asakusafw.directio.hive.tools.cli - package com.asakusafw.directio.hive.tools.cli
-
CLI Tools for Hive.
- com.asakusafw.directio.hive.util - package com.asakusafw.directio.hive.util
-
Utilities for Hive.
- com.asakusafw.directio.tools - package com.asakusafw.directio.tools
-
Command Line Tools for Direct I/O.
- com.asakusafw.dmdl - package com.asakusafw.dmdl
-
Core classes of DMDL compiler.
- com.asakusafw.dmdl.analyzer - package com.asakusafw.dmdl.analyzer
-
Sematic analyzer for DMDL.
- com.asakusafw.dmdl.analyzer.driver - package com.asakusafw.dmdl.analyzer.driver
-
Core sematic analyzer drivers.
- com.asakusafw.dmdl.directio.csv.driver - package com.asakusafw.dmdl.directio.csv.driver
-
DMDL extensions for Direct I/O.
- com.asakusafw.dmdl.directio.hive.common - package com.asakusafw.dmdl.directio.hive.common
-
Hive support common classes.
- com.asakusafw.dmdl.directio.hive.orc - package com.asakusafw.dmdl.directio.hive.orc
-
Hive ORCFile support.
- com.asakusafw.dmdl.directio.hive.parquet - package com.asakusafw.dmdl.directio.hive.parquet
-
Hive Parquet file support.
- com.asakusafw.dmdl.directio.json.driver - package com.asakusafw.dmdl.directio.json.driver
-
JSON support for Direct I/O.
- com.asakusafw.dmdl.directio.line.driver - package com.asakusafw.dmdl.directio.line.driver
-
Line based text support for Direct I/O.
- com.asakusafw.dmdl.directio.sequencefile.driver - package com.asakusafw.dmdl.directio.sequencefile.driver
-
DMDL SequenceFile extensions for Direct I/O.
- com.asakusafw.dmdl.directio.text - package com.asakusafw.dmdl.directio.text
-
Formatted text support for Direct I/O.
- com.asakusafw.dmdl.directio.text.csv - package com.asakusafw.dmdl.directio.text.csv
-
CSV support for Direct I/O.
- com.asakusafw.dmdl.directio.text.tabular - package com.asakusafw.dmdl.directio.text.tabular
-
Tabular-style text support for Direct I/O.
- com.asakusafw.dmdl.directio.tsv.driver - package com.asakusafw.dmdl.directio.tsv.driver
-
Special TSV support for Direct I/O.
- com.asakusafw.dmdl.directio.util - package com.asakusafw.dmdl.directio.util
-
Utilities for DMDL for Direct I/O.
- com.asakusafw.dmdl.java - package com.asakusafw.dmdl.java
-
Core classes of DMDL Java backend.
- com.asakusafw.dmdl.java.analyzer - package com.asakusafw.dmdl.java.analyzer
-
Enhances analyzer for Java source generation.
- com.asakusafw.dmdl.java.emitter - package com.asakusafw.dmdl.java.emitter
-
Java source code emitters.
- com.asakusafw.dmdl.java.emitter.driver - package com.asakusafw.dmdl.java.emitter.driver
-
Extension points for DMDL Java emitter.
- com.asakusafw.dmdl.java.spi - package com.asakusafw.dmdl.java.spi
-
Extension points for DMDL Java program emittion.
- com.asakusafw.dmdl.java.util - package com.asakusafw.dmdl.java.util
-
Internal common libraries for DMDL Java backend.
- com.asakusafw.dmdl.model - package com.asakusafw.dmdl.model
-
Syntactic models for DMDL.
- com.asakusafw.dmdl.semantics - package com.asakusafw.dmdl.semantics
-
Semantic intermediate representations of DMDL.
- com.asakusafw.dmdl.semantics.trait - package com.asakusafw.dmdl.semantics.trait
-
Core traits for intermediate representations of DMDL.
- com.asakusafw.dmdl.semantics.type - package com.asakusafw.dmdl.semantics.type
-
Core types for intermediate representations of DMDL.
- com.asakusafw.dmdl.source - package com.asakusafw.dmdl.source
-
DMDL source code abstraction.
- com.asakusafw.dmdl.spi - package com.asakusafw.dmdl.spi
-
Extension points for DMDL semantic analyzers.
- com.asakusafw.dmdl.util - package com.asakusafw.dmdl.util
-
Internal common libraries for DMDL.
- com.asakusafw.dmdl.windgate.csv.driver - package com.asakusafw.dmdl.windgate.csv.driver
-
DMDL extensions for WindGate CSV.
- com.asakusafw.dmdl.windgate.jdbc.driver - package com.asakusafw.dmdl.windgate.jdbc.driver
-
DMDL extensions for WindGate.
- com.asakusafw.dmdl.windgate.stream.driver - package com.asakusafw.dmdl.windgate.stream.driver
-
DMDL extensions for WindGate.
- com.asakusafw.dmdl.windgate.util - package com.asakusafw.dmdl.windgate.util
-
Utilities for WindGate DMDL.
- com.asakusafw.info - package com.asakusafw.info
-
Asakusa DSL core information models.
- com.asakusafw.info.cli - package com.asakusafw.info.cli
-
CLI for information models.
- com.asakusafw.info.cli.common - package com.asakusafw.info.cli.common
-
Common classes for CLI.
- com.asakusafw.info.cli.generate - package com.asakusafw.info.cli.generate
-
Implementations of generate
group.
- com.asakusafw.info.cli.generate.ddl - package com.asakusafw.info.cli.generate.ddl
-
Implementations of generate ddl
group.
- com.asakusafw.info.cli.generate.dot - package com.asakusafw.info.cli.generate.dot
-
Implementations of generate dot
group.
- com.asakusafw.info.cli.list - package com.asakusafw.info.cli.list
-
Implementations of list
group.
- com.asakusafw.info.directio - package com.asakusafw.info.directio
-
Asakusa Direct I/O information models.
- com.asakusafw.info.graph - package com.asakusafw.info.graph
-
Graph like structure models.
- com.asakusafw.info.hive - package com.asakusafw.info.hive
-
Schema information of Hive-associated tables.
- com.asakusafw.info.hive.annotation - package com.asakusafw.info.hive.annotation
-
Annotations for inter-operability between Asakusa and Hive.
- com.asakusafw.info.hive.syntax - package com.asakusafw.info.hive.syntax
-
Hive DDL.
- com.asakusafw.info.operator - package com.asakusafw.info.operator
-
Asakusa operator DSL information models.
- com.asakusafw.info.operator.view - package com.asakusafw.info.operator.view
-
Views of operator graphs.
- com.asakusafw.info.plan - package com.asakusafw.info.plan
-
Asakusa execution plan information models.
- com.asakusafw.info.task - package com.asakusafw.info.task
-
Asakusa task information models.
- com.asakusafw.info.value - package com.asakusafw.info.value
-
Wrapped values.
- com.asakusafw.info.windgate - package com.asakusafw.info.windgate
-
Asakusa WindGate information models.
- com.asakusafw.iterative.common - package com.asakusafw.iterative.common
-
Common runtime classes for Asakusa Iterative Extensions.
- com.asakusafw.iterative.common.basic - package com.asakusafw.iterative.common.basic
-
Basic implementations of common runtime classes for Asakusa Iterative Extensions.
- com.asakusafw.operation.tools.directio - package com.asakusafw.operation.tools.directio
-
Direct I/O tools.
- com.asakusafw.operation.tools.directio.bootstrap - package com.asakusafw.operation.tools.directio.bootstrap
-
Direct I/O tools bootstrap for Windows platform.
- com.asakusafw.operation.tools.directio.common - package com.asakusafw.operation.tools.directio.common
-
Common classes for Direct I/O CLI.
- com.asakusafw.operation.tools.directio.conf - package com.asakusafw.operation.tools.directio.conf
-
Implementation of Direct I/O configuration command.
- com.asakusafw.operation.tools.directio.file - package com.asakusafw.operation.tools.directio.file
-
Implementation of Direct I/O file command.
- com.asakusafw.operation.tools.directio.transaction - package com.asakusafw.operation.tools.directio.transaction
-
Implementation of Direct I/O file transaction.
- com.asakusafw.operation.tools.hadoop.fs - package com.asakusafw.operation.tools.hadoop.fs
-
Command Line Tools for Hadoop FileSystem.
- com.asakusafw.operation.tools.portal - package com.asakusafw.operation.tools.portal
-
Asakusa Framework command portal.
- com.asakusafw.operation.tools.setup - package com.asakusafw.operation.tools.setup
-
Asakusa Framework Setup Tools.
- com.asakusafw.operator - package com.asakusafw.operator
-
Asakusa Operator DSL Compiler Core APIs.
- com.asakusafw.operator.builtin - package com.asakusafw.operator.builtin
-
Built-in Asakusa Operator Drivers.
- com.asakusafw.operator.description - package com.asakusafw.operator.description
-
Description classes.
- com.asakusafw.operator.dmdl - package com.asakusafw.operator.dmdl
-
Internal representation of Asakusa data models using DMDL.
- com.asakusafw.operator.flowpart - package com.asakusafw.operator.flowpart
-
Asakusa Operator DSL Compiler for flow-parts.
- com.asakusafw.operator.method - package com.asakusafw.operator.method
-
Asakusa Operator DSL Compiler for operator methods.
- com.asakusafw.operator.model - package com.asakusafw.operator.model
-
Internal representation of Asakusa operators and data models.
- com.asakusafw.operator.util - package com.asakusafw.operator.util
-
Common utilities for Asakusa Operator DSL compiler.
- com.asakusafw.runtime.core - package com.asakusafw.runtime.core
-
Runtime core classes.
- com.asakusafw.runtime.core.api - package com.asakusafw.runtime.core.api
-
Meta API of Asakusa Framework APIs.
- com.asakusafw.runtime.core.context - package com.asakusafw.runtime.core.context
-
Application Execution Context Managements.
- com.asakusafw.runtime.core.legacy - package com.asakusafw.runtime.core.legacy
-
The legacy Asakusa Framework implementations.
- com.asakusafw.runtime.core.util - package com.asakusafw.runtime.core.util
-
Core utilities for runtime.
- com.asakusafw.runtime.directio - package com.asakusafw.runtime.directio
-
Direct I/O access from Asakusa Framework.
- com.asakusafw.runtime.directio.api - package com.asakusafw.runtime.directio.api
-
User APIs of Direct I/O.
- com.asakusafw.runtime.directio.api.legacy - package com.asakusafw.runtime.directio.api.legacy
-
The legacy Direct I/O implementations.
- com.asakusafw.runtime.directio.hadoop - package com.asakusafw.runtime.directio.hadoop
-
Direct I/O access for Hadoop Environment.
- com.asakusafw.runtime.directio.keepalive - package com.asakusafw.runtime.directio.keepalive
-
Keep-alive utilities for Direct I/O access.
- com.asakusafw.runtime.directio.util - package com.asakusafw.runtime.directio.util
-
Generic utilities for direct I/O access.
- com.asakusafw.runtime.flow - package com.asakusafw.runtime.flow
-
Classes for executing data flow operations.
- com.asakusafw.runtime.flow.join - package com.asakusafw.runtime.flow.join
-
Classes for join algorithm.
- com.asakusafw.runtime.io - package com.asakusafw.runtime.io
-
Classes for data model input/output.
- com.asakusafw.runtime.io.csv - package com.asakusafw.runtime.io.csv
-
CSV Reader and Emitter.
- com.asakusafw.runtime.io.csv.directio - package com.asakusafw.runtime.io.csv.directio
-
Direct I/O adapters for CSV format.
- com.asakusafw.runtime.io.json - package com.asakusafw.runtime.io.json
-
Extracting and generating JSON files.
- com.asakusafw.runtime.io.json.directio - package com.asakusafw.runtime.io.json.directio
-
Direct I/O adapters of JSON files.
- com.asakusafw.runtime.io.json.value - package com.asakusafw.runtime.io.json.value
-
Converts between runtime values and JSON values.
- com.asakusafw.runtime.io.line - package com.asakusafw.runtime.io.line
-
Line reader and emitter.
- com.asakusafw.runtime.io.line.directio - package com.asakusafw.runtime.io.line.directio
-
Direct I/O adapters of line read/write.
- com.asakusafw.runtime.io.sequencefile - package com.asakusafw.runtime.io.sequencefile
-
Utility classes for SequenceFile
.
- com.asakusafw.runtime.io.text - package com.asakusafw.runtime.io.text
-
Extracting and generating formatted text files.
- com.asakusafw.runtime.io.text.csv - package com.asakusafw.runtime.io.text.csv
-
Extracting and generating CSV text files.
- com.asakusafw.runtime.io.text.directio - package com.asakusafw.runtime.io.text.directio
-
Direct I/O adapters of formatted text files.
- com.asakusafw.runtime.io.text.driver - package com.asakusafw.runtime.io.text.driver
-
Drivers for text I/O.
- com.asakusafw.runtime.io.text.tabular - package com.asakusafw.runtime.io.text.tabular
-
Extracting and generating tabular-style text files.
- com.asakusafw.runtime.io.text.value - package com.asakusafw.runtime.io.text.value
-
Converts between runtime values and text.
- com.asakusafw.runtime.io.tsv - package com.asakusafw.runtime.io.tsv
-
Legacy TSV Reader and Emitter.
- com.asakusafw.runtime.io.util - package com.asakusafw.runtime.io.util
-
Utilities about I/O access.
- com.asakusafw.runtime.mapreduce.simple - package com.asakusafw.runtime.mapreduce.simple
-
Simplified MapReduce engine.
- com.asakusafw.runtime.model - package com.asakusafw.runtime.model
-
Meta-classes for data model classes.
- com.asakusafw.runtime.report - package com.asakusafw.runtime.report
-
Built-in Report API plug-ins.
- com.asakusafw.runtime.stage - package com.asakusafw.runtime.stage
-
Classes for Hadoop stages.
- com.asakusafw.runtime.stage.collector - package com.asakusafw.runtime.stage.collector
-
Classes for collecting output data-sets of jobflow execution.
- com.asakusafw.runtime.stage.directio - package com.asakusafw.runtime.stage.directio
-
Map Reduce stage elements for Direct I/O.
- com.asakusafw.runtime.stage.inprocess - package com.asakusafw.runtime.stage.inprocess
-
In-process job execution configurator.
- com.asakusafw.runtime.stage.input - package com.asakusafw.runtime.stage.input
-
Classes for stage inputs.
- com.asakusafw.runtime.stage.launcher - package com.asakusafw.runtime.stage.launcher
-
Launches each stage client.
- com.asakusafw.runtime.stage.optimizer - package com.asakusafw.runtime.stage.optimizer
-
Stage execution optimizers.
- com.asakusafw.runtime.stage.output - package com.asakusafw.runtime.stage.output
-
Classes for stage outputs.
- com.asakusafw.runtime.stage.preparator - package com.asakusafw.runtime.stage.preparator
-
Copies original flow inputs into temporary area.
- com.asakusafw.runtime.stage.resource - package com.asakusafw.runtime.stage.resource
-
Classes for stage resources.
- com.asakusafw.runtime.stage.temporary - package com.asakusafw.runtime.stage.temporary
-
Temporary storage for each stage.
- com.asakusafw.runtime.testing - package com.asakusafw.runtime.testing
-
Classes for testing.
- com.asakusafw.runtime.trace - package com.asakusafw.runtime.trace
-
Tracing support.
- com.asakusafw.runtime.util - package com.asakusafw.runtime.util
-
Utilities for Asakusa runtime.
- com.asakusafw.runtime.util.cache - package com.asakusafw.runtime.util.cache
-
Application cache facilities.
- com.asakusafw.runtime.util.hadoop - package com.asakusafw.runtime.util.hadoop
-
Utilities for Hadoop runtime.
- com.asakusafw.runtime.util.lock - package com.asakusafw.runtime.util.lock
-
Lock facilities.
- com.asakusafw.runtime.value - package com.asakusafw.runtime.value
-
Classes for runtime values.
- com.asakusafw.runtime.windows - package com.asakusafw.runtime.windows
-
Runtime for Windows platform.
- com.asakusafw.runtime.workaround - package com.asakusafw.runtime.workaround
-
Workaround for Asakusa runtime libraries.
- com.asakusafw.runtime.workaround.snappyjava - package com.asakusafw.runtime.workaround.snappyjava
-
Workaround for snappy-java
.
- com.asakusafw.testdata.generator - package com.asakusafw.testdata.generator
-
Core classes of test data template generator.
- com.asakusafw.testdata.generator.excel - package com.asakusafw.testdata.generator.excel
-
Excel template generator.
- com.asakusafw.testdriver - package com.asakusafw.testdriver
-
Test driver classes.
- com.asakusafw.testdriver.compiler - package com.asakusafw.testdriver.compiler
-
Asakusa DSL TestKit Compiler API.
- com.asakusafw.testdriver.compiler.basic - package com.asakusafw.testdriver.compiler.basic
-
Basic implementations of Asakusa DSL TestKit Compiler.
- com.asakusafw.testdriver.compiler.util - package com.asakusafw.testdriver.compiler.util
-
Utilities for Asakusa DSL TestKit Compiler.
- com.asakusafw.testdriver.configurator - package com.asakusafw.testdriver.configurator
-
Built-in test environment configurators.
- com.asakusafw.testdriver.core - package com.asakusafw.testdriver.core
-
Core classes of test moderator.
- com.asakusafw.testdriver.directio - package com.asakusafw.testdriver.directio
-
Moderates test input/result using Direct I/O.
- com.asakusafw.testdriver.directio.api - package com.asakusafw.testdriver.directio.api
-
Tester APIs of Direct I/O.
- com.asakusafw.testdriver.excel - package com.asakusafw.testdriver.excel
-
Test data/condition definitions in Excel sheets.
- com.asakusafw.testdriver.excel.extension - package com.asakusafw.testdriver.excel.extension
-
Extensions for test data providers using Excel books.
- com.asakusafw.testdriver.excel.legacy - package com.asakusafw.testdriver.excel.legacy
-
Legacy test condition definitions in Excel sheets.
- com.asakusafw.testdriver.executor - package com.asakusafw.testdriver.executor
-
Executes test tasks.
- com.asakusafw.testdriver.hadoop - package com.asakusafw.testdriver.hadoop
-
Test helpers for Hadoop.
- com.asakusafw.testdriver.html - package com.asakusafw.testdriver.html
-
HTML style test data definitions.
- com.asakusafw.testdriver.inprocess - package com.asakusafw.testdriver.inprocess
-
In-process Hadoop task executor.
- com.asakusafw.testdriver.json - package com.asakusafw.testdriver.json
-
JSON style Test data definitions.
- com.asakusafw.testdriver.loader - package com.asakusafw.testdriver.loader
-
Data loaders and its mock implementations.
- com.asakusafw.testdriver.model - package com.asakusafw.testdriver.model
-
Default implementation of data model adapters.
- com.asakusafw.testdriver.rule - package com.asakusafw.testdriver.rule
-
Tiny rule builder.
- com.asakusafw.testdriver.tools.runner - package com.asakusafw.testdriver.tools.runner
-
Asakusa batch application runner using test driver facilities.
- com.asakusafw.testdriver.windgate - package com.asakusafw.testdriver.windgate
-
Moderates test input/result using WindGate.
- com.asakusafw.testdriver.windgate.inprocess - package com.asakusafw.testdriver.windgate.inprocess
-
Emulation mode API for WindGate.
- com.asakusafw.testdriver.windows - package com.asakusafw.testdriver.windows
-
Configures testing environment for Windows platform.
- com.asakusafw.trace.io - package com.asakusafw.trace.io
-
I/O libraries for tracepoints.
- com.asakusafw.trace.model - package com.asakusafw.trace.model
-
Models for data-flow tracing.
- com.asakusafw.utils.collections - package com.asakusafw.utils.collections
-
Collection utilities.
- com.asakusafw.utils.gradle - package com.asakusafw.utils.gradle
-
Asakusa Framework integration utilities.
- com.asakusafw.utils.graph - package com.asakusafw.utils.graph
-
A simple graph classes.
- com.asakusafw.utils.io - package com.asakusafw.utils.io
-
Simple Object I/O APIs.
- com.asakusafw.utils.io.csv - package com.asakusafw.utils.io.csv
-
CSV format I/O utilities.
- com.asakusafw.utils.java.internal.model.syntax - package com.asakusafw.utils.java.internal.model.syntax
-
Naive Java DOM implementations.
- com.asakusafw.utils.java.internal.model.util - package com.asakusafw.utils.java.internal.model.util
-
Internal utlities for Java DOM building/emitting.
- com.asakusafw.utils.java.internal.parser.javadoc.ir - package com.asakusafw.utils.java.internal.parser.javadoc.ir
-
Internal representation of Java documentation comments.
- com.asakusafw.utils.java.jsr199.testing - package com.asakusafw.utils.java.jsr199.testing
-
Utilities for testing with javax.tools.JavaCompiler
.
- com.asakusafw.utils.java.jsr269.bridge - package com.asakusafw.utils.java.jsr269.bridge
-
Utilities for convert javax.lang.model
into Java DOM.
- com.asakusafw.utils.java.model.syntax - package com.asakusafw.utils.java.model.syntax
-
Interfaces for representing Java DOMs.
- com.asakusafw.utils.java.model.util - package com.asakusafw.utils.java.model.util
-
Utilities for Java DOM building/emitting.
- com.asakusafw.utils.java.parser.javadoc - package com.asakusafw.utils.java.parser.javadoc
-
Parses Java documentation comments and converts them to Java DOMs.
- com.asakusafw.utils.jcommander - package com.asakusafw.utils.jcommander
-
Utility classes for JCommander.
- com.asakusafw.utils.jcommander.common - package com.asakusafw.utils.jcommander.common
-
A common implementations for JCommander.
- com.asakusafw.utils.launcher - package com.asakusafw.utils.launcher
-
Launches Tool classes.
- com.asakusafw.vocabulary.attribute - package com.asakusafw.vocabulary.attribute
-
Attributes about flow elements.
- com.asakusafw.vocabulary.batch - package com.asakusafw.vocabulary.batch
-
Batch DSL vocabulary annotations/classes.
- com.asakusafw.vocabulary.directio - package com.asakusafw.vocabulary.directio
-
Asakusa DSL vocabularies extensions for Direct I/O.
- com.asakusafw.vocabulary.external - package com.asakusafw.vocabulary.external
-
Flow DSL vocabulary annotations/classes about external I/O.
- com.asakusafw.vocabulary.flow - package com.asakusafw.vocabulary.flow
-
Flow DSL vocabulary annotations/classes about data flow representations.
- com.asakusafw.vocabulary.flow.builder - package com.asakusafw.vocabulary.flow.builder
-
Flow connection APIs (for internal use only).
- com.asakusafw.vocabulary.flow.graph - package com.asakusafw.vocabulary.flow.graph
-
Internal graphical representation of Flow DSL.
- com.asakusafw.vocabulary.flow.processor - package com.asakusafw.vocabulary.flow.processor
-
Represents characteristics of each operator behavior.
- com.asakusafw.vocabulary.flow.testing - package com.asakusafw.vocabulary.flow.testing
-
Classes for Flow DSL testing.
- com.asakusafw.vocabulary.flow.util - package com.asakusafw.vocabulary.flow.util
-
Provides built-in Flow DSL vocabularies.
- com.asakusafw.vocabulary.iterative - package com.asakusafw.vocabulary.iterative
-
Asakusa DSL vocabularies for Iterative batch extensions.
- com.asakusafw.vocabulary.model - package com.asakusafw.vocabulary.model
-
Provides annotations for data model and operations over data models.
- com.asakusafw.vocabulary.operator - package com.asakusafw.vocabulary.operator
-
Operator DSL vocabulary annotations/classes.
- com.asakusafw.vocabulary.windgate - package com.asakusafw.vocabulary.windgate
-
Asakusa DSL vocabularies extensions for WindGate.
- com.asakusafw.windgate.bootstrap - package com.asakusafw.windgate.bootstrap
-
Launches WindGate.
- com.asakusafw.windgate.cli - package com.asakusafw.windgate.cli
-
Command line tools for WindGate.
- com.asakusafw.windgate.core - package com.asakusafw.windgate.core
-
Script models for WindGate.
- com.asakusafw.windgate.core.process - package com.asakusafw.windgate.core.process
-
Provides WindGate process.
- com.asakusafw.windgate.core.resource - package com.asakusafw.windgate.core.resource
-
Abstract implementations of WindGate resources.
- com.asakusafw.windgate.core.session - package com.asakusafw.windgate.core.session
-
Provides WindGate session management.
- com.asakusafw.windgate.core.util - package com.asakusafw.windgate.core.util
-
Utilities for WindGate.
- com.asakusafw.windgate.core.vocabulary - package com.asakusafw.windgate.core.vocabulary
-
WindGate common configuration vocabularies.
- com.asakusafw.windgate.file.resource - package com.asakusafw.windgate.file.resource
-
Resource implementation using the local file system (for testing).
- com.asakusafw.windgate.file.session - package com.asakusafw.windgate.file.session
-
Session implementation using the local file system.
- com.asakusafw.windgate.hadoopfs - package com.asakusafw.windgate.hadoopfs
-
WindGate resources using Hadoop FileSystem core classes.
- com.asakusafw.windgate.hadoopfs.jsch - package com.asakusafw.windgate.hadoopfs.jsch
-
WindGate resources using Hadoop FileSystem via SSH connection using
JSch.
- com.asakusafw.windgate.hadoopfs.ssh - package com.asakusafw.windgate.hadoopfs.ssh
-
WindGate resources using Hadoop FileSystem via SSH connection.
- com.asakusafw.windgate.hadoopfs.temporary - package com.asakusafw.windgate.hadoopfs.temporary
-
WindGate drivers for temporary files.
- com.asakusafw.windgate.jdbc - package com.asakusafw.windgate.jdbc
-
WindGate resources using JDBC.
- com.asakusafw.windgate.retryable - package com.asakusafw.windgate.retryable
-
Retryable Process Extension for WindGate.
- com.asakusafw.windgate.stream - package com.asakusafw.windgate.stream
-
WindGate resource skeletons using Input/Output streams.
- com.asakusafw.windgate.stream.file - package com.asakusafw.windgate.stream.file
-
WindGate resources using local file systems.
- com.asakusafw.workflow.cli - package com.asakusafw.workflow.cli
-
CLI of Asakusa workflow.
- com.asakusafw.workflow.cli.common - package com.asakusafw.workflow.cli.common
-
Common classes for CLI.
- com.asakusafw.workflow.cli.run - package com.asakusafw.workflow.cli.run
-
Implementations of run
command.
- com.asakusafw.workflow.executor - package com.asakusafw.workflow.executor
-
Provides workflow executors.
- com.asakusafw.workflow.executor.basic - package com.asakusafw.workflow.executor.basic
-
Basic implementations of workflow executions.
- com.asakusafw.workflow.hadoop - package com.asakusafw.workflow.hadoop
-
Asakusa workflow Hadoop bridge classes.
- com.asakusafw.workflow.hadoop.bootstrap - package com.asakusafw.workflow.hadoop.bootstrap
-
Hadoop bridge bootstrap for Windows platform.
- com.asakusafw.workflow.model - package com.asakusafw.workflow.model
-
Represents workflow models.
- com.asakusafw.workflow.model.attribute - package com.asakusafw.workflow.model.attribute
-
Provides common attributes.
- com.asakusafw.workflow.model.basic - package com.asakusafw.workflow.model.basic
-
Basic implementations of workflow models.
- com.asakusafw.yaess.basic - package com.asakusafw.yaess.basic
-
Basic modules for YAESS.
- com.asakusafw.yaess.bootstrap - package com.asakusafw.yaess.bootstrap
-
Program entries for YAESS.
- com.asakusafw.yaess.core - package com.asakusafw.yaess.core
-
Core models/interfaces for YAESS.
- com.asakusafw.yaess.core.task - package com.asakusafw.yaess.core.task
-
Facade tasks for YAESS.
- com.asakusafw.yaess.core.util - package com.asakusafw.yaess.core.util
-
Utilities for YAESS.
- com.asakusafw.yaess.flowlog - package com.asakusafw.yaess.flowlog
-
Generate logs for individual jobflow executions.
- com.asakusafw.yaess.iterative - package com.asakusafw.yaess.iterative
-
YAESS extension for Asakusa Iterative Extensions.
- com.asakusafw.yaess.jobqueue - package com.asakusafw.yaess.jobqueue
-
YAESS Hadoop Script Handlers for Job Queue.
- com.asakusafw.yaess.jobqueue.client - package com.asakusafw.yaess.jobqueue.client
-
YAESS Hadoop Script Handlers for Job Queue.
- com.asakusafw.yaess.jsch - package com.asakusafw.yaess.jsch
-
YAESS Script Handlers via JSch.
- com.asakusafw.yaess.multidispatch - package com.asakusafw.yaess.multidispatch
-
YAESS Script Handler Dispatcher.
- com.asakusafw.yaess.paralleljob - package com.asakusafw.yaess.paralleljob
-
Simple Parallel Job Scheduler Plug-in for YAESS.
- com.asakusafw.yaess.tools - package com.asakusafw.yaess.tools
-
Command line tools for YAESS.
- combine(JobContext, List<StageInputSplit>) - Method in class com.asakusafw.runtime.stage.input.DefaultSplitCombiner
-
- combine(JobContext, List<StageInputSplit>) - Method in class com.asakusafw.runtime.stage.input.ExtremeSplitCombiner
-
- combine(JobContext, List<StageInputSplit>) - Method in class com.asakusafw.runtime.stage.input.IdentitySplitCombiner
-
- combine(JobContext, List<StageInputSplit>) - Method in class com.asakusafw.runtime.stage.input.SplitCombiner
-
- combineSummarization(T) - Method in interface com.asakusafw.vocabulary.model.SummarizedModel.Interface
-
Deprecated.
Summarizes the target model into this.
- Command(String, List<String>, String, String, Map<String, String>) - Constructor for class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
Creates a new instance.
- COMMAND_DELETE - Static variable in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
The remote 'delete' command path.
- COMMAND_GET - Static variable in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
The remote 'get' command path.
- COMMAND_PUT - Static variable in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
The remote 'put' command path.
- CommandBuilder<T> - Interface in com.asakusafw.utils.jcommander
-
An abstract super interface of command builders.
- CommandConfigurationException - Exception in com.asakusafw.utils.jcommander
-
Exceptions about configuring command.
- CommandConfigurationException(String) - Constructor for exception com.asakusafw.utils.jcommander.CommandConfigurationException
-
Creates a new instance.
- CommandConfigurationException(String, Throwable) - Constructor for exception com.asakusafw.utils.jcommander.CommandConfigurationException
-
Creates a new instance.
- commander - Variable in class com.asakusafw.utils.jcommander.common.GroupUsageCommand
-
The context commander.
- CommandException - Exception in com.asakusafw.utils.jcommander
-
Exceptions about command.
- CommandException(String) - Constructor for exception com.asakusafw.utils.jcommander.CommandException
-
Creates a new instance.
- CommandException(String, Throwable) - Constructor for exception com.asakusafw.utils.jcommander.CommandException
-
Creates a new instance.
- CommandExecutionException - Exception in com.asakusafw.utils.jcommander
-
Exceptions about executing command.
- CommandExecutionException(String) - Constructor for exception com.asakusafw.utils.jcommander.CommandExecutionException
-
Creates a new instance.
- CommandExecutionException(String, Throwable) - Constructor for exception com.asakusafw.utils.jcommander.CommandExecutionException
-
Creates a new instance.
- CommandLauncher - Interface in com.asakusafw.utils.gradle
-
Launches commands.
- CommandLauncher - Interface in com.asakusafw.workflow.executor
-
Launches commands.
- CommandLineUtil - Class in com.asakusafw.windgate.cli
-
Utilities for command line interfaces.
- CommandLineUtil - Class in com.asakusafw.yaess.bootstrap
-
Utilities for command line interfaces.
- CommandLineUtil - Class in com.asakusafw.yaess.tools
-
Utilities for command line interfaces.
- CommandLineUtils - Class in com.asakusafw.dmdl.util
-
Utilities for command line interfaces.
- CommandPath - Class in com.asakusafw.utils.gradle
-
Represents a command path.
- CommandPath(List<? extends Path>) - Constructor for class com.asakusafw.utils.gradle.CommandPath
-
Creates a new instance.
- CommandProvider - Interface in com.asakusafw.utils.jcommander.common
-
Provides commands.
- CommandScript - Class in com.asakusafw.yaess.core
-
A script that describes process command using operating system shell.
- CommandScript(String, Set<String>, String, String, List<String>, Map<String, String>) - Constructor for class com.asakusafw.yaess.core.CommandScript
-
Creates a new instance.
- CommandScript(String, Set<String>, String, String, List<String>, Map<String, String>, Collection<String>) - Constructor for class com.asakusafw.yaess.core.CommandScript
-
Creates a new instance.
- CommandScriptHandler - Interface in com.asakusafw.yaess.core
-
- CommandScriptHandlerDispatcher - Class in com.asakusafw.yaess.multidispatch
-
- CommandScriptHandlerDispatcher() - Constructor for class com.asakusafw.yaess.multidispatch.CommandScriptHandlerDispatcher
-
Creates a new instance.
- CommandTaskInfo - Interface in com.asakusafw.workflow.model
-
Represents a command task.
- CommandTaskInfo.ConfigurationResolver - Interface in com.asakusafw.workflow.model
-
Resolves extra configurations.
- CommandToken - Class in com.asakusafw.workflow.model
-
Represents a token in command.
- CommandToken(String) - Constructor for class com.asakusafw.workflow.model.CommandToken
-
Creates a new instance.
- CommandToken.TokenKind - Enum in com.asakusafw.workflow.model
-
Represents a token.
- comment(String) - Method in class com.asakusafw.directio.hive.serde.DataModelDescriptorBuilder
-
Sets comment for the target data model.
- comment(int, String) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Registers a comment.
- comment(int, String) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- Comment - Interface in com.asakusafw.utils.java.model.syntax
-
An abstract super interface of comments.
- COMMENT_CHARSET - Static variable in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Charset for commit mark file comments.
- CommentEmitTrait - Class in com.asakusafw.utils.java.model.util
-
A Java DOM trait for attaching comment text.
- CommentEmitTrait(List<String>) - Constructor for class com.asakusafw.utils.java.model.util.CommentEmitTrait
-
Creates a new instance.
- commitAttemptOutput(OutputAttemptContext) - Method in interface com.asakusafw.runtime.directio.DirectDataSource
-
Commits output on the attempt.
- commitAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- commitAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceCore
-
- commitAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.keepalive.KeepAliveDataSource
-
- commitJob(JobContext) - Method in class com.asakusafw.runtime.stage.output.LegacyBridgeOutputCommitter
-
- commitTask(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.LegacyBridgeOutputCommitter
-
- commitTransactionOutput(OutputTransactionContext) - Method in interface com.asakusafw.runtime.directio.DirectDataSource
-
Commits output on the transaction.
- commitTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- commitTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceCore
-
- commitTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.keepalive.KeepAliveDataSource
-
- CommonsLoggingReport - Class in com.asakusafw.runtime.report
-
Report API via Commons Logging.
- CommonsLoggingReport() - Constructor for class com.asakusafw.runtime.report.CommonsLoggingReport
-
- Comparator() - Constructor for class com.asakusafw.runtime.stage.collector.SortableSlot.Comparator
-
Creates a new instance.
- compare(WritableComparable, WritableComparable) - Method in class com.asakusafw.runtime.io.util.ShuffleKey.AbstractGroupComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class com.asakusafw.runtime.io.util.ShuffleKey.AbstractGroupComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class com.asakusafw.runtime.stage.collector.SortableSlot.Comparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class com.asakusafw.runtime.util.BasicByteArrayComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in interface com.asakusafw.runtime.util.ByteArrayComparator
-
Compares the two byte array regions (as unsigned bytes), and returns their sign value.
- compare(byte[], int, int, byte[], int, int) - Method in class com.asakusafw.runtime.util.PureByteArrayComparator
-
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.BooleanOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.ByteOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.DateOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.DateTimeOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.DecimalOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.DoubleOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.FloatOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.IntOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.LongOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.ShortOption
-
Compares between the two objects in serialized form.
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.asakusafw.runtime.value.StringOption
-
Compares between the two objects in serialized form.
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.io.util.InvertOrder
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.io.util.NullWritableRawComparable
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.io.util.ShuffleKey
-
- compareInBytes(byte[], int, byte[], int) - Method in interface com.asakusafw.runtime.io.util.WritableRawComparable
-
Compares two objects in bytes.
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableTuple
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableUnion
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.stage.directio.StringTemplate
-
Compares two objects in bytes.
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.BooleanOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.ByteOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.DateOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.DateTimeOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.DecimalOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.DoubleOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.FloatOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.IntOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.LongOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.ShortOption
-
- compareInBytes(byte[], int, byte[], int) - Method in class com.asakusafw.runtime.value.StringOption
-
- CompareOperator - Enum in com.asakusafw.testdriver.rule
-
Represents a compare operator.
- compareTo(ClassInfo) - Method in class com.asakusafw.info.value.ClassInfo
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.io.util.InvertOrder
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.io.util.NullWritableRawComparable
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.io.util.ShuffleKey
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableTuple
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableUnion
-
- compareTo(SortableSlot) - Method in class com.asakusafw.runtime.stage.collector.SortableSlot
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.stage.directio.StringTemplate
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.BooleanOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.ByteOption
-
- compareTo(Date) - Method in class com.asakusafw.runtime.value.Date
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.DateOption
-
- compareTo(DateTime) - Method in class com.asakusafw.runtime.value.DateTime
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.DateTimeOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.DecimalOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.DoubleOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.FloatOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.IntOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.LongOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.ShortOption
-
- compareTo(WritableRawComparable) - Method in class com.asakusafw.runtime.value.StringOption
-
- compareTo(PropertyName) - Method in class com.asakusafw.testdriver.core.PropertyName
-
- Compatibility - Class in com.asakusafw.directio.hive.orc
-
compatibility layer for Direct I/O ORC File support.
- Compatibility() - Constructor for class com.asakusafw.directio.hive.orc.Compatibility
-
- Compatibility - Class in com.asakusafw.directio.hive.parquet
-
compatibility layer for Direct I/O Parquet support.
- Compatibility() - Constructor for class com.asakusafw.directio.hive.parquet.Compatibility
-
- CompatibilityUtil - Class in com.asakusafw.directio.hive.util
-
utilities about Hive v1/v2 compatibilities.
- CompatibilityV1 - Class in com.asakusafw.directio.hive.orc.v1
-
compatibility layer for Direct I/O ORC File support.
- CompatibilityV1() - Constructor for class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
- CompatibilityV1 - Class in com.asakusafw.directio.hive.parquet.v1
-
compatibility layer for Direct I/O Parquet support.
- CompatibilityV1() - Constructor for class com.asakusafw.directio.hive.parquet.v1.CompatibilityV1
-
- CompatibilityV2 - Class in com.asakusafw.directio.hive.orc.v2
-
compatibility layer for Direct I/O ORC File support.
- CompatibilityV2() - Constructor for class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
- CompatibilityV2 - Class in com.asakusafw.directio.hive.parquet.v2
-
compatibility layer for Direct I/O Parquet support.
- CompatibilityV2() - Constructor for class com.asakusafw.directio.hive.parquet.v2.CompatibilityV2
-
- CompilationUnit - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents compilation units.
- CompilationUnitImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- CompilationUnitImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
- compile(String) - Static method in class com.asakusafw.runtime.directio.FilePattern
-
Compiles pattern expression.
- compileBatch(Class<?>) - Method in interface com.asakusafw.testdriver.compiler.CompilerSession
-
Compiles a batch class.
- CompileEnvironment - Class in com.asakusafw.operator
-
Represents operator compiler environment.
- CompileEnvironment(ProcessingEnvironment, List<? extends OperatorDriver>, List<? extends DataModelMirrorRepository>) - Constructor for class com.asakusafw.operator.CompileEnvironment
-
Creates a new instance.
- CompileEnvironment.Support - Enum in com.asakusafw.operator
-
- compileFlow(FlowDescription, FlowPortMap) - Method in interface com.asakusafw.testdriver.compiler.CompilerSession
-
Compiles a flow.
- compileJobflow(Class<?>) - Method in interface com.asakusafw.testdriver.compiler.CompilerSession
-
Compiles a jobflow class.
- CompilerConfiguration - Interface in com.asakusafw.testdriver.compiler
-
- CompilerConfiguration.DebugLevel - Enum in com.asakusafw.testdriver.compiler
-
Represents a debug level.
- CompilerConfiguration.OptimizeLevel - Enum in com.asakusafw.testdriver.compiler
-
Represents an optimization level.
- CompilerConstants - Class in com.asakusafw.testdriver.compiler
-
Constants for Asakusa DSL TestKit Compiler.
- CompilerOption - Class in com.asakusafw.operator
-
Compiler options.
- CompilerSession - Interface in com.asakusafw.testdriver.compiler
-
An abstract super interface of Asakusa DSL TestKit Compiler.
- CompilerToolkit - Interface in com.asakusafw.testdriver.compiler
-
Entry API for Asakusa DSL TestKit Compiler.
- complete() - Method in class com.asakusafw.windgate.core.session.SessionMirror
-
Completes and releases this session.
- complete() - Method in class com.asakusafw.windgate.core.session.SessionMirror.Null
-
- completesSession - Variable in enum com.asakusafw.windgate.cli.ExecutionKind
-
Whether this execution completes a session.
- CompositeDataModelDriver - Class in com.asakusafw.dmdl.java.emitter
-
- CompositeDataModelDriver(ClassLoader) - Constructor for class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- CompositeDataModelDriver(List<? extends JavaDataModelDriver>) - Constructor for class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
Creates and returns a new instance.
- CompositeSourceRepository - Class in com.asakusafw.dmdl.source
-
- CompositeSourceRepository(List<? extends DmdlSourceRepository>) - Constructor for class com.asakusafw.dmdl.source.CompositeSourceRepository
-
Creates and returns a new instance.
- CompositeVerifyRule - Class in com.asakusafw.testdriver.core
-
Composite verify rule.
- CompositeVerifyRule(VerifyRule, List<? extends TestRule>) - Constructor for class com.asakusafw.testdriver.core.CompositeVerifyRule
-
Creates a new instance.
- COMPUTATION_MODULE - Static variable in annotation type com.asakusafw.runtime.trace.TraceLocation
-
Represents the computation module ID.
- compute(Model) - Static method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
Returns the digest value of the target object.
- computeBlocks(FileSystem, FileStatus) - Static method in class com.asakusafw.runtime.directio.hadoop.BlockMap
-
Returns a list of
BlockInfo
for the target file.
- computeInputFragments(StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
- computeInputFragments(AbstractOrcFileFormat<?>, StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.orc.Compatibility
-
- computeInputFragments(AbstractOrcFileFormat<?>, StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
- computeInputFragments(AbstractOrcFileFormat<?>, StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
- computeInputFragments(StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
- computeInputFragments(AbstractParquetFileFormat<?>, StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.parquet.Compatibility
-
- computeInputFragments(AbstractParquetFileFormat<?>, StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.parquet.v1.CompatibilityV1
-
- computeInputFragments(AbstractParquetFileFormat<?>, StripedDataFormat.InputContext) - Method in class com.asakusafw.directio.hive.parquet.v2.CompatibilityV2
-
- computeInputFragments(StripedDataFormat.InputContext) - Method in interface com.asakusafw.runtime.directio.hadoop.StripedDataFormat
-
- computeName(EmitContext, ModelDeclaration) - Method in interface com.asakusafw.dmdl.directio.hive.common.Namer
-
Returns the related name for the target model.
- computeTrackingId(ExecutionContext, ExecutionScript) - Static method in class com.asakusafw.yaess.core.Job
-
Computes the tracking ID.
- computeTrackingId(ExecutionContext) - Static method in class com.asakusafw.yaess.core.Job
-
Computes the tracking ID for script-less job.
- concat(E) - Method in class com.asakusafw.utils.collections.SingleLinkedList
-
Creates and returns a new list with the value in head of this list.
- concat(List<? extends Source<? extends T>>) - Static method in class com.asakusafw.utils.io.Sources
-
Concatenates a list of sources.
- ConcreteDataModelMirror - Class in com.asakusafw.operator.model
-
- ConcreteDataModelMirror(CompileEnvironment, DeclaredType, PropertyMirrorCollector) - Constructor for class com.asakusafw.operator.model.ConcreteDataModelMirror
-
Creates a new instance.
- ConcreteModelEmitter - Class in com.asakusafw.dmdl.java.emitter
-
Abstract super class which emits a record/joined/summarized model as a Java model class.
- ConcreteModelEmitter(DmdlSemantics, Configuration, ModelDeclaration, JavaDataModelDriver) - Constructor for class com.asakusafw.dmdl.java.emitter.ConcreteModelEmitter
-
Creates and returns a new instance.
- ConcurrentBatchFileCacheRepository - Class in com.asakusafw.runtime.util.cache
-
- ConcurrentBatchFileCacheRepository(FileCacheRepository, ExecutorService) - Constructor for class com.asakusafw.runtime.util.cache.ConcurrentBatchFileCacheRepository
-
Creates a new instance with default exception handler.
- ConcurrentBatchFileCacheRepository(FileCacheRepository, ExecutorService, ConcurrentBatchFileCacheRepository.ExceptionHandler) - Constructor for class com.asakusafw.runtime.util.cache.ConcurrentBatchFileCacheRepository
-
Creates a new instance.
- ConcurrentBatchFileCacheRepository.ExceptionHandler - Interface in com.asakusafw.runtime.util.cache
-
Exception handler.
- ConditionalExpression - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents conditional expression.
- ConditionalExpressionImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ConditionalExpressionImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
- ConditionSheetItem - Enum in com.asakusafw.testdriver.excel.legacy
-
Represents a kind of cell on the Excel rule sheets.
- ConditionSheetItem.ItemType - Enum in com.asakusafw.testdriver.excel.legacy
-
Represents a kind of item.
- ConfigurableBinaryStreamFormat<T> - Class in com.asakusafw.runtime.directio.hadoop
-
- ConfigurableBinaryStreamFormat() - Constructor for class com.asakusafw.runtime.directio.hadoop.ConfigurableBinaryStreamFormat
-
- Configuration(ClassLoader, List<File>, Pattern, Function<? super TableInfo, ? extends String>, String, File) - Constructor for class com.asakusafw.directio.hive.tools.cli.GenerateCreateTableTask.Configuration
-
Creates a new instance.
- Configuration() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
- configuration() - Method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileTrait
-
- configuration() - Method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileTrait
-
- Configuration() - Constructor for class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait.Configuration
-
- Configuration() - Constructor for class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatTrait.Configuration
-
- Configuration() - Constructor for class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
- Configuration - Class in com.asakusafw.dmdl.java
-
Configurations for DMDL Java emitter.
- Configuration(ModelFactory, DmdlSourceRepository, Name, Emitter, ClassLoader, Locale) - Constructor for class com.asakusafw.dmdl.java.Configuration
-
Creates and returns a new instance.
- Configuration() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
- Configuration() - Constructor for class com.asakusafw.runtime.stage.input.DefaultSplitCombiner.Configuration
-
- Configuration(TestDriverContext, BatchInfo, String) - Constructor for class com.asakusafw.testdriver.tools.runner.RunTask.Configuration
-
Creates a new instance.
- CONFIGURATION_FILE_NAME - Static variable in class com.asakusafw.runtime.flow.RuntimeResourceManager
-
The standard name of the framework configuration file.
- CONFIGURATION_FILE_PATH - Static variable in class com.asakusafw.runtime.flow.RuntimeResourceManager
-
The path to configuration file (relative from $ASAKUSA_HOME).
- ConfigurationDetecter - Class in com.asakusafw.runtime.util.hadoop
-
Detects and write out the current Hadoop configuration directory.
- ConfigurationFactory - Class in com.asakusafw.testdriver.hadoop
-
Creates Configuration
s with system defaults.
- ConfigurationFactory(URL) - Constructor for class com.asakusafw.testdriver.hadoop.ConfigurationFactory
-
Creates a new instance.
- ConfigurationFactory(ConfigurationFactory.Preferences) - Constructor for class com.asakusafw.testdriver.hadoop.ConfigurationFactory
-
Creates a new instance.
- ConfigurationFactory.Preferences - Class in com.asakusafw.testdriver.hadoop
-
- ConfigurationGroup - Class in com.asakusafw.operation.tools.directio.conf
-
A group command for Direct I/O configuration.
- ConfigurationGroup() - Constructor for class com.asakusafw.operation.tools.directio.conf.ConfigurationGroup
-
- ConfigurationItem - Interface in com.asakusafw.windgate.core.vocabulary
-
An abstract super interface of configuration items.
- ConfigurationListCommand - Class in com.asakusafw.operation.tools.directio.conf
-
A command for printing Direct I/O configuration.
- ConfigurationListCommand() - Constructor for class com.asakusafw.operation.tools.directio.conf.ConfigurationListCommand
-
- ConfigurationParameter - Class in com.asakusafw.operation.tools.directio.common
-
Handles parameters about Hadoop configuration.
- ConfigurationParameter() - Constructor for class com.asakusafw.operation.tools.directio.common.ConfigurationParameter
-
- ConfigurationProvider - Class in com.asakusafw.runtime.util.hadoop
-
Creates Configuration
s with system defaults.
- ConfigurationProvider() - Constructor for class com.asakusafw.runtime.util.hadoop.ConfigurationProvider
-
Creates a new instance.
- ConfigurationProvider(URL) - Constructor for class com.asakusafw.runtime.util.hadoop.ConfigurationProvider
-
Creates a new instance.
- ConfigurationSystemCommand - Class in com.asakusafw.operation.tools.directio.conf
-
A command for printing Direct I/O system configuration.
- ConfigurationSystemCommand() - Constructor for class com.asakusafw.operation.tools.directio.conf.ConfigurationSystemCommand
-
- configure(DirectDataSourceProfile) - Method in class com.asakusafw.runtime.directio.AbstractDirectDataSource
-
Configures this data source.
- configure(DirectDataSourceProfile) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- configure(Job) - Method in class com.asakusafw.runtime.stage.inprocess.InProcessStageConfigurator
-
- configure(Job) - Method in class com.asakusafw.runtime.stage.optimizer.LibraryCopySuppressionConfigurator
-
- configure(Job) - Method in class com.asakusafw.runtime.stage.optimizer.ReducerSimplifierConfigurator
-
- configure(Job) - Method in class com.asakusafw.runtime.stage.StageConfigurator
-
Configures the target job.
- configure(Configuration) - Method in class com.asakusafw.runtime.util.hadoop.ConfigurationProvider
-
- configure(Job) - Method in class com.asakusafw.runtime.workaround.snappyjava.MacSnappyJavaWorkaround
-
- configure() - Method in class com.asakusafw.testdriver.configurator.SnappyConfigurator
-
- configure() - Method in class com.asakusafw.testdriver.core.TestingEnvironmentConfigurator
-
Configures the current testing environment.
- configure(Configuration) - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory
-
- configure(String, String) - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
Adds a configuration item.
- configure(String, String) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Adds a runtime configuration item.
- configure() - Method in class com.asakusafw.testdriver.windows.WindowsEnvironmentConfigurator
-
- configure(T, TryConsumer<? super T, IOException>) - Method in class com.asakusafw.utils.gradle.BaseProject
-
Configures the given object.
- configure(Consumer<? super CommandBuilder<T>>) - Method in interface com.asakusafw.utils.jcommander.CommandBuilder
-
Configures this object.
- configure(Consumer<? super CommandBuilder<T>>) - Method in class com.asakusafw.utils.jcommander.JCommanderWrapper
-
Configures this object.
- configure(T) - Method in class com.asakusafw.windgate.core.BaseProvider
-
Configures this provider.
- configure(ProcessProfile) - Method in class com.asakusafw.windgate.core.process.BasicProcessProvider
-
- configure(ResourceProfile) - Method in class com.asakusafw.windgate.core.util.VoidResourceProvider
-
- configure(ResourceProfile) - Method in class com.asakusafw.windgate.file.resource.FileResourceProvider
-
- configure(SessionProfile) - Method in class com.asakusafw.windgate.file.session.FileSessionProvider
-
- configure(ResourceProfile) - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsProvider
-
- configure(ResourceProfile) - Method in class com.asakusafw.windgate.hadoopfs.jsch.JschHadoopFsProvider
-
- configure(ResourceProfile) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceProvider
-
- configure(ProcessProfile) - Method in class com.asakusafw.windgate.retryable.RetryableProcessProvider
-
- configure(ResourceProfile) - Method in class com.asakusafw.windgate.stream.file.FileResourceProvider
-
- configure(ServiceProfile<?>) - Method in class com.asakusafw.yaess.core.CoreProfile
-
- configure(ServiceProfile<?>) - Method in class com.asakusafw.yaess.core.ExecutionLockProvider
-
- configure(ServiceProfile<?>) - Method in class com.asakusafw.yaess.core.ExecutionMonitorProvider
-
- configure(ServiceProfile<?>) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
- configure(ServiceProfile<?>) - Method in class com.asakusafw.yaess.core.JobScheduler
-
- configure(ServiceProfile<?>) - Method in interface com.asakusafw.yaess.core.Service
-
Configures this service.
- configure(ServiceProfile<?>) - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- configureExtension(ServiceProfile<?>) - Method in class com.asakusafw.yaess.basic.BasicCommandScriptHandler
-
- configureExtension(ServiceProfile<?>) - Method in class com.asakusafw.yaess.basic.BasicHadoopScriptHandler
-
- configureExtension(ServiceProfile<?>) - Method in class com.asakusafw.yaess.basic.ProcessCommandScriptHandler
-
Configures this handler internally (extension point).
- configureExtension(ServiceProfile<?>) - Method in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
Configures this handler internally (extension point).
- configureExtension(ServiceProfile<?>) - Method in class com.asakusafw.yaess.jsch.SshCommandScriptHandler
-
- configureExtension(ServiceProfile<?>) - Method in class com.asakusafw.yaess.jsch.SshHadoopScriptHandler
-
- configureJsonFormat(JsonFormat.Builder<T>) - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
- configureStage(Job, VariableTable) - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Configures the Job
object for this stage.
- confluent(Source<T>, Source<T>) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Returns a new confluent operator instance.
- confluent(Source<T>, Source<T>, Source<T>) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Returns a new confluent operator instance.
- confluent(Source<T>, Source<T>, Source<T>, Source<T>) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Returns a new confluent operator instance.
- confluent(Iterable<? extends Source<T>>) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Returns a new confluent operator instance.
- confluent(Source<T>...) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Returns a new confluent operator instance.
- confluent(Source<T>, Source<T>) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Returns a new confluent operator instance.
- confluent(Source<T>, Source<T>, Source<T>) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Returns a new confluent operator instance.
- confluent(Source<T>, Source<T>, Source<T>, Source<T>) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Returns a new confluent operator instance.
- confluent(Iterable<? extends Source<T>>) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Returns a new confluent operator instance.
- confluent(Source<T>...) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Returns a new confluent operator instance.
- Confluent - Annotation Type in com.asakusafw.vocabulary.operator
-
Represents confluent operator annotation.
- CONFLUENT_NAME - Static variable in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
The common instance name of confluent operator.
- connect(Output, Consumer<? super Wire>) - Method in class com.asakusafw.info.graph.Input
-
- connect(Input, Consumer<? super Wire>) - Method in class com.asakusafw.info.graph.Output
-
- connect(TOpposite) - Method in class com.asakusafw.info.graph.Port
-
Connects to the given opposite port.
- connect(TOpposite, Consumer<? super Wire>) - Method in class com.asakusafw.info.graph.Port
-
Connects to the given opposite port.
- connect(FlowElementOutput, FlowElementInput) - Static method in class com.asakusafw.vocabulary.flow.graph.PortConnection
-
Connects between the two ports.
- connect() - Method in interface com.asakusafw.windgate.hadoopfs.ssh.SshConnection
-
Connects to this target.
- Connectivity - Enum in com.asakusafw.vocabulary.flow.graph
-
Represents a kind of connectivity.
- Constant - Class in com.asakusafw.vocabulary.flow.builder
-
Represents a constant.
- Constant(Type, Object) - Constructor for class com.asakusafw.vocabulary.flow.builder.Constant
-
Creates a new instance.
- ConstantRetryStrategy - Class in com.asakusafw.runtime.util.lock
-
- ConstantRetryStrategy() - Constructor for class com.asakusafw.runtime.util.lock.ConstantRetryStrategy
-
Creates a new instance for do not retry tasks.
- ConstantRetryStrategy(int) - Constructor for class com.asakusafw.runtime.util.lock.ConstantRetryStrategy
-
Creates a new instance for do not retry tasks.
- ConstantRetryStrategy(int, long) - Constructor for class com.asakusafw.runtime.util.lock.ConstantRetryStrategy
-
Creates a new instance.
- ConstantRetryStrategy(int, long, long) - Constructor for class com.asakusafw.runtime.util.lock.ConstantRetryStrategy
-
Creates a new instance.
- Constants - Class in com.asakusafw.operator
-
Available constant values in this project.
- Constants - Class in com.asakusafw.vocabulary.windgate
-
The common constants of WindGate vocabularies.
- ConstructorDeclaration - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents constructor declarations.
- ConstructorDeclarationImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ConstructorDeclarationImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- ConstructorInvocation - Interface in com.asakusafw.utils.java.model.syntax
-
An abstract super interface of constructor invocations.
- constructorReference() - Method in class com.asakusafw.utils.java.model.util.TypeBuilder
-
Returns the constructor invocation using the building type as its qualifier.
- constructorReference(List<? extends Type>) - Method in class com.asakusafw.utils.java.model.util.TypeBuilder
-
Returns the constructor invocation using the building type as its qualifier.
- ConstructorReferenceExpression - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents method reference expressions only for constructors.
- ConstructorReferenceExpressionImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ConstructorReferenceExpressionImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ConstructorReferenceExpressionImpl
-
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Consumes attribute elements about format settings.
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Consumes attribute elements about property settings.
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonStreamSettings
-
Consumes attribute elements about I/O stream settings.
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.text.EscapeSettings
-
Consumes attribute elements about escape settings, and returns corresponding
EscapeSettings
.
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.text.QuoteSettings
-
Consumes attribute elements about escape settings, and returns corresponding
QuoteSettings
.
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Consumes attribute elements about escape settings, and returns corresponding
EscapeSettings
.
- consume(DmdlSemantics, AstAttribute, Map<String, AstAttributeElement>) - Static method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Consumes attribute elements about escape settings, and returns corresponding
EscapeSettings
.
- consume(int) - Method in class com.asakusafw.utils.java.parser.javadoc.DefaultJavadocScanner
-
- consume(int) - Method in interface com.asakusafw.utils.java.parser.javadoc.JavadocScanner
-
Consumes the tokens.
- consumeLineEnd(JavadocScanner, boolean) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Consumes the next line-break, and its consequent white-space, and asterisk tokens.
- container(List<? extends PropertySymbol>) - Static method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
Returns an instance for the target references.
- container(Map<String, ? extends PropertySymbol>) - Static method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
Returns an instance for the target references.
- contains(Path, Path) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Returns whether the parent path contains the child path, or not.
- contains(String) - Method in class com.asakusafw.runtime.value.StringOption
-
Returns whether or not this text contains the given substring.
- contains(StringOption) - Method in class com.asakusafw.runtime.value.StringOption
-
Returns whether or not this text contains the given substring.
- contains(Object) - Method in interface com.asakusafw.utils.graph.Graph
-
Returns whether this graph contains the target vertex or not.
- contains(Object) - Method in class com.asakusafw.utils.graph.HashGraph
-
- containsKey(Object) - Method in class com.asakusafw.runtime.value.ValueOptionMap
-
- ContainsString - Class in com.asakusafw.testdriver.rule
-
Accepts iff actual contains expected string.
- ContainsString() - Constructor for class com.asakusafw.testdriver.rule.ContainsString
-
- containsString() - Static method in class com.asakusafw.testdriver.rule.Predicates
-
- containsTraverse() - Method in class com.asakusafw.runtime.directio.FilePattern
-
Returns whether this pattern contains traverse (**
).
- containsVariables() - Method in class com.asakusafw.runtime.directio.FilePattern
-
Returns whether this pattern contains variables (${var}).
- ContentsConfigurator - Class in com.asakusafw.utils.gradle
-
Configures project contents.
- ContentsConfigurator(TryConsumer<? super Bundle, IOException>) - Constructor for class com.asakusafw.utils.gradle.ContentsConfigurator
-
Creates a new instance.
- Context - Class in com.asakusafw.dmdl.analyzer
-
A context of semantic analyzer.
- Context(DmdlSemantics, Iterable<? extends TypeDriver>, Iterable<? extends AttributeDriver>) - Constructor for class com.asakusafw.dmdl.analyzer.Context
-
Creates and returns a new instance.
- context - Variable in class com.asakusafw.dmdl.directio.json.driver.JsonStreamFormatGenerator
-
The current context.
- context - Variable in class com.asakusafw.dmdl.directio.text.AbstractTextStreamFormatGenerator
-
The current context.
- Context(CompileEnvironment, AnnotationMirror, ExecutableElement) - Constructor for class com.asakusafw.operator.OperatorDriver.Context
-
Creates a new instance.
- Context() - Constructor for class com.asakusafw.runtime.directio.DataFilter.Context
-
Creates a new instance without batch arguments.
- Context(Map<String, String>) - Constructor for class com.asakusafw.runtime.directio.DataFilter.Context
-
Creates a new instance.
- Context - Class in com.asakusafw.windgate.bootstrap
-
Represents a bootstrap context.
- ContinueStatement - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents continue statement.
- ContinueStatementImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- ContinueStatementImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.ContinueStatementImpl
-
- convert(DirectDataSourceProfile, Configuration) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
- convert(DataModelDefinition<?>, JsonElement) - Static method in class com.asakusafw.testdriver.json.JsonObjectDriver
-
- convert(PackageElement) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the package element.
- convert(Name) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the name.
- convert(TypeMirror) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the type mirror.
- convert(ArrayType) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the array type.
- convert(DeclaredType) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the class, interface type, or its parameterized type.
- convert(NoType) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the void
pseudo-type.
- convert(PrimitiveType) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the primitive type.
- convert(TypeVariable) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the type variable.
- convert(WildcardType) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the wildcard type.
- convert(Collection<Modifier>) - Method in class com.asakusafw.utils.java.jsr269.bridge.Jsr269
-
Converts the modifiers.
- convert(String, int) - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocConverter
-
Analyzes the documentation comment string and returns the corresponded
Javadoc
object.
- Convert - Annotation Type in com.asakusafw.vocabulary.operator
-
変換演算子を表すメソッドに付与する注釈。
- convert(Configuration, ResourceProfile) - Static method in class com.asakusafw.windgate.hadoopfs.HadoopFsProfile
-
- convert(Configuration, ResourceProfile) - Static method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
- convert(ResourceProfile) - Static method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
- convert(ProcessProfile) - Static method in class com.asakusafw.windgate.retryable.RetryableProcessProfile
-
- convert(ResourceProfile) - Static method in class com.asakusafw.windgate.stream.file.FileProfile
-
- convert(ServiceProfile<?>) - Static method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Converts the generic profile into the structured profile about
FlowLogger
.
- convert(ServiceProfile<?>) - Static method in class com.asakusafw.yaess.jobqueue.JobClientProfile
-
Converts general profile into the corresponded this profile.
- ConvertOperatorDriver - Class in com.asakusafw.operator.builtin
-
- ConvertOperatorDriver() - Constructor for class com.asakusafw.operator.builtin.ConvertOperatorDriver
-
- copy() - Method in class com.asakusafw.runtime.flow.join.LookUpKey
-
Returns a copy of this key.
- copy(String, String) - Method in class com.asakusafw.testdata.generator.excel.SheetEditor
-
Creates a clone of the specified sheet.
- copy(Path) - Method in class com.asakusafw.utils.gradle.Bundle
-
Copies files from the given directory into bundle root.
- copy(Path, String) - Method in class com.asakusafw.utils.gradle.Bundle
-
Copies files from the given file or directory onto the path.
- copy(String) - Static method in class com.asakusafw.utils.gradle.ContentsConfigurator
-
Returns a configuration which copies contents onto the contents root.
- copy(Path) - Static method in class com.asakusafw.utils.gradle.ContentsConfigurator
-
Returns a configuration which copies contents onto the contents root.
- copy(String, String) - Static method in class com.asakusafw.utils.gradle.ContentsConfigurator
-
Returns a configuration which copies contents onto the given destination path.
- copy(Path, String) - Static method in class com.asakusafw.utils.gradle.ContentsConfigurator
-
Returns a configuration which copies contents onto the given destination path.
- copy(Graph<? extends V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Returns a copy of the target graph.
- copy() - Method in class com.asakusafw.utils.java.model.util.AttributeBuilder
-
Returns a copy of this builder.
- copy() - Method in class com.asakusafw.utils.java.model.util.ExpressionBuilder
-
Returns a copy of this builder.
- copy() - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Returns a copy of this builder.
- copy() - Method in class com.asakusafw.utils.java.model.util.TypeBuilder
-
Returns a copy of this builder.
- copy() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
Creates a new copy without any connections.
- copyFrom(T) - Method in interface com.asakusafw.runtime.model.DataModel
-
Copies the properties in the specified object into this.
- copyFrom(BooleanOption) - Method in class com.asakusafw.runtime.value.BooleanOption
-
Deprecated.
- copyFrom(ByteOption) - Method in class com.asakusafw.runtime.value.ByteOption
-
Deprecated.
- copyFrom(DateOption) - Method in class com.asakusafw.runtime.value.DateOption
-
Deprecated.
- copyFrom(DateTimeOption) - Method in class com.asakusafw.runtime.value.DateTimeOption
-
Deprecated.
- copyFrom(DecimalOption) - Method in class com.asakusafw.runtime.value.DecimalOption
-
Deprecated.
- copyFrom(DoubleOption) - Method in class com.asakusafw.runtime.value.DoubleOption
-
Deprecated.
- copyFrom(FloatOption) - Method in class com.asakusafw.runtime.value.FloatOption
-
Deprecated.
- copyFrom(IntOption) - Method in class com.asakusafw.runtime.value.IntOption
-
Deprecated.
- copyFrom(LongOption) - Method in class com.asakusafw.runtime.value.LongOption
-
Deprecated.
- copyFrom(ShortOption) - Method in class com.asakusafw.runtime.value.ShortOption
-
Deprecated.
- copyFrom(StringOption) - Method in class com.asakusafw.runtime.value.StringOption
-
Deprecated.
- copyFrom(V) - Method in class com.asakusafw.runtime.value.ValueOption
-
- copyFrom(T) - Method in interface com.asakusafw.vocabulary.model.DataModel.Interface
-
Deprecated.
Copies each property value of the specified object into this data model.
- copyFromModel(T, K, V) - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
Copy the data model into the key and value.
- copyObject(Object) - Method in class com.asakusafw.directio.hive.serde.AbstractValueInspector
-
- copyToModel(K, V, T) - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
Copy key and value into the target data model.
- CoreConstants - Class in com.asakusafw.windgate.bootstrap
-
Constants of Asakusa Framework Core.
- CoreOperatorFactory - Class in com.asakusafw.vocabulary.flow.util
-
Provides factory methods for core operators.
- CoreOperatorFactory() - Constructor for class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
- CoreOperatorFactory.Checkpoint<T> - Class in com.asakusafw.vocabulary.flow.util
-
Represents a checkpoint operator which provides restarting point for (partial) failures.
- CoreOperatorFactory.Confluent<T> - Class in com.asakusafw.vocabulary.flow.util
-
Represents a confluent operator which provides union of data-sets.
- CoreOperatorFactory.Empty<T> - Class in com.asakusafw.vocabulary.flow.util
-
Represents an empty operator which provides empty data-sets.
- CoreOperatorFactory.EmptyFragment - Class in com.asakusafw.vocabulary.flow.util
-
An empty operator fragment which requires the target type.
- CoreOperatorFactory.Extend<T> - Class in com.asakusafw.vocabulary.flow.util
-
Represents a extend operator which transforms data model objects into other data model types.
- CoreOperatorFactory.ExtendFragment - Class in com.asakusafw.vocabulary.flow.util
-
An extend operator fragment which requires the target type.
- CoreOperatorFactory.Project<T> - Class in com.asakusafw.vocabulary.flow.util
-
Represents a project operator which transforms data model objects into other data model types.
- CoreOperatorFactory.ProjectFragment - Class in com.asakusafw.vocabulary.flow.util
-
An project operator fragment which requires the target type.
- CoreOperatorFactory.Restructure<T> - Class in com.asakusafw.vocabulary.flow.util
-
Represents a restructure operator which transforms data model objects into other data model types.
- CoreOperatorFactory.RestructureFragment - Class in com.asakusafw.vocabulary.flow.util
-
An restructure operator fragment which requires the target type.
- CoreOperators - Class in com.asakusafw.vocabulary.flow.util
-
Provides factory methods for core operators.
- CoreOperatorSpec - Class in com.asakusafw.info.operator
-
Details of a core operator.
- CoreOperatorSpec.CoreOperatorKind - Enum in com.asakusafw.info.operator
-
Represents a kind of core operator.
- CoreProfile - Class in com.asakusafw.windgate.core
-
A core profile for WindGate execution.
- CoreProfile(int) - Constructor for class com.asakusafw.windgate.core.CoreProfile
-
Creates a new instance.
- CoreProfile - Class in com.asakusafw.yaess.core
-
An abstract implementation of core configuration holder.
- CoreProfile() - Constructor for class com.asakusafw.yaess.core.CoreProfile
-
- count() - Method in class com.asakusafw.yaess.jobqueue.JobClientProvider
-
Returns the number of available clients.
- countCodePoints(StringOption) - Static method in class com.asakusafw.runtime.value.StringOptionUtil
-
Returns the number of code-points in the given
StringOption
.
- Counter - Class in com.asakusafw.runtime.directio
-
Receives count.
- Counter() - Constructor for class com.asakusafw.runtime.directio.Counter
-
- CountingInputStream - Class in com.asakusafw.windgate.stream
-
- CountingInputStream(InputStream) - Constructor for class com.asakusafw.windgate.stream.CountingInputStream
-
Creates a new instance.
- CountingOutputStream - Class in com.asakusafw.windgate.stream
-
- CountingOutputStream(OutputStream) - Constructor for class com.asakusafw.windgate.stream.CountingOutputStream
-
Creates a new instance.
- CountInputStream - Class in com.asakusafw.runtime.directio.util
-
- CountInputStream(InputStream, Counter) - Constructor for class com.asakusafw.runtime.directio.util.CountInputStream
-
Creates a new instance.
- countLeadingWhitespaces(CharSequence, int, int) - Static method in class com.asakusafw.runtime.io.text.TextUtil
-
Returns the number of leading whitespace characters in the given character sequence range.
- CountOutputStream - Class in com.asakusafw.runtime.directio.util
-
- CountOutputStream(OutputStream, Counter) - Constructor for class com.asakusafw.runtime.directio.util.CountOutputStream
-
Creates a new instance.
- countTrailingWhitespaces(CharSequence, int, int) - Static method in class com.asakusafw.runtime.io.text.TextUtil
-
Returns the number of trailing whitespace characters in the given character sequence range.
- countUntil(Collection<JavadocTokenKind>, JavadocScanner, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Returns the number of tokens from the starting index until each token has the specified kind.
- countUntilBlockEnd(JavadocScanner, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Returns the number of tokens from the starting index until the current block was closed.
- countUntilCommentEnd(JavadocScanner, boolean, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Returns the number of tokens from the starting index until the end of this comment.
- countUntilNextLineStart(JavadocScanner, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Returns the number of tokens from the starting index until the next printable token on the subsequent lines.
- countUntilNextPrintable(JavadocScanner, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Returns the number of tokens from the starting index until the next printable token.
- countWhile(Collection<JavadocTokenKind>, JavadocScanner, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocScannerUtil
-
Returns the number of tokens from the starting index while each token has the specified kind.
- countWhileTagName(JavadocScanner, int) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockParserUtil
-
Returns the number of tokens in the current block body.
- create(String, long, Collection<BlockInfo>, boolean) - Static method in class com.asakusafw.runtime.directio.hadoop.BlockMap
-
- create() - Static method in class com.asakusafw.runtime.testing.MockResult
-
Creates a new instance.
- create(DataModelDefinition<T>, URI, TestContext) - Method in interface com.asakusafw.testdriver.core.DataModelSinkProvider
-
Creates a
DataModelSink
object corresponding to the specified URI.
- create(DataModelDefinition<T>, URI, TestContext) - Method in interface com.asakusafw.testdriver.core.DifferenceSinkProvider
-
- create(DataModelDefinition<T>, URI, TestContext) - Method in class com.asakusafw.testdriver.core.SpiDataModelSinkProvider
-
- create(DataModelDefinition<T>, URI, TestContext) - Method in class com.asakusafw.testdriver.core.SpiDifferenceSinkProvider
-
- create(DataModelDefinition<T>, URI, TestContext) - Method in class com.asakusafw.testdriver.excel.ExcelSheetSinkProvider
-
- create(DataModelDefinition<T>, URI, TestContext) - Method in class com.asakusafw.testdriver.html.HtmlDifferenceSinkProvider
-
- create() - Static method in class com.asakusafw.utils.collections.Lists
-
Returns an empty list.
- create() - Static method in class com.asakusafw.utils.collections.Maps
-
Creates and returns an empty map.
- create() - Static method in class com.asakusafw.utils.collections.Sets
-
Returns an empty set.
- create(String, ParameterList) - Method in class com.asakusafw.windgate.core.resource.ResourceProvider
-
- create(String) - Method in class com.asakusafw.windgate.core.session.SessionProvider
-
Creates a new session and acquires the session with the specified session ID.
- create(String, ParameterList) - Method in class com.asakusafw.windgate.core.util.VoidResourceProvider
-
- create(String, ParameterList) - Method in class com.asakusafw.windgate.file.resource.FileResourceProvider
-
- create(String) - Method in class com.asakusafw.windgate.file.session.FileSessionProvider
-
- create(String, ParameterList) - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsProvider
-
- create(String, ParameterList) - Method in class com.asakusafw.windgate.hadoopfs.jsch.JschHadoopFsProvider
-
- create(String, ParameterList) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceProvider
-
- create(String, ParameterList) - Method in class com.asakusafw.windgate.stream.file.FileResourceProvider
-
- create(String, String) - Method in class com.asakusafw.yaess.core.util.TemporaryFiles
-
Creates a new temporary file.
- create(String, String, InputStream) - Method in class com.asakusafw.yaess.core.util.TemporaryFiles
-
Creates a new temporary file.
- createCompileEnvironment(ProcessingEnvironment) - Method in class com.asakusafw.operator.AbstractOperatorAnnotationProcessor
-
Creates a compile environment for this processing (for testing).
- createCompileEnvironment(ProcessingEnvironment) - Method in class com.asakusafw.operator.flowpart.FlowPartAnnotationProcessor
-
- createCompileEnvironment(ProcessingEnvironment) - Method in class com.asakusafw.operator.method.OperatorAnnotationProcessor
-
- createConfig() - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
- createContext(String, String) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Creates output context from execution ID and datasource ID.
- createContext(JobContext, String) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
- createContext(TaskAttemptContext, String) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
- createContext(JobContext, String) - Static method in class com.asakusafw.runtime.stage.output.BridgeOutputFormat
-
Creates output context from Hadoop context.
- createContext(TaskAttemptContext, String) - Static method in class com.asakusafw.runtime.stage.output.BridgeOutputFormat
-
Creates output context from Hadoop context.
- createCursor() - Method in class com.asakusafw.dmdl.source.CompositeSourceRepository
-
- createCursor() - Method in class com.asakusafw.dmdl.source.DmdlSourceDirectory
-
- createCursor() - Method in class com.asakusafw.dmdl.source.DmdlSourceFile
-
- createCursor() - Method in interface com.asakusafw.dmdl.source.DmdlSourceRepository
-
Creates and returns a new cursor which can traverse in this repository.
- createCursor() - Method in class com.asakusafw.dmdl.source.DmdlSourceResource
-
- createDataModelObject() - Method in class com.asakusafw.directio.hive.serde.DataModelDescriptor
-
Creates a new instance of the target data model.
- createDrain(ProcessScript<T>) - Method in interface com.asakusafw.windgate.core.resource.DriverFactory
-
Creates a new drain driver.
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.DriverRepository
-
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.ResourceMirror
-
Creates a new drain driver for this resource.
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.file.resource.FileResourceMirror
-
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsMirror
-
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.hadoopfs.ssh.AbstractSshHadoopFsMirror
-
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceMirror
-
- createDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.stream.file.FileResourceMirror
-
- createDrainForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Creates a new drain driver for the drain of this resource.
- createDrainForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- createDrainForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- createDrainForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- createDrainForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Creates a new drain driver for the source of this resource.
- createDrainForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- createDrainForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- createDrainForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- createEmptyWorkbook(SpreadsheetVersion) - Static method in class com.asakusafw.testdata.generator.excel.WorkbookGenerator
-
Creates a new empty workbook for the target version.
- createFileStatus(Path) - Static method in class com.asakusafw.windgate.hadoopfs.ssh.FileList
-
- createFlow(Class<? extends FlowDescription>, Class<?>...) - Static method in class com.asakusafw.vocabulary.flow.builder.FlowElementBuilder
-
Creates a new instance for flow description class.
- createGetTextFormatInternal() - Method in class com.asakusafw.dmdl.directio.text.AbstractTextStreamFormatGenerator
-
- createInput(Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
- createInput(AbstractOrcFileFormat<T>, Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.orc.Compatibility
-
- createInput(AbstractOrcFileFormat<T>, Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
- createInput(AbstractOrcFileFormat<T>, Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
- createInput(Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
- createInput(AbstractParquetFileFormat<T>, Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.parquet.Compatibility
-
- createInput(AbstractParquetFileFormat<T>, Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.parquet.v1.CompatibilityV1
-
- createInput(AbstractParquetFileFormat<T>, Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.directio.hive.parquet.v2.CompatibilityV2
-
- createInput(Class<? extends T>, String, InputStream) - Method in class com.asakusafw.runtime.directio.BinaryStreamFormat
-
Creates a new
ModelInput
for the specified properties.
- createInput(Class<? extends T>, String, InputStream, long, long) - Method in class com.asakusafw.runtime.directio.BinaryStreamFormat
-
Creates a new
ModelInput
for the specified properties.
- createInput(Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormat
-
Creates a new
ModelInput
for the specified properties.
- createInput(Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormat
-
Creates a new
ModelInput
for the specified properties.
- createInput(Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormatAdapter
-
- createInput(Class<? extends T>, FileSystem, Path, long, long, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
- createInput(Class<? extends T>, String, InputStream, long, long) - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
- createInput(Class<? extends T>, String, InputStream, long, long) - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
- createInput(Class<? extends T>, String, InputStream, long, long) - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
- createInput(Class<? extends T>, String, InputStream, long, long) - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- createJob(Configuration) - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Creates a new job.
- createJobMonitor(String, double) - Method in class com.asakusafw.yaess.core.PhaseMonitor
-
Creates a new child task monitor with the specified task size.
- createKeyObject() - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
Returns a key object.
- createLookUpTable() - Method in class com.asakusafw.runtime.flow.join.JoinResource
-
Returns a builder for building a new lookup table.
- createManipulator(ParameterList) - Method in class com.asakusafw.windgate.core.resource.ResourceProvider
-
- createManipulator(ParameterList) - Method in class com.asakusafw.windgate.core.util.VoidResourceProvider
-
- createManipulator(ParameterList) - Method in class com.asakusafw.windgate.file.resource.FileResourceProvider
-
- createManipulator(ParameterList) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceProvider
-
- createManipulator(ParameterList) - Method in class com.asakusafw.windgate.stream.file.FileResourceProvider
-
- createModelInput(InputStream) - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
- createModelInput(RecordParser) - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
- createModelObject() - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
Creates a new data model object.
- createModelOutput(OutputStream) - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
- createModelOutput(RecordEmitter) - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
- createModelSymbol(AstSimpleName) - Method in class com.asakusafw.dmdl.semantics.DmdlSemantics
-
Creates and returns a new model symbol in this world.
- createObjectInput(InputStream) - Method in class com.asakusafw.utils.io.DefaultSerialization
-
- createObjectOutput(OutputStream) - Method in class com.asakusafw.utils.io.DefaultSerialization
-
- createOperator(Class<? extends Annotation>, Class<?>, String, Class<?>...) - Static method in class com.asakusafw.vocabulary.flow.builder.FlowElementBuilder
-
Creates a new instance for operator method.
- createOperator(Class<? extends Annotation>, Class<?>, Class<?>, String, Class<?>...) - Static method in class com.asakusafw.vocabulary.flow.builder.FlowElementBuilder
-
Creates a new instance for operator method.
- createOutput(Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
- createOutput(AbstractOrcFileFormat<T>, Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.orc.Compatibility
-
- createOutput(AbstractOrcFileFormat<T>, Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
- createOutput(AbstractOrcFileFormat<T>, Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
- createOutput(Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
- createOutput(AbstractParquetFileFormat<T>, Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.parquet.Compatibility
-
- createOutput(AbstractParquetFileFormat<T>, Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.parquet.v1.CompatibilityV1
-
- createOutput(AbstractParquetFileFormat<T>, Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.directio.hive.parquet.v2.CompatibilityV2
-
- createOutput(Class<? extends T>, String, OutputStream) - Method in class com.asakusafw.runtime.directio.BinaryStreamFormat
-
Creates a new
ModelOutput
for the specified properties.
- createOutput(Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormat
-
Creates a new
ModelOutput
for the specified properties.
- createOutput(Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormatAdapter
-
- createOutput(Class<? extends T>, FileSystem, Path, Counter) - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
- createOutput(Class<? extends T>, String, OutputStream) - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
- createOutput(Class<? extends T>, String, OutputStream) - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
- createOutput(Class<? extends T>, String, OutputStream) - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
- createOutput(Class<? extends T>, String, OutputStream) - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- createOutput(DataModelDefinition<V>, T) - Method in class com.asakusafw.testdriver.core.AbstractExporterRetriever
-
Creates a
ModelOutput
to prepare what the exporter will use.
- createOutput(DataModelDefinition<V>, T, TestContext) - Method in class com.asakusafw.testdriver.core.AbstractExporterRetriever
-
- createOutput(DataModelDefinition<V>, T) - Method in class com.asakusafw.testdriver.core.AbstractImporterPreparator
-
Creates a
ModelOutput
to prepare the resource which the importer will use.
- createOutput(DataModelDefinition<V>, T, TestContext) - Method in class com.asakusafw.testdriver.core.AbstractImporterPreparator
-
- createOutput(DataModelDefinition<V>, T, TestContext) - Method in interface com.asakusafw.testdriver.core.ExporterRetriever
-
Creates a
ModelOutput
to prepare what the exporter will use.
- createOutput(DataModelDefinition<V>, T, TestContext) - Method in interface com.asakusafw.testdriver.core.ImporterPreparator
-
Creates a
ModelOutput
to prepare the resource which the importer will use.
- createOutput(DataModelDefinition<V>, ExporterDescription, TestContext) - Method in class com.asakusafw.testdriver.core.SpiExporterRetriever
-
- createOutput(DataModelDefinition<V>, ImporterDescription, TestContext) - Method in class com.asakusafw.testdriver.core.SpiImporterPreparator
-
- createOutput(DataModelDefinition<V>, DirectFileInputDescription, TestContext) - Method in class com.asakusafw.testdriver.directio.DirectFileInputPreparator
-
- createOutput(DataModelDefinition<V>, DirectFileOutputDescription, TestContext) - Method in class com.asakusafw.testdriver.directio.DirectFileOutputRetriever
-
- createOutput(DataModelDefinition<V>, WindGateExporterDescription, TestContext) - Method in class com.asakusafw.testdriver.windgate.WindGateExporterRetriever
-
- createOutput(DataModelDefinition<V>, WindGateImporterDescription, TestContext) - Method in class com.asakusafw.testdriver.windgate.WindGateImporterPreparator
-
- createPrefixMap(Map<?, ?>, String) - Static method in class com.asakusafw.windgate.core.util.PropertiesUtil
-
Creates property pairs which has the specified prefix their key.
- createPrefixMap(Map<?, ?>, String) - Static method in class com.asakusafw.yaess.core.util.PropertiesUtil
-
Creates property pairs which has the specified prefix their key.
- createPreparedStatementSupport(PreparedStatement, List<String>) - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelJdbcSupport
-
- createProcessScript(Class<T>, WindGateImporterDescription) - Static method in class com.asakusafw.testdriver.windgate.WindGateTestHelper
-
- createProcessScript(Class<T>, WindGateExporterDescription) - Static method in class com.asakusafw.testdriver.windgate.WindGateTestHelper
-
- createProfileContext(TestContext) - Static method in class com.asakusafw.testdriver.windgate.WindGateTestHelper
-
- createPropertySymbol(AstSimpleName) - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
Creates and returns a new property symbol in this model.
- createPropertySymbol(AstSimpleName) - Method in class com.asakusafw.dmdl.semantics.ModelSymbol
-
Creates and returns a new property symbol in this model.
- createProvider() - Method in class com.asakusafw.windgate.core.BaseProfile
-
Creates a new provider instance
and attach this profile to the created instance.
- createReader(String, InputStream) - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelStreamSupport
-
- createReader(InputStream) - Static method in class com.asakusafw.windgate.hadoopfs.ssh.FileList
-
Creates a new reaer.
- createRecordDefinition() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- createRecordEmitter(OutputStream) - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
- createRecordEmitter(OutputStream) - Method in class com.asakusafw.runtime.io.tsv.TsvIoFactory
-
- createRecordParser(InputStream) - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
- createRecordParser(InputStream) - Method in class com.asakusafw.runtime.io.tsv.TsvIoFactory
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.input.StageInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.input.TemporaryInputFormat
-
- createRecordWriter(TaskAttemptContext, String, Class<V>) - Method in class com.asakusafw.runtime.stage.output.TemporaryOutputFormat
-
Creates a new RecordWriter
to output temporary data.
- createResourceManipulator(TestContext, WindGateProcessDescription, ParameterList) - Static method in class com.asakusafw.testdriver.windgate.WindGateTestHelper
-
- createResultSetSupport(ResultSet, List<String>) - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelJdbcSupport
-
- createRule(DataModelDefinition<T>, VerifyContext) - Method in class com.asakusafw.testdriver.core.VerifyRuleFactory
-
- createSink(DataModelDefinition<T>, TestContext) - Method in class com.asakusafw.testdriver.core.DataModelSinkFactory
-
Creates a new sink.
- createSink(DataModelDefinition<T>, TestContext) - Method in class com.asakusafw.testdriver.core.DifferenceSinkFactory
-
Creates a new sink.
- createSink(DataModelDefinition<T>, TestContext) - Method in class com.asakusafw.testdriver.excel.ExcelSheetSinkFactory
-
- createSink(DataModelDefinition<T>, TestContext) - Method in class com.asakusafw.testdriver.html.HtmlDifferenceSinkFactory
-
- createSink(OutputStream) - Method in class com.asakusafw.utils.io.DefaultSerialization
-
- createSink(OutputStream) - Method in interface com.asakusafw.utils.io.Serialization
-
- createSlotObjects() - Method in class com.asakusafw.runtime.stage.collector.SlotSorter
-
Returns the array of buffer object for each slot.
- createSource(DataModelDefinition<V>, T) - Method in class com.asakusafw.testdriver.core.AbstractExporterRetriever
-
Creates a
DataModelSource
to retrieve what the target exporter had created.
- createSource(DataModelDefinition<V>, T, TestContext) - Method in class com.asakusafw.testdriver.core.AbstractExporterRetriever
-
- createSource(DataModelDefinition<T>, TestContext) - Method in class com.asakusafw.testdriver.core.DataModelSourceFactory
-
Creates a new source.
- createSource(DataModelDefinition<V>, T, TestContext) - Method in interface com.asakusafw.testdriver.core.ExporterRetriever
-
Creates a
DataModelSource
to retrieve what the target exporter had created.
- createSource(DataModelDefinition<T>, TestContext) - Method in class com.asakusafw.testdriver.core.SourceDataModelSourceFactory
-
- createSource(DataModelDefinition<V>, ExporterDescription, TestContext) - Method in class com.asakusafw.testdriver.core.SpiExporterRetriever
-
- createSource(DataModelDefinition<V>, DirectFileOutputDescription, TestContext) - Method in class com.asakusafw.testdriver.directio.DirectFileOutputRetriever
-
- createSource(DataModelDefinition<V>, WindGateExporterDescription, TestContext) - Method in class com.asakusafw.testdriver.windgate.WindGateExporterRetriever
-
- createSource(InputStream) - Method in class com.asakusafw.utils.io.DefaultSerialization
-
- createSource(InputStream) - Method in interface com.asakusafw.utils.io.Serialization
-
- createSource(String, Source<T>) - Method in class com.asakusafw.vocabulary.flow.builder.FlowElementEditor
-
Returns the
Source
object which represents output port of the target flow.
- createSource(String, Class<T>) - Method in class com.asakusafw.vocabulary.flow.builder.FlowElementEditor
-
Returns the
Source
object which represents output port of the target flow.
- createSource(ProcessScript<T>) - Method in interface com.asakusafw.windgate.core.resource.DriverFactory
-
Creates a new source driver.
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.DriverRepository
-
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.ResourceMirror
-
Creates a new source driver for this resource.
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.file.resource.FileResourceMirror
-
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsMirror
-
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.hadoopfs.ssh.AbstractSshHadoopFsMirror
-
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceMirror
-
- createSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.stream.file.FileResourceMirror
-
- createSourceForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Creates a new source driver for the drain of this resource.
- createSourceForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- createSourceForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- createSourceForDrain(ProcessScript<T>) - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- createSourceForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Creates a new source driver for the source of this resource.
- createSourceForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- createSourceForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- createSourceForSource(ProcessScript<T>) - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- createsSession - Variable in enum com.asakusafw.windgate.cli.ExecutionKind
-
Whether this execution creates a new session.
- createTextFormat() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- createValueObject() - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
Returns a value object.
- createValueObject() - Method in class com.asakusafw.runtime.flow.join.JoinResource
-
Returns a new left value object.
- createVariableName(String) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns a variable name which is different to other property names.
- createVerifier(DataModelDefinition<T>, VerifyContext) - Method in class com.asakusafw.testdriver.core.VerifierFactory
-
Creates a new rule.
- createWriter(String, OutputStream) - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelStreamSupport
-
- createWriter(OutputStream) - Static method in class com.asakusafw.windgate.hadoopfs.ssh.FileList
-
Creates a new writer.
- CsvConfiguration - Class in com.asakusafw.runtime.io.csv
-
CSV configurations.
- CsvConfiguration(Charset, List<String>, String, String, String, String) - Constructor for class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Creates a new instance.
- CsvEmitter - Class in com.asakusafw.runtime.io.csv
-
A simple CSV emitter.
- CsvEmitter(OutputStream, String, CsvConfiguration) - Constructor for class com.asakusafw.runtime.io.csv.CsvEmitter
-
Creates a new instance.
- CsvFieldDriver - Class in com.asakusafw.dmdl.directio.csv.driver
-
Processes @directio.csv.field
attributes.
- CsvFieldDriver() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFieldDriver
-
- CsvFieldDriver - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Processes @windgate.csv.field
attributes.
- CsvFieldDriver() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldDriver
-
- CsvFieldReader - Class in com.asakusafw.runtime.io.text.csv
-
- CsvFieldReader(Reader, char, char, boolean, UnaryOperator<CharSequence>) - Constructor for class com.asakusafw.runtime.io.text.csv.CsvFieldReader
-
Creates a new instance.
- CsvFieldTrait - Class in com.asakusafw.dmdl.directio.csv.driver
-
Attributes for CSV fields.
- CsvFieldTrait(AstNode, CsvFieldTrait.Kind, String) - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
Creates a new instance.
- CsvFieldTrait(AstNode, CsvFieldTrait.Kind, String, CsvFieldTrait.QuoteStrategy) - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
Creates a new instance.
- CsvFieldTrait - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Attributes for CSV fields.
- CsvFieldTrait(AstNode, CsvFieldTrait.Kind, String) - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait
-
Creates a new instance.
- CsvFieldTrait(AstNode, CsvFieldTrait.Kind, String, CsvFieldTrait.QuoteStrategy) - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait
-
Creates a new instance.
- CsvFieldTrait.Kind - Enum in com.asakusafw.dmdl.directio.csv.driver
-
The field kind.
- CsvFieldTrait.Kind - Enum in com.asakusafw.dmdl.windgate.csv.driver
-
The field kind.
- CsvFieldTrait.QuoteStrategy - Enum in com.asakusafw.dmdl.directio.csv.driver
-
Column quoting strategy.
- CsvFieldTrait.QuoteStrategy - Enum in com.asakusafw.dmdl.windgate.csv.driver
-
Column quoting strategy.
- CsvFieldWriter - Class in com.asakusafw.runtime.io.text.csv
-
- CsvFieldWriter(Writer, LineSeparator, char, char, boolean, QuoteStyle, QuoteStyle, UnaryOperator<CharSequence>) - Constructor for class com.asakusafw.runtime.io.text.csv.CsvFieldWriter
-
Creates a new instance.
- CsvFileNameDriver - Class in com.asakusafw.dmdl.directio.csv.driver
-
Processes @directio.csv.file_name
attributes.
- CsvFileNameDriver() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFileNameDriver
-
- CsvFileNameDriver - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Processes @windgate.csv.file_name
attributes.
- CsvFileNameDriver() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvFileNameDriver
-
- CsvFormatDriver - Class in com.asakusafw.dmdl.directio.csv.driver
-
Processes @directio.csv
attributes.
- CsvFormatDriver() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFormatDriver
-
- CsvFormatEmitter - Class in com.asakusafw.dmdl.directio.csv.driver
-
- CsvFormatEmitter() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFormatEmitter
-
- CsvFormatException - Exception in com.asakusafw.runtime.io.csv
-
Represents a CSV format exception.
- CsvFormatException(CsvFormatException.Status, Throwable) - Constructor for exception com.asakusafw.runtime.io.csv.CsvFormatException
-
Creates a new instance.
- CsvFormatException.Reason - Enum in com.asakusafw.runtime.io.csv
-
The reason of CSV format exception.
- CsvFormatException.Status - Class in com.asakusafw.runtime.io.csv
-
Statuses of CSV format exception.
- CsvFormatTrait - Class in com.asakusafw.dmdl.directio.csv.driver
-
Attributes for CSV supported data models.
- CsvFormatTrait(AstNode, CsvFormatTrait.Configuration) - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait
-
Creates and returns a new instance.
- CsvFormatTrait.Configuration - Class in com.asakusafw.dmdl.directio.csv.driver
-
The CSV format configuration.
- CsvIgnoreDriver - Class in com.asakusafw.dmdl.directio.csv.driver
-
Processes @directio.csv.ignore
attributes.
- CsvIgnoreDriver() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvIgnoreDriver
-
- CsvIgnoreDriver - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Processes @windgate.csv.ignore
attributes.
- CsvIgnoreDriver() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvIgnoreDriver
-
- CsvLineNumberDriver - Class in com.asakusafw.dmdl.directio.csv.driver
-
Processes @directio.csv.line_number
attributes.
- CsvLineNumberDriver() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvLineNumberDriver
-
- CsvLineNumberDriver - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Processes @windgate.csv.line_number
attributes.
- CsvLineNumberDriver() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvLineNumberDriver
-
- CsvParser - Class in com.asakusafw.runtime.io.csv
-
A simple CSV parser.
- CsvParser(InputStream, String, CsvConfiguration) - Constructor for class com.asakusafw.runtime.io.csv.CsvParser
-
Creates a new instance.
- CsvReader - Class in com.asakusafw.utils.io.csv
-
A simple implementation of CSV reader.
- CsvReader(Reader) - Constructor for class com.asakusafw.utils.io.csv.CsvReader
-
Creates a new instance.
- CsvRecordNumberDriver - Class in com.asakusafw.dmdl.directio.csv.driver
-
Processes @directio.csv.record_number
attributes.
- CsvRecordNumberDriver() - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvRecordNumberDriver
-
- CsvRecordNumberDriver - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Processes @windgate.csv.record_number
attributes.
- CsvRecordNumberDriver() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvRecordNumberDriver
-
- CsvStreamFormatGenerator - Class in com.asakusafw.dmdl.directio.csv.driver
-
- CsvStreamFormatGenerator(EmitContext, ModelDeclaration, CsvFormatTrait.Configuration) - Constructor for class com.asakusafw.dmdl.directio.csv.driver.CsvStreamFormatGenerator
-
creates a new instance.
- CsvSupportDriver - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Processes @windgate.csv
attributes.
- CsvSupportDriver() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportDriver
-
- CsvSupportEmitter - Class in com.asakusafw.dmdl.windgate.csv.driver
-
- CsvSupportEmitter() - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportEmitter
-
- CsvSupportTrait - Class in com.asakusafw.dmdl.windgate.csv.driver
-
Attributes for CSV supported data models.
- CsvSupportTrait(AstNode, CsvSupportTrait.Configuration) - Constructor for class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait
-
Creates and returns a new instance.
- CsvSupportTrait.Configuration - Class in com.asakusafw.dmdl.windgate.csv.driver
-
The CSV format configuration.
- CsvTextDriver - Class in com.asakusafw.dmdl.directio.text.csv
-
Processes @directio.text.csv
attributes.
- CsvTextDriver() - Constructor for class com.asakusafw.dmdl.directio.text.csv.CsvTextDriver
-
- CsvTextEmitter - Class in com.asakusafw.dmdl.directio.text.csv
-
Emits Direct I/O data format classes about CSV text.
- CsvTextEmitter() - Constructor for class com.asakusafw.dmdl.directio.text.csv.CsvTextEmitter
-
- CsvTextFormat - Class in com.asakusafw.runtime.io.text.csv
-
An implementation of
TextFormat
for RFC4180 style CSV files.
- CsvTextFormat.Builder - Class in com.asakusafw.runtime.io.text.csv
-
- CsvTextTrait - Class in com.asakusafw.dmdl.directio.text.csv
-
Attributes of CSV models.
- CsvTextTrait(AstAttribute, TextFormatSettings, QuoteSettings, TextFieldSettings) - Constructor for class com.asakusafw.dmdl.directio.text.csv.CsvTextTrait
-
Creates a new instance.
- CsvWriter - Class in com.asakusafw.utils.io.csv
-
A simple implementation of CSV writer.
- CsvWriter(Appendable) - Constructor for class com.asakusafw.utils.io.csv.CsvWriter
-
Creates a new instance.
- CursorUtil - Class in com.asakusafw.iterative.common.basic
-
- CustomOperatorSpec - Class in com.asakusafw.info.operator
-
Details of a core operator.
- CustomStorageFormatInfo - Class in com.asakusafw.info.hive
-
Represents custom storage format that using Hadoop input/output format.
- CustomStorageFormatInfo(String, String) - Constructor for class com.asakusafw.info.hive.CustomStorageFormatInfo
-
Creates a new instance.
- GateProfile - Class in com.asakusafw.windgate.core
-
A total profile for WindGate execution.
- GateProfile(String, CoreProfile, SessionProfile, Collection<? extends ProcessProfile>, Collection<? extends ResourceProfile>) - Constructor for class com.asakusafw.windgate.core.GateProfile
-
Creates a new instance.
- GateScript - Class in com.asakusafw.windgate.core
-
A gate script.
- GateScript(String, List<? extends ProcessScript<?>>) - Constructor for class com.asakusafw.windgate.core.GateScript
-
Creates a new instance.
- GateTask - Class in com.asakusafw.windgate.core
-
Executes WindGate.
- GateTask(GateProfile, GateScript, String, boolean, boolean, ParameterList) - Constructor for class com.asakusafw.windgate.core.GateTask
-
Creates a new instance.
- generate(EmitContext, DirectFileInputDescriptionGenerator.Description) - Static method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator
-
Generates the class in the context.
- generate(EmitContext, DirectFileOutputDescriptionGenerator.Description) - Static method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator
-
Generates the class in the context.
- generate(ModelDeclaration) - Method in class com.asakusafw.testdata.generator.excel.WorkbookGenerator
-
Generates a workbook for the specified model.
- generate(ModelDeclaration) - Method in interface com.asakusafw.testdata.generator.TemplateGenerator
-
Generates a test template for the specified model.
- GenerateCreateTable - Class in com.asakusafw.directio.hive.tools.cli
-
Program entry for generate Hive QL CREATE TABLE
statements.
- GenerateCreateTableTask - Class in com.asakusafw.directio.hive.tools.cli
-
- GenerateCreateTableTask() - Constructor for class com.asakusafw.directio.hive.tools.cli.GenerateCreateTableTask
-
- GenerateCreateTableTask.Configuration - Class in com.asakusafw.directio.hive.tools.cli
-
- GenerateExecutionId - Class in com.asakusafw.yaess.tools
-
Generates an execution ID.
- generateExporter(EmitContext, FsProcessDescriptionGenerator.Description) - Static method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator
-
Generates the class in the context.
- generateExporter(EmitContext, JdbcProcessDescriptionGenerator.Description) - Static method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator
-
Generates the class in the context.
- GenerateGroup - Class in com.asakusafw.info.cli.generate
-
A group command for Direct I/O Hive tools.
- GenerateGroup() - Constructor for class com.asakusafw.info.cli.generate.GenerateGroup
-
- generateImporter(EmitContext, FsProcessDescriptionGenerator.Description) - Static method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator
-
Generates the class in the context.
- generateImporter(EmitContext, JdbcProcessDescriptionGenerator.Description) - Static method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator
-
Generates the class in the context.
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Generates any resources (includes source programs) for the model.
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcSupportEmitter
-
- generateResources(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportEmitter
-
- GenerateTask - Class in com.asakusafw.dmdl.java
-
Generates Java model classes from input DMDL scripts.
- GenerateTask(Configuration) - Constructor for class com.asakusafw.dmdl.java.GenerateTask
-
Creates and returns a new instance.
- GenerateTask - Class in com.asakusafw.testdata.generator
-
Generates test templates from input DMDL scripts.
- GenerateTask(TemplateGenerator, DmdlSourceRepository, ClassLoader) - Constructor for class com.asakusafw.testdata.generator.GenerateTask
-
Creates a new instance.
- GENERATOR_ID - Static variable in class com.asakusafw.operator.Constants
-
The generator ID.
- GENERATOR_NAME - Static variable in class com.asakusafw.operator.Constants
-
The generator name.
- GENERATOR_VERSION - Static variable in class com.asakusafw.operator.Constants
-
The generator version.
- GeneratorInfoDriver - Class in com.asakusafw.dmdl.java.emitter.driver
-
Attaches a @DataModelKind
annotation.
- GeneratorInfoDriver() - Constructor for class com.asakusafw.dmdl.java.emitter.driver.GeneratorInfoDriver
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.BooleanOptionInspector
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.ByteOptionInspector
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.DoubleOptionInspector
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.FloatOptionInspector
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.IntOptionInspector
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.LongOptionInspector
-
- get(Object) - Method in class com.asakusafw.directio.hive.serde.ShortOptionInspector
-
- get(ModelDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelTrait
-
- get(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
- get(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the trait for the property.
- get(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the trait for the property.
- get() - Static method in class com.asakusafw.info.operator.MarkerOperatorSpec
-
Returns an instance.
- get() - Static method in class com.asakusafw.info.value.NullInfo
-
Returns the instance.
- get() - Method in interface com.asakusafw.iterative.common.BaseCursor
-
Returns the current element on this cursor.
- get(String) - Method in class com.asakusafw.iterative.common.basic.BasicParameterSet
-
- get() - Method in class com.asakusafw.iterative.common.basic.BasicParameterTable.BasicCursor
-
- get(String) - Method in interface com.asakusafw.iterative.common.ParameterSet
-
Returns the target parameter value.
- get() - Method in interface com.asakusafw.iterative.common.ParameterTable.Cursor
-
- get(OperatorDescription.Document) - Method in class com.asakusafw.operator.util.JavadocHelper
-
Returns the document elements for the description.
- get(Class<?>) - Static method in class com.asakusafw.operator.util.Logger
-
Returns a logger for the given context class.
- get() - Method in class com.asakusafw.runtime.core.api.ApiStub
-
Returns the current active implementation on this API stub.
- get(String) - Method in interface com.asakusafw.runtime.core.api.BatchContextApi
-
Returns a value of the context variable (which includes batch arguments).
- get(String) - Static method in class com.asakusafw.runtime.core.BatchContext
-
Returns a value of the context variable (which includes batch arguments).
- get() - Static method in class com.asakusafw.runtime.core.context.RuntimeContext
-
Returns the global context.
- get(String, String) - Method in class com.asakusafw.runtime.core.HadoopConfiguration
-
- get(String) - Static method in class com.asakusafw.runtime.core.legacy.LegacyBatchContext
-
Returns a value of the context variable (which includes batch arguments).
- get(String, String) - Method in interface com.asakusafw.runtime.core.ResourceConfiguration
-
Returns a configuration value for the specified key.
- get() - Method in class com.asakusafw.runtime.core.util.Shared
-
Returns the shared value.
- get() - Method in class com.asakusafw.runtime.directio.Counter
-
Returns current count.
- get(long, long) - Method in class com.asakusafw.runtime.directio.hadoop.BlockMap
-
- get(String) - Method in class com.asakusafw.runtime.directio.hadoop.DirectIoTransactionEditor
-
Returns the corresponded transaction information to the execution ID.
- get(int) - Method in class com.asakusafw.runtime.flow.ArrayListBuffer
-
- get(int) - Method in class com.asakusafw.runtime.flow.FileMapListBuffer
-
- get(LookUpKey) - Method in interface com.asakusafw.runtime.flow.join.LookUpTable
-
Returns a list of objects for the corresponding key.
- get(LookUpKey) - Method in class com.asakusafw.runtime.flow.join.VolatileLookUpTable
-
- get() - Method in class com.asakusafw.runtime.io.text.driver.BasicFieldOutput
-
- get() - Method in interface com.asakusafw.runtime.io.text.driver.FieldOutput
-
Returns the output contents.
- get(ByteOption) - Method in class com.asakusafw.runtime.io.text.value.ByteOptionFieldAdapter
-
- get(DecimalOption) - Method in class com.asakusafw.runtime.io.text.value.DecimalOptionFieldAdapter
-
- get(DoubleOption) - Method in class com.asakusafw.runtime.io.text.value.DoubleOptionFieldAdapter
-
- get(FloatOption) - Method in class com.asakusafw.runtime.io.text.value.FloatOptionFieldAdapter
-
- get(IntOption) - Method in class com.asakusafw.runtime.io.text.value.IntOptionFieldAdapter
-
- get(LongOption) - Method in class com.asakusafw.runtime.io.text.value.LongOptionFieldAdapter
-
- get(T) - Method in class com.asakusafw.runtime.io.text.value.NumericOptionFieldAdapter
-
Returns the property value.
- get(ShortOption) - Method in class com.asakusafw.runtime.io.text.value.ShortOptionFieldAdapter
-
- get(int) - Method in interface com.asakusafw.runtime.io.util.Tuple
-
Returns the element in this tuple.
- get(int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableTuple
-
- get() - Static method in enum com.asakusafw.runtime.util.hadoop.InstallationUtil.FrameworkVersion
-
Returns the currently linked framework version.
- get() - Method in class com.asakusafw.runtime.value.BooleanOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.ByteOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.DateOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.DateTimeOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.DecimalOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.DoubleOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.FloatOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.IntOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.LongOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.ShortOption
-
Returns the value which this object represents.
- get() - Method in class com.asakusafw.runtime.value.StringOption
-
Returns the value which this object represents.
- get(Object) - Method in class com.asakusafw.runtime.value.ValueOptionMap
-
- get(Class<T>) - Method in interface com.asakusafw.testdriver.core.DataModelAdapter
-
- get(Class<T>) - Method in class com.asakusafw.testdriver.core.SpiDataModelAdapter
-
- get(DataModelDefinition<T>, VerifyContext, URI) - Method in class com.asakusafw.testdriver.core.SpiVerifyRuleProvider
-
- get(DataModelDefinition<T>, VerifyContext, URI) - Method in interface com.asakusafw.testdriver.core.VerifyRuleProvider
-
Creates a
VerifyRule
object from the specified source.
- get(DataModelDefinition<T>, VerifyContext, URI) - Method in class com.asakusafw.testdriver.excel.ExcelSheetRuleProvider
-
- get(Class<T>) - Method in class com.asakusafw.testdriver.model.DefaultDataModelAdapter
-
- get(int) - Method in class com.asakusafw.utils.collections.SingleLinkedList
-
Returns the index
-th element in this list.
- get(String) - Method in class com.asakusafw.utils.gradle.Bundle
-
Returns a file on the bundle.
- get(String, TryConsumer<? super Path, IOException>) - Method in class com.asakusafw.utils.gradle.Bundle
-
Process a file on the bundle.
- get(Class<T>) - Method in class com.asakusafw.utils.gradle.GradleAdapter
-
Returns a Gradle model of the project.
- get(Class<T>, Consumer<? super T>) - Method in class com.asakusafw.utils.gradle.GradleAdapter
-
Returns a Gradle model of the project.
- get() - Method in class com.asakusafw.utils.io.csv.CsvReader
-
- get() - Method in class com.asakusafw.utils.io.DefaultSerialization.ObjectSource
-
- get() - Method in interface com.asakusafw.utils.io.Source
-
Returns an object on the current source position.
- get() - Method in interface com.asakusafw.windgate.core.resource.SourceDriver
-
- get() - Method in class com.asakusafw.windgate.core.util.SafeCloser
-
Returns the target object.
- get() - Method in class com.asakusafw.windgate.core.util.VoidSourceDriver
-
- get() - Method in class com.asakusafw.windgate.hadoopfs.temporary.ModelInputSourceDriver
-
- get() - Method in class com.asakusafw.windgate.jdbc.JdbcSourceDriver
-
- get() - Method in class com.asakusafw.windgate.stream.StreamSourceDriver
-
- get() - Method in class com.asakusafw.yaess.jobqueue.JobClientProvider
-
Returns a client.
- GET_RENDEZVOUS - Static variable in class com.asakusafw.runtime.flow.SegmentedCombiner
-
- GET_RENDEZVOUS - Static variable in class com.asakusafw.runtime.flow.SegmentedReducer
-
- getAccessMode(JobContext) - Static method in class com.asakusafw.runtime.stage.resource.StageResourceDriver
-
Returns the access mode for stage resources in the job.
- getActual() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Returns the actual status description.
- getActual() - Method in class com.asakusafw.testdriver.core.Difference
-
Returns the actual data.
- getAdapter() - Method in class com.asakusafw.runtime.io.json.PropertyDefinition
-
Returns a new adapter.
- getAdapter(Class<T>) - Method in class com.asakusafw.vocabulary.flow.builder.AttributeInfo
-
Returns the attribute as the target adapter type.
- getAdapterClass() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the adapter class.
- getAdapterClass() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the field adapter class.
- getAdapterSupplier() - Method in class com.asakusafw.runtime.io.json.PropertyDefinition
-
Returns the adapter supplier.
- getAdapterSupplier() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns a supplier of the field adapter.
- getAllDataSourceInfo() - Method in class com.asakusafw.operation.tools.directio.file.DataSourceParameter
-
Returns the all available Direct I/O data sources.
- getAllFlows() - Method in class com.asakusafw.yaess.core.BatchScript
-
- getAllNodes() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns input/output/arguments.
- getAllowLineFeedInField() - Method in class com.asakusafw.dmdl.directio.text.QuoteSettings
-
Returns whether or not LF can appear as field values.
- getAllReferences() - Method in interface com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceContainer
-
Returns the referred symbols.
- getAllReferences() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceList
-
- getAllReferences() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceMap
-
- getAllStructFieldRefs() - Method in class com.asakusafw.directio.hive.serde.DataModelInspector
-
- getAlternativeTypes() - Method in class com.asakusafw.utils.java.internal.model.syntax.UnionTypeImpl
-
- getAlternativeTypes() - Method in interface com.asakusafw.utils.java.model.syntax.UnionType
-
Returns the alternative types.
- getAnnotation() - Method in class com.asakusafw.info.operator.UserOperatorSpec
-
Returns the operator annotation.
- getAnnotation() - Method in class com.asakusafw.operator.model.KeyMirror.Group
-
Returns the declaring annotation.
- getAnnotation() - Method in class com.asakusafw.operator.model.KeyMirror.Order
-
Returns the declaring annotation.
- getAnnotation() - Method in class com.asakusafw.operator.model.OperatorElement
-
Returns the annotation of target operator/flow-part.
- getAnnotation() - Method in class com.asakusafw.operator.OperatorDriver.Context
-
Returns the target annotation.
- getAnnotation(Class<A>) - Method in interface com.asakusafw.testdriver.core.DataModelDefinition
-
Returns this element's annotation for the specified annotation type.
- getAnnotation(PropertyName, Class<A>) - Method in interface com.asakusafw.testdriver.core.DataModelDefinition
-
Returns the property's annotation for the specified annotation type.
- getAnnotation(Class<A>) - Method in class com.asakusafw.testdriver.model.DefaultDataModelDefinition
-
- getAnnotation(PropertyName, Class<A>) - Method in class com.asakusafw.testdriver.model.DefaultDataModelDefinition
-
- getAnnotation(Class<A>) - Method in class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
- getAnnotation(PropertyName, Class<A>) - Method in class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
- getAnnotations() - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
- getAnnotations() - Method in interface com.asakusafw.utils.java.model.syntax.PackageDeclaration
-
Returns a the annotations.
- getAnnotationType() - Method in enum com.asakusafw.info.operator.CoreOperatorSpec.CoreOperatorKind
-
Returns the (pseudo) annotation type for this.
- getAnnotationType() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Declaration
-
Returns the operator annotation type.
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.BranchOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.CoGroupOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.ConvertOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.ExtractOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.FoldOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.GroupSortOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.LoggingOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.MasterBranchOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.MasterCheckOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.MasterJoinOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.MasterJoinUpdateOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.SplitOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.SummarizeOperatorDriver
-
- getAnnotationTypeName() - Method in class com.asakusafw.operator.builtin.UpdateOperatorDriver
-
- getAnnotationTypeName() - Method in interface com.asakusafw.operator.OperatorDriver
-
Returns the target annotation type name.
- getAppJobflowLibFile(Path, String) - Static method in class com.asakusafw.windgate.bootstrap.CoreConstants
-
Returns the jobflow package file.
- getApplication(Environment, String) - Static method in class com.asakusafw.windgate.bootstrap.CoreConstants
-
Returns the application base directory.
- getApplicationArgumentArray() - Method in class com.asakusafw.runtime.stage.launcher.LauncherOptions
-
Returns the application arguments.
- getApplicationArguments() - Method in class com.asakusafw.runtime.stage.launcher.LauncherOptions
-
Returns the application arguments.
- getApplicationCacheDirectories() - Method in class com.asakusafw.runtime.stage.launcher.LauncherOptions
-
Returns the application cache directory.
- getApplicationClass() - Method in class com.asakusafw.runtime.stage.launcher.LauncherOptions
-
Returns the application class.
- getApplicationClassLoader() - Method in class com.asakusafw.runtime.stage.launcher.LauncherOptions
-
Returns the application class loader.
- getArguments() - Method in class com.asakusafw.operator.description.ObjectDescription
-
Returns the arguments.
- getArguments() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns the input arguments.
- getArguments() - Method in class com.asakusafw.testdriver.core.TestContext.Empty
-
- getArguments() - Method in interface com.asakusafw.testdriver.core.TestContext
-
Returns the user arguments.
- getArguments() - Method in class com.asakusafw.testdriver.TestDriverContext
-
- getArguments() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
Returns the arguments.
- getArguments() - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
- getArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.AlternateConstructorInvocationImpl
-
- getArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- getArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
- getArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
- getArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
- getArguments() - Method in interface com.asakusafw.utils.java.model.syntax.ClassInstanceCreationExpression
-
Returns the actual arguments.
- getArguments() - Method in interface com.asakusafw.utils.java.model.syntax.ConstructorInvocation
-
Returns the actual arguments.
- getArguments() - Method in interface com.asakusafw.utils.java.model.syntax.EnumConstantDeclaration
-
Returns the constructor arguments.
- getArguments() - Method in interface com.asakusafw.utils.java.model.syntax.MethodInvocationExpression
-
Returns the actual arguments.
- getArguments() - Method in class com.asakusafw.workflow.model.basic.BasicCommandTaskInfo
-
- getArguments(Map<String, String>) - Method in class com.asakusafw.workflow.model.basic.BasicCommandTaskInfo
-
- getArguments() - Method in interface com.asakusafw.workflow.model.CommandTaskInfo
-
Returns the raw command arguments.
- getArguments(Map<String, String>) - Method in interface com.asakusafw.workflow.model.CommandTaskInfo
-
Returns the command arguments.
- getArguments() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current argument pairs.
- getArguments() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the batch arguments map for the target job.
- getArgumentsAsString() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current argument pairs as string format.
- getArray() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayAccessExpressionImpl
-
- getArray() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayAccessExpression
-
Returns the array expression.
- getArrayInitializer() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
- getArrayInitializer() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayCreationExpression
-
Returns the array initializer.
- getArrayType() - Method in class com.asakusafw.info.value.ClassInfo
-
Returns the array type of this.
- getAssignmentSymbol() - Method in enum com.asakusafw.utils.java.model.syntax.InfixOperator
-
Returns the assignment operator symbol.
- getAsString() - Method in class com.asakusafw.runtime.value.StringOption
-
Returns the value which this object represents.
- getAttemptId() - Method in class com.asakusafw.runtime.directio.OutputAttemptContext
-
Returns the attempt ID corresponding to this output.
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
- getAttribute(Class<T>) - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementAttributeProvider
-
Returns the attribute of this.
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPort
-
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPortDescription
-
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getAttribute(Class<T>) - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getAttributeOverride() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
Returns the overwritten attributes.
- getAttributes() - Method in interface com.asakusafw.dmdl.semantics.Declaration
-
Returns the attached attributes of this element.
- getAttributes() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
- getAttributes() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
- getAttributes() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
- getAttributes() - Method in class com.asakusafw.info.BatchInfo
-
- getAttributes() - Method in interface com.asakusafw.info.ElementInfo
-
Returns the attributes of this element.
- getAttributes() - Method in interface com.asakusafw.info.graph.Element
-
Returns the attributes of this element.
- getAttributes() - Method in class com.asakusafw.info.JobflowInfo
-
- getAttributes() - Method in interface com.asakusafw.operator.model.AttributeContainer
-
Returns the attributes.
- getAttributes() - Method in class com.asakusafw.operator.model.OperatorDescription
-
- getAttributes() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
- getAttributes() - Method in class com.asakusafw.runtime.directio.DirectDataSourceProfile
-
Returns the attributes of the target data source.
- getAttributes() - Method in class com.asakusafw.runtime.directio.DirectInputFragment
-
Returns the extra attributes.
- getAttributes() - Method in class com.asakusafw.runtime.stage.StageInput
-
Returns the input attributes.
- getAttributes() - Method in class com.asakusafw.runtime.stage.StageOutput
-
Returns the output attributes.
- getAttributes() - Method in class com.asakusafw.trace.model.TraceSetting
-
Returns the extra-attributes.
- getAttributes() - Method in class com.asakusafw.vocabulary.flow.builder.PortInfo
-
Returns the attributes.
- getAttributes() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
Returns the attributes of the operator.
- getAttributes(Class<A>) - Method in class com.asakusafw.workflow.model.basic.AbstractElement
-
- getAttributes(Class<A>) - Method in interface com.asakusafw.workflow.model.Element
-
Returns attributes of this task.
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
- getAttributeTypes() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementAttributeProvider
-
Returns the all available attribute types of this.
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPort
-
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPortDescription
-
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getAttributeTypes() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getAvailable() - Method in class com.asakusafw.iterative.common.basic.BasicParameterSet
-
- getAvailable() - Method in class com.asakusafw.iterative.common.basic.BasicParameterTable
-
- getAvailable() - Method in interface com.asakusafw.iterative.common.ParameterSet
-
Returns the all available parameter names in this set.
- getAvailable() - Method in interface com.asakusafw.iterative.common.ParameterTable
-
Returns the all available parameter names in this set.
- getAvailableApplications(ExecutionContext) - Static method in class com.asakusafw.workflow.cli.common.WorkflowParameter
-
Returns a list of available batch application names on the current context.
- getBarePath() - Method in class com.asakusafw.operation.tools.directio.DirectIoPath
-
Returns the bare path.
- getBasePackage() - Method in class com.asakusafw.dmdl.java.Configuration
-
Returns the Java base package.
- getBasePath() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns base path.
- getBasePath() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns base path.
- getBasePath() - Method in class com.asakusafw.info.directio.DirectFilePortInfo
-
Returns the base path.
- getBasePath() - Method in class com.asakusafw.info.hive.LocationInfo
-
Returns the base path.
- getBasePath() - Method in class com.asakusafw.operation.tools.directio.DirectIoPath
-
Returns the base path including the container data source path.
- getBasePath() - Method in class com.asakusafw.vocabulary.directio.DirectFileInputDescription
-
Returns the base path of target input.
- getBasePath() - Method in class com.asakusafw.vocabulary.directio.DirectFileOutputDescription
-
Returns the base path of target output.
- getBasePath() - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsProfile
-
Returns the target base path.
- getBasePath() - Method in class com.asakusafw.windgate.stream.file.FileProfile
-
Returns the base path of target storage.
- getBaseUri() - Method in class com.asakusafw.yaess.jobqueue.client.HttpJobClient
-
Returns the base URI.
- getBasicTypeKind() - Method in class com.asakusafw.operator.description.BasicTypeDescription
-
Returns the basic type kind.
- getBatch() - Method in interface com.asakusafw.testdriver.compiler.ArtifactMirror
-
Returns the batch application mirror.
- getBatch() - Method in class com.asakusafw.testdriver.compiler.basic.BasicArtifactMirror
-
- getBatchApplicationsInstallationPath() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the path to the batch applications installation location.
- getBatchappsHome(Environment) - Static method in class com.asakusafw.windgate.bootstrap.CoreConstants
-
Returns the batch application installation directory.
- getBatchArgs() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the batch arguments.
- getBatchArguments() - Method in class com.asakusafw.runtime.directio.DataFilter.Context
-
Returns the batch arguments.
- getBatchArguments() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getBatchArguments() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the serialized batch arguments.
- getBatchArguments() - Method in class com.asakusafw.workflow.cli.run.ApplicationParameter
-
Returns the batch arguments.
- getBatchArguments() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getBatchArguments() - Method in interface com.asakusafw.workflow.executor.TaskExecutionContext
-
Returns the batch arguments.
- getBatchExecutor(ExecutionContext) - Method in class com.asakusafw.workflow.cli.run.ExecutorParameter
-
Returns the batch executor.
- getBatchGetUnit() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Return the number of rows on each fetch (fetch-size
).
- getBatchId() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the batch ID.
- getBatchId() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getBatchId() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the batch ID.
- getBatchId() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getBatchId() - Method in interface com.asakusafw.workflow.executor.TaskExecutionContext
-
Returns the container batch information.
- getBatchId() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current batch ID.
- getBatchId() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the batch ID for target job.
- getBatchInfo(ExecutionContext) - Method in class com.asakusafw.workflow.cli.common.WorkflowParameter
-
Returns workflow information.
- getBatchPutUnit() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Return the number of rows on each batch insertion.
- getBinaryContent() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassFile
-
Returns the contents of this class file.
- getBinaryName() - Method in class com.asakusafw.info.value.ClassInfo
-
Returns the binary name.
- getBinaryName() - Method in class com.asakusafw.operator.description.ClassDescription
-
Returns the binary name.
- getBinaryName() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassFile
-
Returns the binary name of this class file.
- getBlockerIds() - Method in class com.asakusafw.info.JobflowInfo
-
Returns the blocker flow IDs.
- getBlockerIds() - Method in class com.asakusafw.yaess.core.CommandScript
-
- getBlockerIds() - Method in interface com.asakusafw.yaess.core.ExecutionScript
-
Returns the IDs representing blockers of this script execution.
- getBlockerIds() - Method in class com.asakusafw.yaess.core.FlowScript
-
Returns the ID of this flow execution.
- getBlockerIds() - Method in class com.asakusafw.yaess.core.HadoopScript
-
- getBlockerIds() - Method in class com.asakusafw.yaess.core.Job
-
Returns job IDs which blocks executing this job.
- getBlockerIds() - Method in class com.asakusafw.yaess.core.task.HandlerLifecycleJob
-
- getBlockerIds() - Method in class com.asakusafw.yaess.core.task.ScriptJob
-
- getBlockers() - Method in class com.asakusafw.info.task.TaskInfo
-
Returns the blocker task IDs.
- getBlockers() - Method in class com.asakusafw.workflow.model.basic.AbstractGraphElement
-
- getBlockers() - Method in interface com.asakusafw.workflow.model.GraphElement
-
Returns the blocker elements.
- getBlockParsers() - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocBaseParser
-
Returns the block parsers.
- getBlocks() - Method in class com.asakusafw.runtime.directio.hadoop.BlockMap
-
Returns the file blocks in this map.
- getBlocks() - Method in class com.asakusafw.utils.java.internal.model.syntax.JavadocImpl
-
- getBlocks() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocComment
-
Returns the element blocks.
- getBlocks() - Method in interface com.asakusafw.utils.java.model.syntax.Javadoc
-
Returns the documentation blocks.
- getBlockScanner() - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockInfo
-
Returns the scanner which provides the block contents.
- getBlockSize() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the block size (in bytes).
- getBlockSize() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Returns the block size (in bytes).
- getBlockSize() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Returns the block size (in bytes).
- getBlockSize() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter.Options
-
Returns in-memory block buffer size.
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.CatchClauseImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.DoStatementImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.LabeledStatementImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.LambdaExpressionImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.SynchronizedStatementImpl
-
- getBody() - Method in class com.asakusafw.utils.java.internal.model.syntax.WhileStatementImpl
-
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.CatchClause
-
Returns the catch
block body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.ClassInstanceCreationExpression
-
Returns the anonymous class body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.ConstructorDeclaration
-
Returns the constructor body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.DoStatement
-
Returns the loop body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.EnhancedForStatement
-
Returns the loop body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.EnumConstantDeclaration
-
Returns the class body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.ForStatement
-
Returns the loop body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.InitializerDeclaration
-
Returns the initializer body block.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.LabeledStatement
-
Returns the body statement.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.LambdaExpression
-
Returns the lambda body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorDeclaration
-
Returns the method or constructor body.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.SynchronizedStatement
-
Returns the body block.
- getBody() - Method in interface com.asakusafw.utils.java.model.syntax.WhileStatement
-
Returns the loop body.
- getBodyDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
- getBodyDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassBodyImpl
-
- getBodyDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getBodyDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getBodyDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getBodyDeclarations() - Method in interface com.asakusafw.utils.java.model.syntax.ClassBody
-
Returns class members.
- getBodyDeclarations() - Method in interface com.asakusafw.utils.java.model.syntax.TypeDeclaration
-
Returns type member declarations.
- getBoundKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.WildcardImpl
-
- getBoundKind() - Method in interface com.asakusafw.utils.java.model.syntax.Wildcard
-
Returns the type bound kind.
- getBufferSize() - Method in class com.asakusafw.runtime.io.line.LineConfiguration
-
Returns the buffer size (hint) in bytes.
- getBuildId() - Method in class com.asakusafw.yaess.core.BatchScript
-
Returns the build ID of this batch.
- getBuiltinOperatorClass(String) - Static method in class com.asakusafw.operator.Constants
-
Returns the implementation class name of target class with the specified name.
- getBundle(Path) - Method in class com.asakusafw.utils.gradle.BaseProject
-
Returns a project related bundle.
- getBytes() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Returns the byte array in this slice.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.BooleanOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.ByteOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.DateOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.DateTimeOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.DecimalOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.DoubleOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.FloatOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.IntOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.LongOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.ShortOption
-
Returns the actual number of bytes from the serialized byte array.
- getBytesLength(byte[], int, int) - Static method in class com.asakusafw.runtime.value.StringOption
-
Returns the actual number of bytes from the serialized byte array.
- getCacheName() - Method in class com.asakusafw.runtime.flow.join.JoinResource
-
Returns the name of Hadoop distributed cache which provides contents of the lookup table.
- getCallerClass() - Method in class com.asakusafw.testdriver.DriverElementBase
-
Returns the caller class.
- getCallerClass() - Method in class com.asakusafw.testdriver.DriverInputBase
-
- getCallerClass() - Method in class com.asakusafw.testdriver.DriverToolBase
-
- getCallerClass() - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
- getCallerClass() - Method in class com.asakusafw.testdriver.TestDriverBase
-
- getCallerClass() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the caller class.
- getCallerClass() - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
- getCatchClauses() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
- getCatchClauses() - Method in interface com.asakusafw.utils.java.model.syntax.TryStatement
-
Returns the catch
clauses.
- getCategory() - Method in class com.asakusafw.directio.hive.serde.DataModelInspector
-
- getCategory() - Method in enum com.asakusafw.info.hive.FieldType.TypeName
-
Returns the type category.
- getCategory() - Method in enum com.asakusafw.info.hive.StorageFormatInfo.FormatKind
-
Returns the category.
- getCategory() - Method in class com.asakusafw.info.operator.CoreOperatorSpec
-
Returns the core operator kind.
- getCategory() - Method in class com.asakusafw.info.operator.CustomOperatorSpec
-
Returns the operator category.
- getCategory() - Method in enum com.asakusafw.utils.java.model.syntax.InfixOperator
-
Returns the operator category.
- getCategory() - Method in enum com.asakusafw.utils.java.model.syntax.UnaryOperator
-
Returns the operator category.
- getChar(int) - Static method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
- getCharacter() - Method in class com.asakusafw.dmdl.directio.text.EscapeSettings
-
Returns the escape character.
- getCharacter() - Method in class com.asakusafw.dmdl.directio.text.QuoteSettings
-
Returns quote character.
- getCharContent(boolean) - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileJavaFile
-
- getCharContent(boolean) - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileResourceFile
-
- getCharset() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the charset name.
- getCharset() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Returns the character set encoding name.
- getCharset() - Method in class com.asakusafw.runtime.io.line.LineConfiguration
-
Returns the text charset.
- getCharsetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Returns the charset name.
- getCharsetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Returns the charset name.
- getCharsetName() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait.Configuration
-
Returns the charset name.
- getCharsetName() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
Returns the charset name.
- getCharsetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Returns the charset name.
- getChildKeys(Map<?, ?>, String, String) - Static method in class com.asakusafw.yaess.core.util.PropertiesUtil
-
Collect the child keys
from the properties.
- getClasses() - Method in class com.asakusafw.directio.hive.tools.cli.ClassCollector
-
Returns the collected classes.
- getClassLoader() - Method in class com.asakusafw.runtime.core.HadoopConfiguration
-
- getClassLoader() - Method in interface com.asakusafw.runtime.core.ResourceConfiguration
-
Returns a class loader for this configuration.
- getClassLoader() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getClassLoader() - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns the class loader.
- getClassLoader() - Method in class com.asakusafw.testdriver.core.TestContext.Empty
-
- getClassLoader() - Method in interface com.asakusafw.testdriver.core.TestContext
-
Returns the class loader to load testing peripherals.
- getClassLoader() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getClassLoader() - Method in class com.asakusafw.testdriver.TestDriverContext
-
- getClassLoader() - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
- getClassLoader() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileCompiler
-
Returns the class loader which provides compiled classes by the compiler.
- getClassLoader() - Method in class com.asakusafw.windgate.bootstrap.Classpath.Session
-
Returns the class loader of this session.
- getClassLoader() - Method in class com.asakusafw.windgate.core.BaseProfile
-
- getClassLoader() - Method in class com.asakusafw.windgate.core.ProfileContext
-
Returns a class loader to load services.
- getClassLoader() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Returns the class loader for the resources.
- getClassLoader() - Method in class com.asakusafw.windgate.stream.file.FileProfile
-
Returns the current class loader.
- getClassLoader() - Method in class com.asakusafw.workflow.executor.basic.BasicExecutionContext
-
- getClassLoader() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getClassLoader() - Method in interface com.asakusafw.workflow.executor.ExecutionContext
-
Returns the class loader to load testing peripherals.
- getClassLoader() - Method in class com.asakusafw.yaess.core.ProfileContext
-
Returns a class loader to load services.
- getClassLoader() - Method in class com.asakusafw.yaess.core.ServiceProfile
-
- getClassName(EmitContext, ModelDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelEmitter
-
Returns the generated class name for this.
- getClassName(EmitContext, ModelDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileEmitter
-
Returns the generated class name for this.
- getClassName(EmitContext, ModelDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileEmitter
-
Returns the generated class name for this.
- getClassName() - Method in class com.asakusafw.info.value.ClassInfo
-
Returns the fully qualified class name.
- getClassName() - Method in class com.asakusafw.operator.description.ClassDescription
-
Returns the fully qualified class name.
- getClassName() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Job
-
Deprecated.
Returns the fully qualified name of the job client class.
- getClassName() - Method in class com.asakusafw.workflow.model.basic.BasicHadoopTaskInfo
-
- getClassName() - Method in interface com.asakusafw.workflow.model.HadoopTaskInfo
-
Returns the entry class name.
- getClassName() - Method in class com.asakusafw.yaess.core.HadoopScript
-
Returns the target class name.
- getClassNameKey() - Method in class com.asakusafw.runtime.core.legacy.LegacyReport.Initializer
-
- getClassNameKey() - Method in class com.asakusafw.runtime.core.legacy.RuntimeResource.DelegateRegisterer
-
Returns the configuration key of the delegation object class name.
- getClasspathEntries() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getClasspathEntries() - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns the additional classpath entries.
- getCleanupPath() - Method in class com.asakusafw.runtime.stage.AbstractCleanupStageClient
-
Returns the cleanup target path.
- getClients() - Method in class com.asakusafw.yaess.jobqueue.JobClientProfile
-
Returns the job clients.
- getClusterWorkDir() - Method in class com.asakusafw.testdriver.TestDriverContext
-
- getCodecName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Returns the codec name.
- getCodecName() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait.Configuration
-
Returns the codec name.
- getCodecName() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
Returns the codec name.
- getCol() - Method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem
-
Returns the column number.
- getCollectionItemSeparator() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
Returns the collection items terminator character.
- getColumnIndex() - Method in enum com.asakusafw.testdriver.excel.RuleSheetFormat
-
Returns the column index where this kind assigned in a sheet.
- getColumnMap() - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelJdbcSupport
-
Returns the column names into property names mapping.
- getColumnName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the explicit column name.
- getColumnName(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the explicit/inferred column name.
- getColumnNames() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns the column names.
- getColumnNames() - Method in class com.asakusafw.vocabulary.windgate.JdbcExporterDescription
-
Returns the target column names.
- getColumnNames() - Method in class com.asakusafw.vocabulary.windgate.JdbcImporterDescription
-
Returns the target column names.
- getColumnNames() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
Returns the target column names.
- getColumnNumber() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Returns the current column number (1-origin).
- getColumns() - Method in class com.asakusafw.info.hive.TableInfo
-
Returns the columns.
- getCombinerClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the combiner class.
- getCommand() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
Returns the command.
- getCommand() - Method in class com.asakusafw.vocabulary.batch.ScriptWorkDescription
-
Deprecated.
Returns the command line.
- getCommand() - Method in class com.asakusafw.workflow.model.basic.BasicCommandTaskInfo
-
- getCommand() - Method in interface com.asakusafw.workflow.model.CommandTaskInfo
-
Returns the command location.
- getCommandExecutor() - Method in class com.asakusafw.yaess.basic.BasicCommandScriptHandler
-
- getCommandExecutor() - Method in class com.asakusafw.yaess.basic.BasicHadoopScriptHandler
-
- getCommandExecutor() - Method in class com.asakusafw.yaess.basic.ProcessCommandScriptHandler
-
Returns command executor for this handler (extension point).
- getCommandExecutor() - Method in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
Returns command executor for this handler (extension point).
- getCommandExecutor() - Method in class com.asakusafw.yaess.jsch.SshCommandScriptHandler
-
- getCommandExecutor() - Method in class com.asakusafw.yaess.jsch.SshHadoopScriptHandler
-
- getCommandHandlers() - Method in class com.asakusafw.yaess.core.YaessProfile
-
Returns command script handlers for each target profile name.
- getCommandLauncher() - Method in class com.asakusafw.utils.gradle.BaseProject
-
- getCommandLauncher() - Method in interface com.asakusafw.utils.gradle.ProjectContext
-
Returns a command launcher of this context.
- getCommandLauncher(ExecutionContext) - Static method in class com.asakusafw.workflow.executor.basic.BasicCommandTaskExecutor
-
- getCommandLauncher(ExecutionContext, BasicCommandLauncher.OutputConsumer) - Static method in class com.asakusafw.workflow.executor.basic.BasicCommandTaskExecutor
-
- getCommandLineTokens() - Method in class com.asakusafw.yaess.core.CommandScript
-
Returns a sequence of command line tokens.
- getComment() - Method in class com.asakusafw.info.BatchInfo
-
Returns the comment.
- getComment() - Method in class com.asakusafw.info.hive.ColumnInfo
-
Returns the column comment.
- getComment() - Method in class com.asakusafw.info.hive.TableInfo
-
Returns the table comment.
- getComment() - Method in class com.asakusafw.info.ParameterInfo
-
Returns the comment.
- getComment() - Method in class com.asakusafw.runtime.directio.hadoop.DirectIoTransactionEditor.TransactionInfo
-
Returns the comment for this commit.
- getComment() - Method in class com.asakusafw.workflow.model.attribute.ParameterInfo
-
Returns the comment.
- getComments() - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
- getComments() - Method in interface com.asakusafw.utils.java.model.syntax.CompilationUnit
-
Returns the comments.
- getCommitMarkPath(Configuration, String) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Returns the commit mark path.
- getCommonTypeInfo() - Static method in enum com.asakusafw.directio.hive.serde.StringValueSerdeFactory
-
Returns the common type information which each this enum member returns.
- getCommonTypeInfo() - Static method in enum com.asakusafw.directio.hive.serde.TimestampValueSerdeFactory
-
Returns the common type information which each this enum member returns.
- getCompiled() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
Returns the generated Java class files.
- getCompiled() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileCompiler
-
Returns the class files which are generated by this compiler.
- getCompilerDebugLevel() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the compiler debug level.
- getCompilerOptimizeLevel() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the compiler optimization level.
- getCompilerOptions() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the compiler specific options.
- getCompilerWorkingDirectory() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the compiler working directory.
- getCompileWorkBaseDir() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the path to the compiler working directory.
- getCompletions(Element, AnnotationMirror, ExecutableElement, String) - Method in class com.asakusafw.operator.AbstractOperatorAnnotationProcessor
-
- getCompletions(Element, AnnotationMirror, ExecutableElement, String) - Method in class com.asakusafw.operator.method.OperatorAnnotationProcessor
-
- getCompletions(OperatorDriver.Context, ExecutableElement, String) - Method in interface com.asakusafw.operator.OperatorDriver
-
Returns a list of proposals about target annotation element.
- getCompletions(Element, AnnotationMirror, ExecutableElement, String) - Method in class com.asakusafw.utils.java.jsr199.testing.SafeProcessor
-
- getComponent() - Method in class com.asakusafw.windgate.retryable.RetryableProcessProfile
-
Returns the target process provider.
- getComponentPath() - Method in class com.asakusafw.operation.tools.directio.DirectIoPath
-
Returns the component base path.
- getComponentPath(String) - Method in class com.asakusafw.runtime.directio.DirectDataSourceRepository
-
Returns the component path of the target path.
- getComponentType() - Method in class com.asakusafw.operator.description.ArrayTypeDescription
-
Returns the component type.
- getComponentType() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayTypeImpl
-
- getComponentType() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocArrayType
-
Returns the element type.
- getComponentType() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayType
-
Returns the element type.
- getCompressionCodec(Path) - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
Returns a compression codec for output sequence files.
- getCompressionCodec() - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsProfile
-
- getCompressionCodec() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
- getCompressionCodecClass() - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
Returns the compression codec class.
- getCompressionCodecClass() - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
Returns the compression codec class.
- getCompressionCodecClass() - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
Returns the compression codec class.
- getCompressionCodecClass() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
Returns the compression codec class.
- getCompressionCodecName() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the compression codec name.
- getCompressionCodecName(Class<T>) - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the compression codec name.
- getCompressionCodecName() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Returns the compression codec name.
- getCompressionCodecName() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Returns the compression codec name.
- getCompressionCodecNameClass() - Method in class com.asakusafw.directio.hive.parquet.Compatibility
-
returns the compression kind class.
- getCompressionCodecNameClass() - Method in class com.asakusafw.directio.hive.parquet.v1.CompatibilityV1
-
- getCompressionCodecNameClass() - Method in class com.asakusafw.directio.hive.parquet.v2.CompatibilityV2
-
- getCompressionKind() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the ORCFile compression kind.
- getCompressionKind(Class<T>) - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the ORCFile compression kind.
- getCompressionKindClass() - Method in class com.asakusafw.directio.hive.orc.Compatibility
-
returns the compression kind class.
- getCompressionKindClass() - Method in class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
- getCompressionKindClass() - Method in class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
- getCompressionType() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonStreamSettings
-
Returns the compression type.
- getCompressionType() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the compression type.
- getCondition() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns condition.
- getCondition() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
- getCondition() - Method in class com.asakusafw.utils.java.internal.model.syntax.DoStatementImpl
-
- getCondition() - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
- getCondition() - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
- getCondition() - Method in class com.asakusafw.utils.java.internal.model.syntax.WhileStatementImpl
-
- getCondition() - Method in interface com.asakusafw.utils.java.model.syntax.ConditionalExpression
-
Returns the condition term.
- getCondition() - Method in interface com.asakusafw.utils.java.model.syntax.DoStatement
-
Returns the condition expression.
- getCondition() - Method in interface com.asakusafw.utils.java.model.syntax.ForStatement
-
Returns the loop condition expression.
- getCondition() - Method in interface com.asakusafw.utils.java.model.syntax.IfStatement
-
Returns the condition expression.
- getCondition() - Method in interface com.asakusafw.utils.java.model.syntax.WhileStatement
-
Returns the condition expression.
- getCondition() - Method in class com.asakusafw.vocabulary.windgate.JdbcImporterDescription
-
Returns the conditional expression in SQL.
- getCondition() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
Returns the SQL condition expression.
- getConditonByJapanseName(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.ColumnMatchingCondition
-
- getConditonByJapanseName(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.NullValueCondition
-
- getConditonByJapanseName(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.RowMatchingCondition
-
- getConf() - Method in class com.asakusafw.runtime.directio.hadoop.ConfigurableBinaryStreamFormat
-
- getConf() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- getConf() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.BridgeInputSplit
-
- getConf() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullInputSplit
-
- getConf() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
- getConfiguration() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait
-
Returns CSV configuration.
- getConfiguration() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait
-
Returns line configuration.
- getConfiguration() - Method in class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatTrait
-
Returns SequenceFile format configuration.
- getConfiguration() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait
-
Returns TSV configuration.
- getConfiguration() - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the current configuration.
- getConfiguration() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait
-
Returns CSV configuration.
- getConfiguration() - Method in class com.asakusafw.info.windgate.WindGatePortInfo
-
Returns the driver configuration.
- getConfiguration() - Method in class com.asakusafw.operation.tools.directio.common.ConfigurationParameter
-
Returns the configuration.
- getConfiguration() - Method in class com.asakusafw.operation.tools.directio.file.DataSourceParameter
-
Returns the Hadoop configuration.
- getConfiguration() - Method in class com.asakusafw.operation.tools.directio.transaction.TransactionEditorParameter
-
Returns the Hadoop configuration.
- getConfiguration(boolean) - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
Returns the CSV format configuration.
- getConfiguration() - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
Returns the line based text format configuration.
- getConfiguration() - Method in class com.asakusafw.runtime.stage.launcher.LauncherOptions
-
Returns the Hadoop configuration.
- getConfiguration() - Method in class com.asakusafw.runtime.stage.resource.StageResourceDriver
-
Returns the current configuration.
- getConfiguration() - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
Returns the Configuration object for the current environment.
- getConfiguration() - Method in class com.asakusafw.windgate.core.DriverScript
-
Returns the configuration for this driver.
- getConfiguration() - Method in class com.asakusafw.windgate.core.process.ProcessProfile
-
Returns the extra configuration of this process.
- getConfiguration() - Method in class com.asakusafw.windgate.core.resource.ResourceProfile
-
Returns the extra configuration of this resource.
- getConfiguration() - Method in class com.asakusafw.windgate.core.session.SessionProfile
-
Returns the extra configuration of the session.
- getConfiguration(ProfileContext) - Static method in class com.asakusafw.windgate.hadoopfs.HadoopFsProvider
-
Returns the Hadoop configuration for the current context.
- getConfiguration() - Method in class com.asakusafw.yaess.core.ServiceProfile
-
Return the optional configuration for the service.
- getConfiguration(String, boolean, boolean) - Method in class com.asakusafw.yaess.core.ServiceProfile
-
Returns the target configuration.
- getConfigurationPath(Map<String, String>) - Static method in class com.asakusafw.runtime.util.hadoop.ConfigurationProvider
-
Computes the default Hadoop configuration path.
- getConfigurationPath() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Returns the Hadoop configuration path.
- getConfigurations() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getConfigurations() - Method in class com.asakusafw.workflow.executor.basic.BasicExecutionContext
-
- getConfigurations() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getConfigurations() - Method in interface com.asakusafw.workflow.executor.ExecutionContext
-
Returns the platform configurations.
- getConnected(Object) - Method in interface com.asakusafw.utils.graph.Graph
-
Returns the vertices which are direct successors of the specified vertex.
- getConnected() - Method in interface com.asakusafw.utils.graph.Graph.Vertex
-
Returns the succeeding vertices from this vertex.
- getConnected(Object) - Method in class com.asakusafw.utils.graph.HashGraph
-
- getConnected() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPort
-
Returns the set of connections into this port.
- getConnectionProperties() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Return extra configuration properties.
- getConnectRetryCount() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Returns the retry count on create connection.
- getConnectRetryInterval() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Returns the retry interval (in second).
- getConstantDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getConstantDeclarations() - Method in interface com.asakusafw.utils.java.model.syntax.EnumDeclaration
-
Returns the enum constant declarations.
- getConstructor() - Method in class com.asakusafw.vocabulary.flow.builder.FlowNodeBuilder
-
Returns the target constructor.
- getContainerPath() - Method in class com.asakusafw.operation.tools.directio.DirectIoPath
-
Returns the container path.
- getContainerPath(String) - Method in class com.asakusafw.runtime.directio.DirectDataSourceRepository
-
Returns the container path of the target path.
- getContainerPaths() - Method in class com.asakusafw.runtime.directio.DirectDataSourceRepository
-
- getContainerType(PropertyReferenceDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the collection type of target reference.
- getContent() - Method in class com.asakusafw.runtime.io.text.csv.CsvFieldReader
-
- getContent() - Method in interface com.asakusafw.runtime.io.text.FieldReader
-
Returns the content of the current field.
- getContent() - Method in class com.asakusafw.runtime.io.text.tabular.TabularFieldReader
-
- getContent() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocText
-
Returns the contents.
- getContents() - Method in class com.asakusafw.runtime.directio.FilePattern.Selection
-
Returns contents in this selection.
- getContents() - Method in interface com.asakusafw.testdriver.compiler.ArtifactMirror
-
Returns the compiled contents.
- getContents() - Method in class com.asakusafw.testdriver.compiler.basic.BasicArtifactMirror
-
- getContents() - Method in class com.asakusafw.utils.gradle.BaseProject
-
Returns the project bundle.
- getContents() - Method in class com.asakusafw.utils.java.model.util.CommentEmitTrait
-
Returns the comment lines.
- getContext() - Method in class com.asakusafw.windgate.core.BaseProfile
-
Returns the current profile context.
- getContext() - Method in class com.asakusafw.windgate.core.process.ProcessProfile
-
- getContext() - Method in class com.asakusafw.windgate.core.resource.ResourceProfile
-
- getContext() - Method in class com.asakusafw.windgate.core.session.SessionProfile
-
- getContext() - Method in class com.asakusafw.yaess.core.ServiceProfile
-
Returns the current profile context.
- getContextId() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the context ID.
- getContextParameters() - Method in class com.asakusafw.windgate.core.ProfileContext
-
Returns context parameters (may be environment variables).
- getContextParameters() - Method in class com.asakusafw.yaess.core.ProfileContext
-
Returns context parameters (may be environment variables).
- getContextPath() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the logical context path.
- getConverter(int) - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelConverter
-
- getConverter() - Method in class com.asakusafw.directio.hive.parquet.v1.DecimalValueDriver
-
- getConverter() - Method in class com.asakusafw.directio.hive.parquet.v1.LimitedStringValueDriver
-
- getConverter() - Method in interface com.asakusafw.directio.hive.parquet.v1.ParquetValueDriver
-
- getConverter(int) - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelConverter
-
- getConverter() - Method in class com.asakusafw.directio.hive.parquet.v2.DecimalValueDriver
-
- getConverter() - Method in class com.asakusafw.directio.hive.parquet.v2.LimitedStringValueDriver
-
- getConverter() - Method in interface com.asakusafw.directio.hive.parquet.v2.ParquetValueDriver
-
- getCore() - Method in class com.asakusafw.windgate.core.GateProfile
-
Returns the core segment of this profile.
- getCore() - Method in class com.asakusafw.yaess.core.YaessProfile
-
Returns a core profile.
- getCount() - Method in class com.asakusafw.runtime.directio.util.CountInputStream
-
Returns the count since have read bytes.
- getCount() - Method in class com.asakusafw.runtime.directio.util.CountOutputStream
-
Returns the count since have read bytes.
- getCount() - Method in class com.asakusafw.windgate.stream.CountingInputStream
-
Returns the count since have read bytes.
- getCount() - Method in class com.asakusafw.windgate.stream.CountingOutputStream
-
Returns the count since have read bytes.
- getCounter() - Method in class com.asakusafw.runtime.directio.OutputAttemptContext
-
Returns the operation counter.
- getCounter() - Method in class com.asakusafw.runtime.directio.OutputTransactionContext
-
Returns the operation counter.
- getCreatedIds() - Method in class com.asakusafw.windgate.core.session.SessionProvider
-
Returns session IDs which are created and not completed/aborted.
- getCreatedIds() - Method in class com.asakusafw.windgate.file.session.FileSessionProvider
-
- getCurrentBatchId() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the current batch ID.
- getCurrentBlock() - Method in class com.asakusafw.runtime.stage.temporary.TemporaryFileInput
-
Returns the current block number (0..
).
- getCurrentExecutionId() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the current execution ID.
- getCurrentFile() - Method in class com.asakusafw.windgate.hadoopfs.ssh.FileList.Reader
-
- getCurrentFlowId() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the current flow ID.
- getCurrentKey() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullRecordReader
-
- getCurrentKey() - Method in class com.asakusafw.runtime.stage.input.StageInputRecordReader
-
- getCurrentLineNumber() - Method in class com.asakusafw.runtime.io.csv.CsvParser
-
Returns the 1-origin line number where the current record is started.
- getCurrentObject() - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelConverter
-
Returns the current object.
- getCurrentObject() - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelConverter
-
Returns the current object.
- getCurrentPath() - Method in class com.asakusafw.windgate.hadoopfs.ssh.FileList.Reader
-
- getCurrentPath() - Method in class com.asakusafw.windgate.stream.file.FileInputStreamProvider
-
- getCurrentPath() - Method in class com.asakusafw.windgate.stream.file.FileOutputStreamProvider
-
- getCurrentPath() - Method in class com.asakusafw.windgate.stream.InputStreamProvider
-
Returns the path about the current stream.
- getCurrentPath() - Method in class com.asakusafw.windgate.stream.OutputStreamProvider
-
Returns the path about the current stream.
- getCurrentRecord() - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelMaterializer
-
- getCurrentRecord() - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelMaterializer
-
- getCurrentRecordNumber() - Method in class com.asakusafw.runtime.io.csv.CsvParser
-
Returns the 1-origin record number.
- getCurrentValue() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullRecordReader
-
- getCurrentValue() - Method in class com.asakusafw.runtime.stage.input.StageInputRecordReader
-
- getCursorPosition() - Method in class com.asakusafw.runtime.flow.ArrayListBuffer
-
Returns the current cursor position.
- getCustomTruncate() - Method in class com.asakusafw.vocabulary.windgate.JdbcExporterDescription
-
Returns the custom truncate statement in SQL (for EXPERT).
- getCustomTruncate() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
Returns the custom truncate SQL statement.
- getData() - Method in class com.asakusafw.runtime.io.util.DataBuffer
-
Returns the data bytes.
- getData() - Method in class com.asakusafw.vocabulary.flow.builder.DataInfo
-
Returns the data.
- getData() - Method in class com.asakusafw.yaess.basic.BasicExtension
-
- getData() - Method in interface com.asakusafw.yaess.core.Extension
-
Returns the extension data.
- getDatabaseName() - Method in interface com.asakusafw.info.hive.syntax.HiveCreateTable
-
Returns the target database name.
- getDatabaseName() - Method in class com.asakusafw.info.hive.syntax.SimpleCreateTable
-
- getDataClass() - Method in interface com.asakusafw.runtime.directio.DataDefinition
-
Returns the target data model class.
- getDataClass() - Method in class com.asakusafw.runtime.directio.SimpleDataDefinition
-
- getDataClass() - Method in class com.asakusafw.windgate.core.ProcessScript
-
Returns the data model class to be transferred.
- getDataFilter() - Method in interface com.asakusafw.runtime.directio.DataDefinition
-
Returns the data filter.
- getDataFilter() - Method in class com.asakusafw.runtime.directio.SimpleDataDefinition
-
- getDataFormat() - Method in interface com.asakusafw.runtime.directio.DataDefinition
-
Returns the data format.
- getDataFormat() - Method in class com.asakusafw.runtime.directio.SimpleDataDefinition
-
- getDataFormatNamers() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelTrait
-
Returns the data format namers.
- getDataModelClass() - Method in class com.asakusafw.directio.hive.serde.DataModelDescriptor
-
Returns the target data model class.
- getDataModelComment() - Method in class com.asakusafw.directio.hive.serde.DataModelDescriptor
-
Returns comment for this data model.
- getDataModelDefinition() - Method in class com.asakusafw.testdriver.DriverInputBase
-
Returns the data model definition for this port.
- getDataModelDescriptor() - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
Returns the target data model descriptor.
- getDataModelDescriptor() - Method in class com.asakusafw.directio.hive.orc.OrcFileFormat
-
- getDataModelDescriptor() - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
Returns the target data model descriptor.
- getDataModelDescriptor() - Method in class com.asakusafw.directio.hive.parquet.ParquetFileFormat
-
- getDataModelSinkFactory(URI) - Method in interface com.asakusafw.testdriver.core.TestDataToolProvider
-
- getDataModelSinkFactory(URI) - Method in class com.asakusafw.testdriver.core.TestToolRepository
-
- getDataModelSourceFactory(URI) - Method in interface com.asakusafw.testdriver.core.TestDataToolProvider
-
- getDataModelSourceFactory(URI) - Method in class com.asakusafw.testdriver.core.TestToolRepository
-
- getDataPageSize() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the data page size (in bytes).
- getDataPageSize() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Returns the data page size (in bytes).
- getDataPageSize() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Returns the data page size (in bytes).
- getDataSize() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns the data size.
- getDataSize() - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Returns the data size.
- getDataSize() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns the data size.
- getDataSize() - Method in interface com.asakusafw.vocabulary.external.ImporterDescription
-
Returns the estimated data size.
- getDataSourceInfo() - Method in class com.asakusafw.operation.tools.directio.file.DataSourceParameter
-
Returns the data source information.
- getDataSourceInfo(BasePath) - Method in class com.asakusafw.operation.tools.directio.file.DataSourceParameter
-
Returns the data source information for the path.
- getDataType() - Method in class com.asakusafw.info.directio.DirectFilePortInfo
-
Returns the data type name.
- getDataType() - Method in class com.asakusafw.info.operator.InputAttribute
-
- getDataType() - Method in interface com.asakusafw.info.operator.InputInfo
-
Returns the data type.
- getDataType() - Method in class com.asakusafw.info.operator.OutputAttribute
-
- getDataType() - Method in interface com.asakusafw.info.operator.OutputInfo
-
Returns the data type.
- getDataType() - Method in class com.asakusafw.info.operator.view.InputView
-
- getDataType() - Method in class com.asakusafw.info.operator.view.OutputView
-
- getDataType() - Method in class com.asakusafw.runtime.directio.hadoop.StripedDataFormat.InputContext
-
Returns the target data type.
- getDataType() - Method in class com.asakusafw.testdriver.compiler.basic.BasicPortMirror
-
- getDataType() - Method in interface com.asakusafw.testdriver.compiler.PortMirror
-
Returns the data type.
- getDataType() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPortDescription
-
Return the data type of this port.
- getDataType() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
Returns the data type of this input.
- getDataType() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
Returns the data type of this output.
- getDataTypeName() - Method in class com.asakusafw.runtime.stage.temporary.TemporaryFileInput
-
Returns the target data type name.
- getDateFormat() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
- getDateFormat() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the date format.
- getDateFormat() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the string representation of DATE
.
- getDateFormat() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
- getDateFormat() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
- getDateFormat() - Method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Returns the log date format.
- getDateTimeFormat() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
- getDateTimeFormat() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the date-time format.
- getDateTimeFormat() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the string representation of DATETIME
.
- getDateTimeFormat() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
- getDateTimeFormat() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
- getDay() - Method in class com.asakusafw.runtime.value.Date
-
Returns the day of this date.
- getDay() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the day of this date and time.
- getDayFromCalendar(Calendar) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Returns a date as the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
.
- getDayFromDate(int, int, int) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Returns a date as the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
.
- getDayFromDate(Date) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Returns a date as the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
.
- getDayFromSeconds(long) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
to
the corresponded date as the number of elapsed days.
- getDayFromYear(int) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the year to the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
about
the first day of the specified year.
- getDayOfMonth(int, boolean) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed days from beginning of the year to the date in the current month.
- getDaysSinceEpoch(Date) - Static method in class com.asakusafw.directio.hive.util.TemporalUtil
-
Returns the day number since the epoch date.
- getDebugLevel() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getDebugLevel() - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns the debug level.
- getDecimal(int, int) - Static method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
- getDecimalFormat() - Method in class com.asakusafw.runtime.io.text.value.NumericOptionFieldAdapter.NumericBuilderBase
-
Returns the number format.
- getDecimalOutputStyle() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the decimal output style.
- getDecimalPrecision() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the explicit decimal precision.
- getDecimalScale() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the explicit decimal scale.
- getDecimalStyle() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Returns the decimal style.
- getDeclaration() - Method in class com.asakusafw.dmdl.directio.util.MapValue.Entry
-
Returns the declaration.
- getDeclaration() - Method in class com.asakusafw.dmdl.directio.util.MapValue
-
Returns the declaration.
- getDeclaration() - Method in class com.asakusafw.dmdl.directio.util.Value
-
Returns the declaration.
- getDeclaration() - Method in class com.asakusafw.operator.model.OperatorClass
-
Returns the declaring class of this.
- getDeclaration() - Method in class com.asakusafw.operator.model.OperatorElement
-
Returns the method/constructor declaration of this operator.
- getDeclaration() - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalClassDeclarationImpl
-
- getDeclaration() - Method in interface com.asakusafw.utils.java.model.syntax.LocalClassDeclaration
-
Returns the declaring class.
- getDeclaration() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
Returns information of the operator declaration.
- getDeclaredMembers() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
Returns all declared members in this model.
- getDeclaredModels() - Method in class com.asakusafw.dmdl.semantics.DmdlSemantics
-
Returns all models declared in this world.
- getDeclaredProperties() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
Returns all declared properties in this model.
- getDeclaredPropertyReferences() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
Returns all declared property references in this model.
- getDeclaring() - Method in class com.asakusafw.vocabulary.batch.Work
-
Returns the batch which declaring this work.
- getDeclaring() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Declaration
-
Returns the declaring class.
- getDeclaringClass() - Method in class com.asakusafw.info.operator.UserOperatorSpec
-
Returns the operator class.
- getDeclaringClass() - Method in class com.asakusafw.info.value.AnnotationInfo
-
Returns the annotation type.
- getDeclaringClass() - Method in class com.asakusafw.info.value.EnumInfo
-
Returns the declaring class.
- getDeclaringClass() - Method in class com.asakusafw.info.value.UnknownInfo
-
Returns the value class.
- getDeclaringClass() - Method in class com.asakusafw.operator.description.AnnotationDescription
-
Returns the declaring annotation type.
- getDeclaringClass() - Method in class com.asakusafw.operator.description.EnumConstantDescription
-
Returns the declaring enum type.
- getDeclaringClass() - Method in interface com.asakusafw.runtime.io.text.driver.FieldOutput.Option
-
Returns the option type.
- getDeclaringClass() - Method in interface com.asakusafw.vocabulary.attribute.Attribute
-
Returns the declaring class of this attribute.
- getDeclaringClass() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementAttribute
-
Returns the declaring class of this attribute.
- getDeclaringClass() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorHelper
-
- getDeclaringType() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMember
-
Returns the declaring type.
- getDefault() - Static method in enum com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait.QuoteStrategy
-
Returns the default value.
- getDefault() - Static method in enum com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait.QuoteStrategy
-
Returns the default value.
- getDefault() - Static method in enum com.asakusafw.operator.WarningAction
-
- getDefault() - Static method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory
-
Returns a default factory which refers the System Hadoop configuration path.
- getDefault() - Static method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
- getDefault() - Static method in enum com.asakusafw.vocabulary.flow.graph.Connectivity
-
Returns the default connectivity.
- getDefault() - Static method in enum com.asakusafw.vocabulary.operator.Logging.Level
-
規定のレベルを返す。
- getDefault() - Static method in enum com.asakusafw.yaess.core.ExecutionLock.Scope
-
Returns the default scope.
- getDefaultExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
- getDefaultExpression() - Method in interface com.asakusafw.utils.java.model.syntax.AnnotationElementDeclaration
-
Returns the default value of the element.
- getDefaultStyle() - Method in class com.asakusafw.dmdl.directio.text.QuoteSettings
-
Returns the default quote style.
- getDefinitionId() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the qualified stage ID {@literal (a.k.a.
- getDefinitionId(String, String, String) - Static method in class com.asakusafw.runtime.stage.StageConstants
-
Returns the qualified stage ID from individual IDs.
- getDefinitionId() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns the static definition ID of this plan.
- getDeleteCommand() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the delete command.
- getDeletePatterns() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns the view of delete patterns.
- getDeletePatterns() - Method in class com.asakusafw.info.directio.DirectFileOutputInfo
-
Returns the delete patterns.
- getDeletePatterns() - Method in class com.asakusafw.vocabulary.directio.DirectFileOutputDescription
-
Returns the resource path pattern to delete before output.
- getDependencies() - Method in class com.asakusafw.info.plan.PlanVertexSpec
-
Returns the blocker vertex names.
- getDependencies() - Method in class com.asakusafw.vocabulary.batch.Work
-
Returns the dependencies of this work.
- getDescription() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns the textual description for the target class.
- getDescription() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns the textual description for the target class.
- getDescription(Declaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the description text of the declaration.
- getDescription() - Method in interface com.asakusafw.dmdl.semantics.Declaration
-
Returns the description of this element.
- getDescription() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
- getDescription() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
- getDescription() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
- getDescription() - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Returns the textual description for the target class.
- getDescription() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns the textual description for the target class.
- getDescription() - Method in class com.asakusafw.operator.model.ExternMirror
-
Returns the extern description type.
- getDescription() - Method in class com.asakusafw.operator.model.OperatorElement
-
Returns the description of this operator element.
- getDescription() - Method in class com.asakusafw.testdriver.compiler.basic.BasicPortMirror
-
- getDescription() - Method in interface com.asakusafw.testdriver.compiler.PortMirror
-
Returns the importer/exporter description object.
- getDescription() - Method in class com.asakusafw.vocabulary.batch.Work
-
Returns the description of this work.
- getDescription() - Method in class com.asakusafw.vocabulary.flow.builder.ExternInfo
-
Returns the external port description class.
- getDescription() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
Returns the description of this element.
- getDescription() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPort
-
Returns the description of this port.
- getDescription() - Method in class com.asakusafw.vocabulary.flow.graph.FlowGraph
-
Returns the description class.
- getDescription() - Method in class com.asakusafw.vocabulary.flow.graph.FlowIn
-
Returns the description of this input.
- getDescription() - Method in class com.asakusafw.vocabulary.flow.graph.FlowOut
-
Returns the description of this output.
- getDescription() - Method in enum com.asakusafw.windgate.core.session.SessionException.Reason
-
Returns the description of this reason.
- getDescriptionClass() - Method in class com.asakusafw.info.BatchInfo
-
- getDescriptionClass() - Method in class com.asakusafw.info.directio.DirectFilePortInfo
-
Returns the description class name.
- getDescriptionClass() - Method in interface com.asakusafw.info.ElementInfo
-
Returns the description class name.
- getDescriptionClass() - Method in class com.asakusafw.info.hive.HiveInputInfo
-
- getDescriptionClass() - Method in class com.asakusafw.info.hive.HiveOutputInfo
-
- getDescriptionClass() - Method in interface com.asakusafw.info.hive.HivePortInfo
-
Returns the description class name.
- getDescriptionClass() - Method in class com.asakusafw.info.JobflowInfo
-
- getDescriptionClass() - Method in class com.asakusafw.info.operator.FlowOperatorSpec
-
Returns the description class.
- getDescriptionClass() - Method in class com.asakusafw.info.operator.InputOperatorSpec
-
Returns the description class.
- getDescriptionClass() - Method in class com.asakusafw.info.operator.OutputOperatorSpec
-
Returns the description class.
- getDescriptionClass() - Method in class com.asakusafw.info.windgate.WindGatePortInfo
-
Returns the description class name.
- getDescriptionClass() - Method in class com.asakusafw.testdriver.core.BaseExporterRetriever
-
- getDescriptionClass() - Method in class com.asakusafw.testdriver.core.BaseImporterPreparator
-
- getDescriptionClass() - Method in interface com.asakusafw.testdriver.core.ExporterRetriever
-
- getDescriptionClass() - Method in interface com.asakusafw.testdriver.core.ImporterPreparator
-
- getDescriptionClass() - Method in class com.asakusafw.testdriver.core.SpiExporterRetriever
-
- getDescriptionClass() - Method in class com.asakusafw.testdriver.core.SpiImporterPreparator
-
- getDescriptor() - Method in enum com.asakusafw.utils.java.model.syntax.BasicTypeKind
-
Returns the type descriptor.
- getDesiredStreamSize() - Method in class com.asakusafw.windgate.stream.OutputStreamProvider
-
Returns the desired each stream size.
- getDestination() - Method in class com.asakusafw.info.graph.Wire
-
Returns the destination input.
- getDevelopmentEnvironmentVersion() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the development environment version.
- getDiagnostic() - Method in class com.asakusafw.testdriver.core.Difference
-
Returns a diagnostic message.
- getDiagnostics() - Method in exception com.asakusafw.dmdl.analyzer.DmdlSemanticException
-
Returns semantic diagnostics of current error.
- getDiagnostics() - Method in class com.asakusafw.dmdl.semantics.DmdlSemantics
-
Returns the all diagnostics about semantics analysis.
- getDictionaryPageSize() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the dictionary page size (in bytes).
- getDictionaryPageSize() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Returns the dictionary page size (in bytes).
- getDictionaryPageSize() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Returns the dictionary page size (in bytes).
- getDifferences() - Method in class com.asakusafw.iterative.common.basic.BasicParameterTable.BasicCursor
-
- getDifferences() - Method in interface com.asakusafw.iterative.common.ParameterTable.Cursor
-
Returns the changed parameter names from the previous element.
- getDifferenceSink() - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Returns the difference information sink for this output.
- getDifferenceSinkFactory(URI) - Method in interface com.asakusafw.testdriver.core.TestDataToolProvider
-
- getDifferenceSinkFactory(URI) - Method in class com.asakusafw.testdriver.core.TestToolRepository
-
- getDimensionExpressions() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
- getDimensionExpressions() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayCreationExpression
-
Returns the dimension expressions.
- getDirection() - Method in class com.asakusafw.info.operator.InputGroup.Order
-
Returns the direction.
- getDirection() - Method in class com.asakusafw.operator.model.KeyMirror.Order
-
Returns the ordering direction.
- getDirection() - Method in class com.asakusafw.vocabulary.attribute.ViewInfo.Ordering
-
Returns the ordering direction.
- getDirection() - Method in class com.asakusafw.vocabulary.flow.builder.PortInfo
-
Returns the port direction.
- getDirection() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPortDescription
-
Returns the port direction.
- getDirection() - Method in class com.asakusafw.vocabulary.flow.graph.ShuffleKey.Order
-
Returns the ordering direction.
- getDirectory() - Method in class com.asakusafw.utils.gradle.BaseProject
-
Returns the project directory.
- getDirectory() - Method in class com.asakusafw.utils.gradle.BasicProject
-
- getDirectory() - Method in class com.asakusafw.utils.gradle.Bundle
-
Returns the bundle directory.
- getDirectory() - Method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Returns the base directory of log output target.
- getDirectView() - Method in class com.asakusafw.runtime.flow.join.LookUpKey
-
Returns a direct view of this key.
- getDocument() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns the documents about the operator.
- getDocument() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the document for this node.
- getDownstream() - Method in class com.asakusafw.vocabulary.flow.graph.PortConnection
-
Returns the downstream port.
- getDrainScript() - Method in class com.asakusafw.windgate.core.ProcessScript
-
Returns the script which describes a drain driver.
- getDriver(ObjectInspector) - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getDriver(ObjectInspector) - Method in interface com.asakusafw.directio.hive.serde.ValueSerde
-
- getDrivers() - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
Returns the element drivers.
- getDriverScript() - Method in class com.asakusafw.vocabulary.windgate.FsExporterDescription
-
- getDriverScript() - Method in class com.asakusafw.vocabulary.windgate.FsImporterDescription
-
- getDriverScript() - Method in class com.asakusafw.vocabulary.windgate.JdbcExporterDescription
-
- getDriverScript() - Method in class com.asakusafw.vocabulary.windgate.JdbcImporterDescription
-
- getDriverScript() - Method in interface com.asakusafw.vocabulary.windgate.WindGateProcessDescription
-
Returns the driver script of this description.
- getDriverScript(DriverScript.Kind) - Method in class com.asakusafw.windgate.core.ProcessScript
-
Returns the script which describes a specified driver.
- getEditor() - Method in class com.asakusafw.operation.tools.directio.transaction.TransactionEditorParameter
-
Returns the editor.
- getElapsedDays() - Method in class com.asakusafw.runtime.value.Date
-
Returns the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
.
- getElapsedSeconds() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
.
- getElement(int) - Method in class com.asakusafw.info.graph.Node
-
Returns the element node of this node.
- getElement() - Method in class com.asakusafw.operator.model.OperatorDescription.ExternalDocument
-
Returns the element.
- getElement() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementResolver
-
Returns the target flow element of this resolver.
- getElementGraph() - Method in class com.asakusafw.info.operator.view.OperatorView
-
- getElementMap(AstAttribute) - Static method in class com.asakusafw.dmdl.util.AttributeUtil
-
Extract the attributes into (name, element) pairs.
- getElements() - Method in class com.asakusafw.info.graph.Node
-
Returns the element nodes of this node.
- getElements() - Method in class com.asakusafw.info.ParameterListAttribute
-
Returns the elements.
- getElements() - Method in class com.asakusafw.info.value.AnnotationInfo
-
Returns the elements.
- getElements() - Method in class com.asakusafw.info.value.ListInfo
-
Returns the element values.
- getElements() - Method in class com.asakusafw.operator.description.AnnotationDescription
-
Returns the annotation elements.
- getElements() - Method in class com.asakusafw.operator.description.ArrayDescription
-
Returns the array elements.
- getElements() - Method in class com.asakusafw.operator.model.OperatorClass
-
Returns the operator elements.
- getElements() - Method in class com.asakusafw.runtime.directio.FilePattern.Segment
-
Returns pattern elements in this segment.
- getElements() - Method in class com.asakusafw.testdriver.compiler.basic.BasicBatchMirror
-
- getElements() - Method in interface com.asakusafw.testdriver.compiler.BatchMirror
-
- getElements() - Method in class com.asakusafw.trace.model.TraceSettingList
-
Returns the setting elements.
- getElements() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayInitializerImpl
-
- getElements() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocBlockImpl
-
- getElements() - Method in class com.asakusafw.utils.java.internal.model.syntax.NormalAnnotationImpl
-
- getElements() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayInitializer
-
Returns the element expressions.
- getElements() - Method in interface com.asakusafw.utils.java.model.syntax.DocBlock
-
Returns the inline elements.
- getElements() - Method in interface com.asakusafw.utils.java.model.syntax.NormalAnnotation
-
Returns the annotation elements.
- getElements() - Method in class com.asakusafw.workflow.model.attribute.ParameterListAttribute
-
Returns the elements.
- getElements() - Method in class com.asakusafw.workflow.model.basic.BasicBatchInfo
-
- getElements() - Method in interface com.asakusafw.workflow.model.BatchInfo
-
Returns the element jobflows.
- getElementType(PropertyReferenceDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the element type of target reference.
- getElementType() - Method in class com.asakusafw.dmdl.semantics.type.CollectionType
-
Returns the element type.
- getElementType() - Method in class com.asakusafw.info.hive.ArrayType
-
Returns the element type.
- getElementTypes() - Method in class com.asakusafw.info.hive.UnionType
-
Returns the element types.
- getElseExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
- getElseExpression() - Method in interface com.asakusafw.utils.java.model.syntax.ConditionalExpression
-
Returns the false term.
- getElseStatement() - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
- getElseStatement() - Method in interface com.asakusafw.utils.java.model.syntax.IfStatement
-
Returns the false statement.
- getEnableDictionary() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns whether the dictionary is enabled or not.
- getEnabledScriptKinds() - Method in class com.asakusafw.yaess.core.FlowScript
-
Returns the enabled script kinds in this flow execution.
- getEnableValidation() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns whether the schema validation is enabled or not.
- getEncoding() - Method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Returns the log output encoding.
- getEnd() - Method in class com.asakusafw.runtime.directio.hadoop.BlockInfo
-
Returns the end byte position of this block in the file.
- getEntity() - Method in class com.asakusafw.dmdl.directio.util.Value
-
Returns the entity.
- getEntity() - Method in interface com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceContainer
-
Returns the container entity.
- getEntity() - Method in class com.asakusafw.info.operator.view.InputView
-
Returns the entity element.
- getEntity() - Method in class com.asakusafw.info.operator.view.OperatorView
-
Returns the entity element.
- getEntity() - Method in class com.asakusafw.info.operator.view.OutputView
-
Returns the entity element.
- getEntity() - Method in class com.asakusafw.operation.tools.directio.DataSourceInfo
-
Returns the data source.
- getEntity() - Method in class com.asakusafw.runtime.core.api.ApiStub.Reference
-
Returns the entity.
- getEntity() - Method in class com.asakusafw.runtime.io.util.InvertOrder
-
Returns the entity object.
- getEntries() - Method in class com.asakusafw.dmdl.directio.util.MapValue
-
Returns the entries.
- getEntries() - Method in class com.asakusafw.info.cli.common.ApplicationBaseDirectoryParameter
-
Returns the available entries in the batch applications directory.
- getEntries(Path) - Static method in class com.asakusafw.info.cli.common.ApplicationBaseDirectoryParameter
-
Returns the available entries in the batch application base directory.
- getEntries() - Method in class com.asakusafw.runtime.io.text.tabular.EscapeSequence
-
Returns the entries.
- getEntries() - Method in exception com.asakusafw.runtime.io.text.UnmappableOutputException
-
Returns the entries.
- getEnvironment() - Method in interface com.asakusafw.dmdl.spi.AttributeDriver.Context
-
Returns the current environment.
- getEnvironment() - Method in interface com.asakusafw.dmdl.spi.TypeDriver.Context
-
Returns the current environment.
- getEnvironment() - Method in class com.asakusafw.operator.OperatorDriver.Context
-
Returns the current compiling environment.
- getEnvironment() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
Returns the environment variables.
- getEnvironmentVariables() - Method in class com.asakusafw.testdriver.core.TestContext.Empty
-
- getEnvironmentVariables() - Method in interface com.asakusafw.testdriver.core.TestContext
-
Returns the environment variables.
- getEnvironmentVariables() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getEnvironmentVariables() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Returns the current environment variables.
- getEnvironmentVariables() - Method in class com.asakusafw.testdriver.TestDriverContext
-
- getEnvironmentVariables() - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
- getEnvironmentVariables() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the additional remote environment variables.
- getEnvironmentVariables() - Method in class com.asakusafw.workflow.executor.basic.BasicExecutionContext
-
- getEnvironmentVariables() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getEnvironmentVariables() - Method in interface com.asakusafw.workflow.executor.ExecutionContext
-
Returns the environment variables.
- getEnvironmentVariables() - Method in class com.asakusafw.yaess.core.CommandScript
-
- getEnvironmentVariables() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current environment variables for sub processes.
- getEnvironmentVariables() - Method in interface com.asakusafw.yaess.core.ExecutionScript
-
Returns desired environment variables used in this execution.
- getEnvironmentVariables(ExecutionContext, ExecutionScript) - Method in interface com.asakusafw.yaess.core.ExecutionScriptHandler
-
Returns desired environment variables to execute scripts using this handler.
- getEnvironmentVariables(ExecutionContext, ExecutionScript) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
Returns desired environment variables to execute scripts using this handler.
- getEnvironmentVariables() - Method in class com.asakusafw.yaess.core.HadoopScript
-
- getEnvironmentVariables() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the environment variables for the target job.
- getEnvironmentVariables(ExecutionContext, ExecutionScript) - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- getErasure(TypeMirror) - Method in class com.asakusafw.operator.CompileEnvironment
-
Returns the type erasure.
- getErasure() - Method in class com.asakusafw.operator.description.ArrayTypeDescription
-
- getErasure() - Method in class com.asakusafw.operator.description.BasicTypeDescription
-
- getErasure() - Method in class com.asakusafw.operator.description.ClassDescription
-
- getErasure() - Method in interface com.asakusafw.operator.description.TypeDescription
-
Returns the erasure of this type.
- getErrorCode() - Method in class com.asakusafw.runtime.io.text.UnmappableOutput
-
Returns the error code.
- getErrorCode() - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Returns the error code for target job.
- getErrorMessage() - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Returns the error message for target job.
- getEscapeCharacter() - Method in class com.asakusafw.runtime.io.text.tabular.EscapeSequence
-
Returns the escape character.
- getEscapeFile(ExecutionContext) - Method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Returns abstract path for the escaped log file.
- getEscapeLineSeparator() - Method in class com.asakusafw.dmdl.directio.text.EscapeSettings
-
Returns whether or not line separators can be escaped.
- getEscapeNoAscii() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Returns the escape no ASCII flag.
- getEscapeSettings() - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextTrait
-
Returns the escape settings.
- getExceptionTypes() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getExceptionTypes() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getExceptionTypes() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorDeclaration
-
Returns the exception types.
- getExchange() - Method in class com.asakusafw.info.plan.PlanInputSpec
-
Returns the data exchanging strategy.
- getExchange() - Method in class com.asakusafw.info.plan.PlanOutputSpec
-
Returns the data exchanging strategy.
- getExecutionContext() - Method in class com.asakusafw.workflow.cli.common.ExecutionContextParameter
-
Returns the execution context.
- getExecutionId() - Method in class com.asakusafw.runtime.directio.hadoop.DirectIoTransactionEditor.TransactionInfo
-
Returns the target execution ID.
- getExecutionId() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the execution ID of the current jobflow.
- getExecutionId() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getExecutionId() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the current execution ID.
- getExecutionId() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns the runtime execution ID of this plan.
- getExecutionId() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the execution ID.
- getExecutionId() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getExecutionId() - Method in interface com.asakusafw.workflow.executor.TaskExecutionContext
-
Returns the current execution ID.
- getExecutionId() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current execution ID.
- getExecutionId() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the execution ID for target job.
- getExitCode() - Method in exception com.asakusafw.yaess.basic.ExitCodeException
-
Returns actual exit code.
- getExitCode() - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Returns the exit code of target job.
- getExpected() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Returns the expected status description.
- getExpected() - Method in class com.asakusafw.testdriver.core.Difference
-
Returns the expected data.
- getExpectedType() - Method in enum com.asakusafw.testdriver.excel.ValueConditionKind
-
Returns a description of expected type of this predicate.
- getExplicitCommandPath() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Returns the explicitly defined Hadoop command path.
- getExplicitConfigurationPath() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Returns the explicitly defined Hadoop configuration path.
- getExporterDescription() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
Returns the exporter description of this output.
- getExporterRetriever(T) - Method in class com.asakusafw.testdriver.core.TestToolRepository
-
- getExporters() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns tasks in export phase.
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssertStatementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.CastExpressionImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.ExpressionStatementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.InstanceofExpressionImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.ParenthesizedExpressionImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.ReturnStatementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.SingleElementAnnotationImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchCaseLabelImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchStatementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.SynchronizedStatementImpl
-
- getExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.ThrowStatementImpl
-
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.AnnotationElement
-
Returns the element value.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.AssertStatement
-
Returns the assertion expression.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.CastExpression
-
Returns the target term.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.EnhancedForStatement
-
Returns the loop target expression.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.ExpressionStatement
-
Returns the element expression.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.InstanceofExpression
-
Returns the target term.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.ParenthesizedExpression
-
Returns the element expression.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.ReturnStatement
-
Returns the return value.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.SingleElementAnnotation
-
Returns the value for value
element.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.SwitchCaseLabel
-
Returns the case
label value.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.SwitchStatement
-
Returns the switch
selector expression.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.SynchronizedStatement
-
Returns the monitor object.
- getExpression() - Method in interface com.asakusafw.utils.java.model.syntax.ThrowStatement
-
Returns the thrown object.
- getExpressions() - Method in class com.asakusafw.utils.java.internal.model.syntax.StatementExpressionListImpl
-
- getExpressions() - Method in interface com.asakusafw.utils.java.model.syntax.StatementExpressionList
-
Returns the expression list.
- getExtended() - Method in class com.asakusafw.yaess.bootstrap.ArgumentList
-
Returns the extended arguments.
- getExtension(Class<T>) - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getExtension(Class<T>) - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns an extension.
- getExtension(Class<T>) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the extension object.
- getExtensions() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
Returns the extensions.
- getExtensions(ExecutionContext, ExecutionScript) - Static method in class com.asakusafw.yaess.basic.BlobUtil
-
- getExtensions() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns the extension BLOBs.
- getExtensionTypes() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the registered extension types.
- getExtern() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the extern mirror of this node.
- getExtern() - Method in class com.asakusafw.vocabulary.flow.builder.EdgeInfo
-
Returns external I/O information.
- getExternalResources() - Method in class com.asakusafw.testdriver.TesterBase
-
Returns initial data providers for the external resources.
- getExtraConfigurations() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns extra configurations for the runtime.
- getExtraDimensions() - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
- getExtraDimensions() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getExtraDimensions() - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
- getExtraDimensions() - Method in interface com.asakusafw.utils.java.model.syntax.FormalParameterDeclaration
-
Returns the extra variable dimensions.
- getExtraDimensions() - Method in interface com.asakusafw.utils.java.model.syntax.MethodDeclaration
-
Returns the number of extra dimensions of the return type.
- getExtraDimensions() - Method in interface com.asakusafw.utils.java.model.syntax.VariableDeclarator
-
Returns the extra variable dimensions.
- getExtraOperations() - Method in class com.asakusafw.info.plan.PlanOutputSpec
-
Returns the extra operations.
- getFactory() - Method in class com.asakusafw.dmdl.java.Configuration
-
Returns Java DOM element factory.
- getFactoryClass(CharSequence) - Static method in class com.asakusafw.operator.Constants
-
Returns the factory class name of target class with the specified name.
- getFalseFormat() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Returns the "false"
representation.
- getFalseFormat() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the string representation of false
.
- getFalseFormat() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Returns the "false"
representation.
- getFalseFormat() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
The boolean false
format.
- getFieldComment() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getFieldID() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getFieldIndex() - Method in class com.asakusafw.runtime.io.text.csv.CsvFieldReader
-
- getFieldIndex() - Method in interface com.asakusafw.runtime.io.text.FieldReader
-
Returns the field index of the current field.
- getFieldIndex() - Method in class com.asakusafw.runtime.io.text.tabular.TabularFieldReader
-
- getFieldIndex() - Method in class com.asakusafw.runtime.io.text.UnmappableOutput
-
Returns the field index where this error was occurred.
- getFieldInitializer(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property initializer.
- getFieldMappingStrategy() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the field mapping strategy.
- getFieldMappingStrategy() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the field mapping strategy.
- getFieldMappingStrategy() - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Returns the field mapping strategy.
- getFieldName() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getFieldName(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
Returns the CSV field name of the property.
- getFieldName(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFieldTrait
-
Returns the TSV field name of the property.
- getFieldName(MemberDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property name.
- getFieldName(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait
-
Returns the CSV field name of the property.
- getFieldObjectInspector() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getFields(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- getFields(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Returns the field declarations to mixin to the model.
- getFieldSeparator() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the field separator.
- getFieldSeparator() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
Returns the field separator character.
- getFieldSeparatorEscape() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
Returns the escape character for the field separator.
- getFieldSettings() - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextTrait
-
Returns the field settings.
- getFieldSettings() - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextTrait
-
Returns the field settings.
- getFieldType(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property data type.
- getFieldTypeAsClass(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property data type as related class object.
- getFieldTypeAsClass(BasicTypeKind) - Static method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property data type as related class object.
- getFile() - Method in class com.asakusafw.yaess.basic.FileBlob
-
Returns the file.
- getFileExtension() - Method in class com.asakusafw.yaess.basic.FileBlob
-
- getFileExtension() - Method in interface com.asakusafw.yaess.core.Blob
-
Returns the file extension for this object.
- getFileForInput(JavaFileManager.Location, String, String) - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
- getFileForOutput(JavaFileManager.Location, String, String, FileObject) - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
- getFileName(ModelDeclaration) - Method in enum com.asakusafw.testdata.generator.excel.WorkbookFormat
-
Returns a simple file name for the model.
- getFileSize() - Method in class com.asakusafw.runtime.directio.hadoop.BlockMap
-
Returns the file size.
- getFileSystem() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the file system for the this datastore.
- getFileSystem() - Method in class com.asakusafw.runtime.directio.hadoop.StripedDataFormat.InputContext
-
Returns the file system for the this datastore.
- getFileSystemPath() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the mapping target path.
- getFilter() - Method in class com.asakusafw.vocabulary.directio.DirectFileInputDescription
-
- getFilterClass() - Method in class com.asakusafw.info.directio.DirectFileInputInfo
-
Returns the filter class name.
- getFinalizers() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns tasks in finalize phase.
- getFinallyBlock() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
- getFinallyBlock() - Method in interface com.asakusafw.utils.java.model.syntax.TryStatement
-
Returns the body block of finally
clause.
- getFlowClass() - Method in class com.asakusafw.vocabulary.batch.JobFlowWorkDescription
-
Returns the jobflow class.
- getFlowElement() - Method in class com.asakusafw.vocabulary.flow.graph.FlowIn
-
- getFlowElement() - Method in class com.asakusafw.vocabulary.flow.graph.FlowOut
-
- getFlowGraph() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
Returns the flow-graph which represents this flow-part structure.
- getFlowId() - Method in class com.asakusafw.info.cli.common.JobflowInfoParameter
-
Returns the flow ID.
- getFlowId() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the flow ID.
- getFlowId() - Method in class com.asakusafw.testdriver.executor.TaskExecutorContextAdapter
-
- getFlowId() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the flow ID.
- getFlowId() - Method in class com.asakusafw.workflow.executor.basic.BasicTaskExecutionContext
-
- getFlowId() - Method in interface com.asakusafw.workflow.executor.TaskExecutionContext
-
Returns the container jobflow information.
- getFlowId() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current flow ID.
- getFlowId() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the flow ID for target job.
- getFlowInputs() - Method in class com.asakusafw.vocabulary.flow.graph.FlowGraph
-
Returns input port elements which represent inputs of this flow graph.
- getFlowOutputs() - Method in class com.asakusafw.vocabulary.flow.graph.FlowGraph
-
Returns output port elements which represent outputs of this flow graph.
- getFolderFor(PackageDeclaration) - Method in class com.asakusafw.utils.java.model.util.Filer
-
Returns the folder for the target package.
- getFolderFor(Name) - Method in class com.asakusafw.utils.java.model.util.Filer
-
Returns the folder for the target package.
- getForceQuoteColumns() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Returns column indices which quoting is always required.
- getFormalParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getFormalParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
- getFormalParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getFormalParameters() - Method in interface com.asakusafw.utils.java.model.syntax.DocMethod
-
Returns the formal parameters.
- getFormalParameters() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorDeclaration
-
Returns the formal parameter declarations.
- getFormat() - Method in class com.asakusafw.runtime.stage.directio.StringTemplate.FormatSpec
-
Returns the format kind.
- getFormat() - Method in class com.asakusafw.vocabulary.directio.DirectFileInputDescription
-
- getFormat() - Method in class com.asakusafw.vocabulary.directio.DirectFileOutputDescription
-
- getFormatClass() - Method in class com.asakusafw.info.directio.DirectFilePortInfo
-
Returns the data format class name.
- getFormatClass() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
- getFormatClass() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit.Source
-
Returns the InputFormat
class.
- getFormatClass() - Method in class com.asakusafw.runtime.stage.StageInput
-
Returns the input format class for handling this input.
- getFormatClass() - Method in class com.asakusafw.runtime.stage.StageOutput
-
Returns the output format class for handling this output.
- getFormatClassName() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns the format class name.
- getFormatClassName() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns the format class name.
- getFormatConfiguration() - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
Returns the format configuration.
- getFormatConfiguration() - Method in class com.asakusafw.directio.hive.orc.OrcFileFormat
-
- getFormatConfiguration() - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
Returns the format configuration.
- getFormatConfiguration() - Method in class com.asakusafw.directio.hive.parquet.ParquetFileFormat
-
- getFormatKind() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonStreamSettings
-
Returns the format kind.
- getFormatKind() - Method in class com.asakusafw.info.hive.BuiltinStorageFormatInfo
-
- getFormatKind() - Method in class com.asakusafw.info.hive.CustomStorageFormatInfo
-
- getFormatKind() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
- getFormatKind() - Method in interface com.asakusafw.info.hive.RowFormatInfo
-
Returns the row format kind.
- getFormatKind() - Method in class com.asakusafw.info.hive.SerdeRowFormatInfo
-
- getFormatKind() - Method in interface com.asakusafw.info.hive.StorageFormatInfo
-
Returns the storage format kind.
- getFormatSettings() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatTrait
-
Returns the format settings.
- getFormatSettings() - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextTrait
-
Returns the format settings.
- getFormatSettings() - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextTrait
-
Returns the format settings.
- getFormatVersion() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the ORCFile format version.
- getFormatVersion(Class<T>) - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the ORCFile format version.
- getFragments() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBlock
-
Returns the element fragments.
- getFrameworkHomePath() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the framework home path.
- getFrameworkHomePathOrNull() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the framework home path.
- getFrom() - Method in class com.asakusafw.runtime.io.text.tabular.EscapeSequence.Entry
-
Returns the original character.
- getFrozenView() - Method in class com.asakusafw.runtime.flow.join.LookUpKey
-
Returns a frozen view of this key.
- getGenetedAnnotation() - Static method in class com.asakusafw.operator.Constants
-
- getGetCommand() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the get command.
- getGranulatity() - Method in class com.asakusafw.info.operator.InputAttribute
-
- getGranulatity() - Method in interface com.asakusafw.info.operator.InputInfo
-
Returns the input granularity.
- getGranulatity() - Method in class com.asakusafw.info.operator.view.InputView
-
- getGroup() - Method in class com.asakusafw.info.operator.InputAttribute
-
- getGroup() - Method in interface com.asakusafw.info.operator.InputInfo
-
Returns the input group info.
- getGroup() - Method in class com.asakusafw.info.operator.view.InputView
-
- getGroup() - Method in class com.asakusafw.info.plan.PlanInputSpec
-
Returns the data exchanging group.
- getGroup() - Method in class com.asakusafw.info.plan.PlanOutputSpec
-
Returns the data exchanging group.
- getGroup() - Method in class com.asakusafw.operator.model.KeyMirror
-
Returns the grouping key list.
- getGrouping() - Method in class com.asakusafw.dmdl.semantics.trait.ReduceTerm
-
Returns symbols of grouping properties.
- getGrouping() - Method in class com.asakusafw.vocabulary.attribute.ViewInfo
-
Returns the grouping properties.
- getGroupingComparatorClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the grouping comparator class (for shuffle keys).
- getGroupObject() - Method in class com.asakusafw.runtime.io.util.ShuffleKey
-
Returns an object for grouping.
- getGroupProperties() - Method in class com.asakusafw.vocabulary.flow.graph.ShuffleKey
-
Returns the grouping properties.
- getHadoopCommand() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory
-
Returns the Hadoop command path for this configuration.
- getHadoopCommand() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Returns the Hadoop command path.
- getHadoopFileSystem(Path) - Method in class com.asakusafw.operation.tools.directio.file.DataSourceParameter
-
Returns the Hadoop file system for the path.
- getHadoopHandler() - Method in class com.asakusafw.yaess.core.YaessProfile
-
Returns a Hadoop script handler.
- getHadoopProperties() - Method in class com.asakusafw.yaess.core.HadoopScript
-
Returns the extra hadoop properties.
- getHandlerId() - Method in interface com.asakusafw.yaess.core.ExecutionScriptHandler
-
Returns the ID of this handler.
- getHandlerId() - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
Returns the ID of this handler.
- getHandlerId() - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- getHeaderCells() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
The header cell values.
- getHeaderStyle() - Method in class com.asakusafw.dmdl.directio.text.QuoteSettings
-
Returns the quote style for header fields.
- getHeaderType() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the header type.
- getHiveMajorVersion() - Static method in class com.asakusafw.directio.hive.util.CompatibilityUtil
-
returns the major version number of Hive.
- getHome(Environment) - Static method in class com.asakusafw.windgate.bootstrap.CoreConstants
-
Returns the framework installation directory.
- getHost() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the target host name.
- getHost() - Method in class com.asakusafw.yaess.jsch.JschProcessExecutor
-
Returns the remote host name.
- getHosts() - Method in class com.asakusafw.runtime.directio.hadoop.BlockInfo
-
Returns the host names.
- getHour() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the hour of this date time.
- getId() - Method in interface com.asakusafw.info.Attribute
-
Returns the attribute ID (optional).
- getId() - Method in class com.asakusafw.info.BatchInfo
-
- getId() - Method in class com.asakusafw.info.directio.DirectFileIoAttribute
-
- getId() - Method in interface com.asakusafw.info.ElementInfo
-
Returns the element ID.
- getId() - Method in class com.asakusafw.info.hive.HiveIoAttribute
-
- getId() - Method in class com.asakusafw.info.JobflowInfo
-
- getId() - Method in class com.asakusafw.info.operator.OperatorGraphAttribute
-
- getId() - Method in class com.asakusafw.info.ParameterListAttribute
-
- getId() - Method in class com.asakusafw.info.plan.PlanAttribute
-
- getId() - Method in class com.asakusafw.info.task.TaskInfo
-
Returns the task ID.
- getId() - Method in class com.asakusafw.info.task.TaskListAttribute
-
- getId() - Method in class com.asakusafw.info.windgate.WindGateIoAttribute
-
- getId() - Method in class com.asakusafw.operation.tools.directio.DataSourceInfo
-
Returns the data source ID.
- getId() - Method in class com.asakusafw.operation.tools.directio.transaction.TransactionIdParameter
-
Returns the transaction ID.
- getId() - Method in class com.asakusafw.runtime.directio.DirectDataSourceProfile
-
Returns the target ID.
- getId() - Method in interface com.asakusafw.runtime.directio.DirectDataSourceProvider
-
Returns the data source ID.
- getId() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Return the ID of this datasource.
- getId() - Method in class com.asakusafw.runtime.directio.ResourceInfo
-
Returns the container datasource ID.
- getId() - Method in class com.asakusafw.testdriver.compiler.basic.BasicBatchMirror
-
- getId() - Method in class com.asakusafw.windgate.core.session.SessionMirror
-
Returns the current session ID.
- getId() - Method in class com.asakusafw.windgate.core.session.SessionMirror.Null
-
- getId() - Method in class com.asakusafw.workflow.model.basic.BasicBatchInfo
-
- getId() - Method in class com.asakusafw.workflow.model.basic.BasicJobflowInfo
-
- getId() - Method in interface com.asakusafw.workflow.model.BatchInfo
-
Returns the batch ID of this batch.
- getId() - Method in interface com.asakusafw.workflow.model.JobflowInfo
-
The flow ID of this jobflow.
- getId() - Method in class com.asakusafw.yaess.core.BatchScript
-
Returns the ID of this batch.
- getId() - Method in class com.asakusafw.yaess.core.CommandScript
-
- getId() - Method in interface com.asakusafw.yaess.core.ExecutionScript
-
Returns the ID of this script execution.
- getId() - Method in class com.asakusafw.yaess.core.FlowScript
-
Returns the ID of this flow.
- getId() - Method in class com.asakusafw.yaess.core.HadoopScript
-
- getId() - Method in class com.asakusafw.yaess.core.Job
-
Returns the ID of this job for other succeeding jobs.
- getId() - Method in class com.asakusafw.yaess.core.task.HandlerLifecycleJob
-
- getId() - Method in class com.asakusafw.yaess.core.task.ScriptJob
-
- getIdentifier() - Method in interface com.asakusafw.dmdl.source.DmdlSourceRepository.Cursor
-
Returns the identifier of the current resource.
- getIdentifier() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocSimpleName
-
Returns the identifier.
- getIdentity() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
Returns the original identity.
- getImage() - Method in class com.asakusafw.workflow.model.CommandToken
-
Returns the token image (for only text tokens).
- getImplementation() - Method in enum com.asakusafw.testdriver.core.PropertyType
-
Returns the implementation type of this type.
- getImplementationClass() - Method in class com.asakusafw.info.operator.UserOperatorSpec
-
Returns the implementation class.
- getImplementationClass(CharSequence) - Static method in class com.asakusafw.operator.Constants
-
Returns the implementation class name of target class with the specified name.
- getImplementing() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Declaration
-
Returns the implementation class.
- getImportDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
- getImportDeclarations() - Method in interface com.asakusafw.utils.java.model.syntax.CompilationUnit
-
Returns the import declarations.
- getImporterDescription() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
Returns the importer description of this input.
- getImporterPreparator(T) - Method in class com.asakusafw.testdriver.core.TestToolRepository
-
- getImporters() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns tasks in import phase.
- getImportKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ImportDeclarationImpl
-
- getImportKind() - Method in interface com.asakusafw.utils.java.model.syntax.ImportDeclaration
-
Returns the import kind.
- getIndex() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayAccessExpressionImpl
-
- getIndex() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayAccessExpression
-
Returns the index expression.
- getIndex() - Method in class com.asakusafw.utils.java.parser.javadoc.DefaultJavadocScanner
-
- getIndex() - Method in interface com.asakusafw.utils.java.parser.javadoc.JavadocScanner
-
- getInfo() - Method in class com.asakusafw.operator.model.OperatorDescription.SpecialReference
-
Return the operator specific information.
- getInitialization() - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
- getInitialization() - Method in interface com.asakusafw.utils.java.model.syntax.ForStatement
-
Returns the loop initialization part.
- getInitializer() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryResourceImpl
-
- getInitializer() - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
- getInitializer() - Method in interface com.asakusafw.utils.java.model.syntax.TryResource
-
Returns the resource expression.
- getInitializer() - Method in interface com.asakusafw.utils.java.model.syntax.VariableDeclarator
-
Returns the variable initializer expression.
- getInitializers() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns tasks in initialize phase.
- getInput(int) - Method in class com.asakusafw.info.graph.Node
-
Returns the input port of this node.
- getInput() - Method in enum com.asakusafw.runtime.io.text.driver.HeaderType
-
Returns the input.
- getInput(String) - Method in class com.asakusafw.vocabulary.flow.builder.FlowElementEditor
-
Returns an input port.
- getInput(String) - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementResolver
-
Returns the input port of the target flow element.
- getInputFiles() - Method in class com.asakusafw.runtime.directio.hadoop.StripedDataFormat.InputContext
-
Returns the input files information.
- getInputFormatClass() - Method in class com.asakusafw.info.hive.CustomStorageFormatInfo
-
Returns the input format class name.
- getInputPaths(JobContext) - Static method in class com.asakusafw.runtime.stage.input.TemporaryInputFormat
-
Returns input paths.
- getInputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
Returns input ports of this element.
- getInputPorts() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Returns the input ports of this element.
- getInputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getInputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getInputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getInputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getInputPorts() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getInputs() - Method in class com.asakusafw.info.cli.generate.ddl.HiveIoParameter
-
Returns the available Direct I/O Hive tables.
- getInputs() - Method in class com.asakusafw.info.directio.DirectFileIoAttribute
-
Returns the inputs.
- getInputs() - Method in class com.asakusafw.info.graph.Node
-
Returns the input ports of this node.
- getInputs() - Method in class com.asakusafw.info.hive.HiveIoAttribute
-
Returns the inputs.
- getInputs() - Method in class com.asakusafw.info.operator.view.OperatorView
-
Returns views of input ports.
- getInputs() - Method in class com.asakusafw.info.windgate.WindGateIoAttribute
-
Returns the inputs.
- getInputs() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns the input datasets.
- getInputs() - Method in class com.asakusafw.testdriver.compiler.basic.BasicJobflowMirror
-
- getInputs() - Method in interface com.asakusafw.testdriver.compiler.JobflowMirror
-
Returns the input ports of the jobflow.
- getInputSplitter() - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
Returns the input splitter of this format.
- getInputSplitter() - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
Returns the input splitter of this format.
- getInputSplitter() - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
Returns the input splitter of this format.
- getInputSplitter() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
Returns the input splitter of this format.
- getInputTransformerClass() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the input transformer class.
- getInspector() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getInspector() - Method in interface com.asakusafw.directio.hive.serde.ValueSerde
-
Returns an ObjectInspector
.
- getInspector() - Method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
- getInstance() - Static method in class com.asakusafw.directio.hive.orc.Compatibility
-
returns the compatibility instance for this environment.
- getInstance() - Static method in class com.asakusafw.directio.hive.parquet.Compatibility
-
returns the compatibility instance for this environment.
- getInstance() - Static method in class com.asakusafw.runtime.util.ByteArrayComparators
-
- getInterfaces(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- getInterfaces(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.ProjectionDriver
-
- getInterfaces(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.WritableDriver
-
- getInterfaces(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Returns the interface types to implement to the model.
- getInterfaceType() - Method in class com.asakusafw.runtime.core.legacy.LegacyReport.Initializer
-
- getInterfaceType() - Method in class com.asakusafw.runtime.core.legacy.RuntimeResource.DelegateRegisterer
-
Returns the interface type of the delegation object.
- getInterfaceType() - Method in enum com.asakusafw.utils.java.model.syntax.ModelKind
-
Returns the interface type of this model kind.
- getInternalInputPort(FlowElementPortDescription) - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
Returns the flow-inside input ports that individually corresponded to each flow-outside input port.
- getInternalName() - Method in class com.asakusafw.operator.description.ClassDescription
-
Returns the binary name.
- getInternalOutputPort(FlowElementPortDescription) - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
Returns the flow-inside outputs ports that individually corresponded to each flow-outside output port.
- getInType(CompileEnvironment, TypeMirror) - Static method in class com.asakusafw.operator.util.TypeHelper
-
Returns the type argument of In
type.
- getJapaneseName() - Method in enum com.asakusafw.testdriver.excel.legacy.ColumnMatchingCondition
-
Returns the Japanese name of this item.
- getJapaneseName() - Method in enum com.asakusafw.testdriver.excel.legacy.NullValueCondition
-
Returns the Japanese name of this item.
- getJapaneseName() - Method in enum com.asakusafw.testdriver.excel.legacy.RowMatchingCondition
-
Returns the Japanese name of this item.
- getJapaneseNames() - Static method in enum com.asakusafw.testdriver.excel.legacy.ColumnMatchingCondition
-
Returns the available Japanese names.
- getJapaneseNames() - Static method in enum com.asakusafw.testdriver.excel.legacy.NullValueCondition
-
Returns the available Japanese names.
- getJapaneseNames() - Static method in enum com.asakusafw.testdriver.excel.legacy.RowMatchingCondition
-
Returns the available Japanese names.
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getJavadoc() - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
- getJavadoc() - Method in interface com.asakusafw.utils.java.model.syntax.InitializerDeclaration
-
Returns the documentation comment.
- getJavadoc() - Method in interface com.asakusafw.utils.java.model.syntax.PackageDeclaration
-
Returns the documentation comment.
- getJavadoc() - Method in interface com.asakusafw.utils.java.model.syntax.TypeBodyDeclaration
-
Returns the documentation comment.
- getJavaFileForInput(JavaFileManager.Location, String, JavaFileObject.Kind) - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
- getJavaFileForOutput(JavaFileManager.Location, String, JavaFileObject.Kind, FileObject) - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
- getJavaRepresentation() - Method in enum com.asakusafw.utils.java.model.syntax.BasicTypeKind
-
Returns the reflection type (
Class
) of this kind.
- getJdbcSupport() - Method in class com.asakusafw.vocabulary.windgate.JdbcExporterDescription
-
- getJdbcSupport() - Method in class com.asakusafw.vocabulary.windgate.JdbcImporterDescription
-
- getJob() - Method in class com.asakusafw.yaess.basic.JobExecutor.Executing
-
Returns the target job.
- getJobExecutor() - Method in class com.asakusafw.yaess.basic.AbstractJobScheduler
-
- getJobExecutor() - Method in class com.asakusafw.yaess.basic.BasicJobScheduler
-
- getJobExecutor() - Method in class com.asakusafw.yaess.paralleljob.ParallelJobScheduler
-
- getJobflowExecutor(ExecutionContext) - Method in class com.asakusafw.workflow.cli.run.ExecutorParameter
-
Returns the jobflow executor.
- getJobflowLibraryName(String) - Static method in class com.asakusafw.testdriver.compiler.CompilerConstants
-
Returns the file name of the jobflow library.
- getJobflowLibraryPath(File, String) - Static method in class com.asakusafw.testdriver.compiler.CompilerConstants
-
Returns the path of the jobflow library path (from the batch directory).
- getJobFlowName(Class<? extends FlowDescription>) - Static method in class com.asakusafw.vocabulary.flow.FlowDescription
-
Returns the flow ID of the target jobflow class.
- getJobflowPackageLocation(String) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the path to the jobflow package (*.jar) deployment directory.
- getJobflows() - Method in class com.asakusafw.info.BatchInfo
-
Returns the jobflows.
- getJobflows() - Method in class com.asakusafw.info.cli.common.JobflowInfoParameter
-
Returns the target jobflows.
- getJobId() - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Returns the target job ID on current operation.
- getJobLabel() - Method in class com.asakusafw.yaess.core.Job
-
Returns the target job label.
- getJobLabel() - Method in class com.asakusafw.yaess.core.task.CleanupJob
-
- getJobLabel() - Method in class com.asakusafw.yaess.core.task.ScriptJob
-
- getJobLabel() - Method in class com.asakusafw.yaess.core.task.SetupJob
-
- getJobOutput(String) - Method in class com.asakusafw.yaess.core.PhaseMonitor
-
Returns an output stream for jobs.
- getJobs() - Method in class com.asakusafw.testdriver.TestExecutionPlan
-
Deprecated.
Returns tasks in main phase.
- getJsonFormat() - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
- getJulianDayNumber(Date) - Static method in class com.asakusafw.directio.hive.util.TemporalUtil
-
Returns the Julian day number of the date.
- getJulianDayNumber(DateTime) - Static method in class com.asakusafw.directio.hive.util.TemporalUtil
-
Returns the Julian day number of the date time.
- getKeepAliveInterval() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns keep-alive interval.
- getKey() - Method in class com.asakusafw.dmdl.directio.util.MapValue.Entry
-
Returns the key.
- getKey() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the key mirror of this node.
- getKey(T) - Method in class com.asakusafw.runtime.flow.ResultOutput
-
Returns a key for the value.
- getKey() - Method in class com.asakusafw.runtime.mapreduce.simple.ShuffleReader
-
- getKey(DataModelReflection) - Method in class com.asakusafw.testdriver.core.CompositeVerifyRule
-
- getKey(T) - Method in interface com.asakusafw.testdriver.core.ModelVerifier
-
Returns the key of the target data model.
- getKey(DataModelReflection) - Method in class com.asakusafw.testdriver.core.ModelVerifierDriver
-
- getKey(DataModelReflection) - Method in interface com.asakusafw.testdriver.core.VerifyRule
-
Returns the key of the target data model.
- getKey(DataModelReflection) - Method in class com.asakusafw.testdriver.rule.VerifyRuleInterpretor
-
- getKey() - Method in class com.asakusafw.vocabulary.flow.builder.EdgeInfo
-
Returns key information.
- getKeyClass() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter
-
Returns the target key class.
- getKeyClass() - Method in class com.asakusafw.runtime.stage.StageOutput
-
Returns the key class of this output.
- getKeyLength() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Returns the key length.
- getKeyOffset() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
- getKeys() - Method in class com.asakusafw.info.operator.InputGroup
-
Returns the keys.
- getKeyType() - Method in class com.asakusafw.info.hive.MapType
-
Returns the key type.
- getKeyword() - Method in enum com.asakusafw.operator.description.BasicTypeDescription.BasicTypeKind
-
Returns the keyword of this basic type.
- getKeyword() - Method in enum com.asakusafw.utils.java.model.syntax.BasicTypeKind
-
Returns the Java keyword of this type.
- getKeyword() - Method in enum com.asakusafw.utils.java.model.syntax.ModifierKind
-
Returns the keyword of this modifier.
- getKind(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
Returns the CSV field kind of the property.
- getKind(PropertyDeclaration, CsvFieldTrait.Kind) - Static method in class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
Returns the CSV field kind of the property.
- getKind(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the field kind of the property.
- getKind() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the field kind.
- getKind(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.line.driver.LineFieldTrait
-
Returns the CSV field kind of the property.
- getKind(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the field kind of the property.
- getKind() - Method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the field kind.
- getKind(PropertyDeclaration, TsvFieldTrait.Kind) - Static method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFieldTrait
-
Returns the TSV field kind of the property.
- getKind() - Method in class com.asakusafw.dmdl.model.AstLiteral
-
Returns the kind of this literal.
- getKind() - Method in interface com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceContainer
-
Returns the kind of this container.
- getKind() - Method in class com.asakusafw.dmdl.semantics.trait.MappingFactor
-
Returns the kind of mapping function.
- getKind() - Method in class com.asakusafw.dmdl.semantics.type.BasicType
-
Returns the kind of this type.
- getKind() - Method in class com.asakusafw.dmdl.semantics.type.CollectionType
-
Returns the collection kind of this type.
- getKind(PropertyDeclaration, CsvFieldTrait.Kind) - Static method in class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait
-
Returns the CSV field kind of the property.
- getKind() - Method in class com.asakusafw.info.value.AnnotationInfo
-
- getKind() - Method in class com.asakusafw.info.value.BooleanInfo
-
- getKind() - Method in class com.asakusafw.info.value.ByteInfo
-
- getKind() - Method in class com.asakusafw.info.value.CharInfo
-
- getKind() - Method in class com.asakusafw.info.value.ClassInfo
-
- getKind() - Method in class com.asakusafw.info.value.DoubleInfo
-
- getKind() - Method in class com.asakusafw.info.value.EnumInfo
-
- getKind() - Method in class com.asakusafw.info.value.FloatInfo
-
- getKind() - Method in class com.asakusafw.info.value.IntInfo
-
- getKind() - Method in class com.asakusafw.info.value.ListInfo
-
- getKind() - Method in class com.asakusafw.info.value.LongInfo
-
- getKind() - Method in class com.asakusafw.info.value.NullInfo
-
- getKind() - Method in class com.asakusafw.info.value.ShortInfo
-
- getKind() - Method in class com.asakusafw.info.value.StringInfo
-
- getKind() - Method in class com.asakusafw.info.value.UnknownInfo
-
- getKind() - Method in interface com.asakusafw.info.value.ValueInfo
-
Returns the type of this value.
- getKind() - Method in class com.asakusafw.operator.model.ConcreteDataModelMirror
-
- getKind() - Method in interface com.asakusafw.operator.model.DataModelMirror
-
Returns the kind of this data model.
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.Document
-
Returns the kind of this document.
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.ExternalDocument
-
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.MethodReference
-
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the kind of this node.
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.ParameterReference
-
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.Reference
-
Returns the kind of this reference.
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.ReferenceDocument
-
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.ReturnReference
-
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.SpecialReference
-
- getKind() - Method in class com.asakusafw.operator.model.OperatorDescription.TextDocument
-
- getKind() - Method in class com.asakusafw.operator.model.PartialDataModelMirror
-
- getKind() - Method in interface com.asakusafw.runtime.directio.FilePattern.PatternElement
-
Returns the kind of this element.
- getKind() - Method in class com.asakusafw.runtime.directio.FilePattern.Selection
-
- getKind() - Method in class com.asakusafw.runtime.directio.FilePattern.Variable
-
- getKind() - Method in class com.asakusafw.testdata.generator.excel.SheetFormat
-
Returns the kind of this format.
- getKind() - Method in class com.asakusafw.utils.java.internal.model.util.LiteralToken
-
Returns the literal kind.
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocArrayType
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBasicType
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBlock
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocComment
-
- getKind() - Method in interface com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElement
-
Returns the element kind.
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocField
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethod
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethodParameter
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocNamedType
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocQualifiedName
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocSimpleName
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocText
-
- getKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.JavadocToken
-
Returns the token kind.
- getKind() - Method in class com.asakusafw.vocabulary.attribute.ViewInfo
-
Returns the view kind.
- getKind() - Method in class com.asakusafw.vocabulary.flow.builder.Constant
-
- getKind() - Method in interface com.asakusafw.vocabulary.flow.builder.Data
-
Returns the kind of this data.
- getKind() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Returns the kind of this element.
- getKind() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getKind() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getKind() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getKind() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getKind() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getKind() - Method in class com.asakusafw.yaess.core.CommandScript
-
- getKind() - Method in interface com.asakusafw.yaess.core.ExecutionScript
-
Returns the kind of this script.
- getKind() - Method in class com.asakusafw.yaess.core.HadoopScript
-
- getKind() - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Returns the kind of this status.
- getLabel() - Method in class com.asakusafw.info.plan.PlanVertexSpec
-
Returns the label.
- getLabel() - Method in class com.asakusafw.operator.description.UnknownValueDescription
-
Returns the label for this description.
- getLabel() - Static method in class com.asakusafw.runtime.core.BatchRuntime
-
Returns the version label.
- getLabel() - Method in class com.asakusafw.utils.java.internal.model.syntax.LabeledStatementImpl
-
- getLabel() - Method in interface com.asakusafw.utils.java.model.syntax.LabeledStatement
-
Returns the documentation blocks.
- getLastModified() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileResourceFile
-
- getLastSegment() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedNameImpl
-
- getLastSegment() - Method in class com.asakusafw.utils.java.internal.model.syntax.SimpleNameImpl
-
- getLastSegment() - Method in interface com.asakusafw.utils.java.model.syntax.Name
-
Returns the simple name of this name.
- getLeftHandSide() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
- getLeftHandSide() - Method in interface com.asakusafw.utils.java.model.syntax.AssignmentExpression
-
Returns the left hand side term.
- getLeftOperand() - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
- getLeftOperand() - Method in interface com.asakusafw.utils.java.model.syntax.InfixExpression
-
Returns the left term.
- getLength() - Method in class com.asakusafw.info.hive.SequenceType
-
Returns the element length.
- getLength() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.BridgeInputSplit
-
- getLength() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullInputSplit
-
- getLength() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
- getLength() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrLocation
-
Returns the character length.
- getLessInputAction() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the error action type for less input fields.
- getLibrariesPackageLocation(String) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the path to the external libraries (*.jar) deployment directory.
- getLibrariesPath() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the path to the dependency libraries path.
- getLineNumber() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Returns the current line number (1-origin).
- getLineNumber() - Method in interface com.asakusafw.runtime.io.json.JsonInput
-
Returns the number of line where the last input starts.
- getLineNumber() - Method in class com.asakusafw.runtime.io.line.BasicLineInput
-
- getLineNumber() - Method in class com.asakusafw.runtime.io.line.LineInput
-
Returns the number of lines which this object has read.
- getLineNumber() - Method in class com.asakusafw.runtime.io.line.Utf8LineInput
-
- getLineNumber() - Method in interface com.asakusafw.runtime.io.text.TextInput
-
Returns the number of line where the last input starts.
- getLineSeparator() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Returns the line separator.
- getLineSeparator() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the line separator.
- getLineSeparator() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
Returns the line separator character.
- getLiteralKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LiteralImpl
-
- getLiteralKind() - Method in interface com.asakusafw.utils.java.model.syntax.Literal
-
Returns the literal kind.
- getLocale() - Method in class com.asakusafw.dmdl.java.Configuration
-
Returns the locale information to generate programs.
- getLocalFileSystem() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the local file system for the this datastore.
- getLocalFileSystemClassName() - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Returns the implementation class name of LocalFileSystem
.
- getLocalTemporaryDirectory(LocalFileSystem) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Returns the local temporary directory.
- getLocation() - Method in class com.asakusafw.info.cli.generate.ddl.HiveIoParameter.TableLocationInfo
-
Returns the location.
- getLocation() - Method in class com.asakusafw.info.hive.HiveInputInfo
-
- getLocation() - Method in class com.asakusafw.info.hive.HiveOutputInfo
-
- getLocation() - Method in interface com.asakusafw.info.hive.HivePortInfo
-
Returns the location information.
- getLocation() - Method in interface com.asakusafw.info.hive.syntax.HiveCreateTable
-
Returns the target table location.
- getLocation() - Method in class com.asakusafw.info.hive.syntax.SimpleCreateTable
-
- getLocation() - Method in class com.asakusafw.operator.model.OperatorDescription.ParameterReference
-
Returns the location of parameter (0-origin).
- getLocation() - Method in class com.asakusafw.runtime.stage.StageResource
-
Returns the path expression for the resources.
- getLocation() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.AbstractIrDocElement
-
- getLocation() - Method in interface com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElement
-
Returns the location where this element appears.
- getLocation() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.JavadocToken
-
Returns the location of this token.
- getLocation() - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockInfo
-
Returns the location where this block was appeared.
- getLocation() - Method in exception com.asakusafw.utils.java.parser.javadoc.JavadocParseException
-
Returns the occurrence location.
- getLocations() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.BridgeInputSplit
-
- getLocations() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullInputSplit
-
- getLocations() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
- getLockFile() - Method in class com.asakusafw.runtime.util.lock.LocalFileLockObject
-
Returns the local lock file.
- getLocks() - Method in class com.asakusafw.yaess.core.YaessProfile
-
Returns a lock provider.
- getLogFile(ExecutionContext) - Method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Returns abstract path for the target log file.
- getLowerLimitSize() - Method in interface com.asakusafw.runtime.io.util.InputSplitter
-
Returns the lower limit of split size.
- getMainClassName() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the main class name for the target job.
- getMalformedInputAction() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the malformed input action.
- getMalformedInputAction() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the error action of malformed inputs.
- getMalformedInputAction() - Method in class com.asakusafw.runtime.io.line.LineConfiguration
-
Returns the action type for malformed inputs.
- getMapPairSeparator() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
Returns the map key terminator character.
- getMapperClass() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
Returns the mapper class for handling this.
- getMapperClass() - Method in class com.asakusafw.runtime.stage.StageInput
-
Returns the mapper class for handling this input.
- getMappings() - Method in class com.asakusafw.dmdl.semantics.trait.ReduceTerm
-
Returns mapping/folding factors in this term.
- getMaterializeSchema() - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelMaterializer
-
Returns the schema which this materializer is required.
- getMaterializeSchema() - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelMaterializer
-
Returns the schema which this materializer is required.
- getMaxProcesses() - Method in class com.asakusafw.windgate.core.CoreProfile
-
the number of max threads in core gate processes.
- getMemberAnnotations(EmitContext, PropertyDeclaration) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelEmitter
-
- getMemberAnnotations(EmitContext, PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- getMemberAnnotations(EmitContext, PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Returns the type annotations to attach to the property.
- getMemberAnnotations(EmitContext, PropertyReferenceDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Returns the type annotations to attach to the reference.
- getMemberName(String) - Method in class com.asakusafw.operator.CompileEnvironment
-
Returns the normalized member name.
- getMembers() - Method in class com.asakusafw.info.hive.StructType
-
Returns the members.
- getMessage() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssertStatementImpl
-
- getMessage() - Method in interface com.asakusafw.utils.java.model.syntax.AssertStatement
-
Returns the assertion expression.
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.cli.WindGateCliLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.core.WindGateCoreLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.core.WindGateLogger
-
Returns the message corrensponded to the code.
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.file.session.FileSessionLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.jdbc.JdbcLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.retryable.RetryableProcessLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.windgate.stream.WindGateStreamLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.basic.YaessBasicLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.bootstrap.YaessBootstrapLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.core.YaessCoreLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.core.YaessLogger
-
Returns the message corrensponded to the code.
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.flowlog.YaessFlowLogLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.jobqueue.YaessJobQueueLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.jsch.YaessJschLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.multidispatch.YaessMultiDispatchLogger
-
- getMessage(String, Object...) - Method in class com.asakusafw.yaess.paralleljob.YaessParallelJobLogger
-
- getMethod() - Method in class com.asakusafw.operator.OperatorDriver.Context
-
Returns the target operator method.
- getMethodName() - Method in class com.asakusafw.info.operator.UserOperatorSpec
-
Returns the operator method name.
- getMethodName() - Method in class com.asakusafw.operator.description.ObjectDescription
-
Returns the factory method name.
- getMethods(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- getMethods(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.ObjectDriver
-
- getMethods(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.StringPropertyDriver
-
- getMethods(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.WritableDriver
-
- getMethods(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Returns the method declarations to mixin to the model.
- getMinimumFragmentSize() - Method in interface com.asakusafw.runtime.directio.FragmentableDataFormat
-
Returns the lower limit of fragment size (in bytes).
- getMinimumFragmentSize(FragmentableDataFormat<?>) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the minimum fragment size.
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the minimum fragment size.
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormatAdapter
-
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.StripedDataFormat.InputContext
-
Returns the minimum fragment size.
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
- getMinimumFragmentSize() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- getMinute() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the minute of this date time.
- getMissingInputAction() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the missing input action.
- getMode() - Method in class com.asakusafw.trace.model.TraceSetting
-
Returns the trigger mode.
- getModelClass() - Method in class com.asakusafw.runtime.io.ModelIoFactory
-
Returns the target data model class.
- getModelClass() - Method in interface com.asakusafw.testdriver.core.DataModelDefinition
-
Returns the corresponded data model class.
- getModelClass() - Method in class com.asakusafw.testdriver.model.DefaultDataModelDefinition
-
- getModelClass() - Method in class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
- getModelClassName() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns the data model class name.
- getModelClassName() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns the data model class name.
- getModelClassName() - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Returns the data model class name.
- getModelClassName() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns the data model class name.
- getModelFactory() - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns Java DOM factory in use.
- getModelFactory() - Static method in class com.asakusafw.utils.java.model.util.Models
-
Returns a basic Java DOM factory.
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.AlternateConstructorInvocationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayAccessExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayInitializerImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayTypeImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssertStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.BasicTypeImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.BlockCommentImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.BlockImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.BreakStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.CastExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.CatchClauseImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassBodyImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassLiteralImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorReferenceExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ContinueStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocBlockImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocFieldImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodParameterImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocTextImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.DoStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.EmptyStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ExpressionStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldAccessExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ImportDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.InstanceofExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.JavadocImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LabeledStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LambdaExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LineCommentImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LiteralImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalClassDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.MarkerAnnotationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ModifierImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.NamedTypeImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.NormalAnnotationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ParameterizedTypeImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ParenthesizedExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.PostfixExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedNameImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedTypeImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ReturnStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SimpleNameImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SingleElementAnnotationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.StatementExpressionListImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchCaseLabelImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchDefaultLabelImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.SynchronizedStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ThisImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ThrowStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryResourceImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.TypeParameterDeclarationImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.UnaryExpressionImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.UnionTypeImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.WhileStatementImpl
-
- getModelKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.WildcardImpl
-
- getModelKind() - Method in interface com.asakusafw.utils.java.model.syntax.Model
-
Returns the model kind.
- getModelType() - Method in class com.asakusafw.testdriver.DriverInputBase
-
Returns the data type of this port.
- getModelType() - Method in interface com.asakusafw.vocabulary.external.ExporterDescription
-
Returns the data model class of exporting data.
- getModelType() - Method in interface com.asakusafw.vocabulary.external.ImporterDescription
-
Returns the data model class of importing data.
- getModifierKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.ModifierImpl
-
- getModifierKind() - Method in interface com.asakusafw.utils.java.model.syntax.Modifier
-
Returns the modifier kind.
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
- getModifiers() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getModifiers() - Method in interface com.asakusafw.utils.java.model.syntax.FormalParameterDeclaration
-
Returns the modifiers and annotations.
- getModifiers() - Method in interface com.asakusafw.utils.java.model.syntax.LocalVariableDeclaration
-
Returns the modifiers and annotations.
- getModifiers() - Method in interface com.asakusafw.utils.java.model.syntax.TypeBodyDeclaration
-
Returns the modifiers and annotations.
- getModuleName() - Method in class com.asakusafw.info.task.TaskInfo
-
Returns the module name.
- getModuleName() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
Returns the target module name.
- getModuleName() - Method in class com.asakusafw.workflow.model.basic.BasicCommandTaskInfo
-
- getModuleName() - Method in class com.asakusafw.workflow.model.basic.BasicDeleteTaskInfo
-
- getModuleName() - Method in class com.asakusafw.workflow.model.basic.BasicHadoopTaskInfo
-
- getModuleName() - Method in interface com.asakusafw.workflow.model.CommandTaskInfo
-
- getModuleName() - Method in interface com.asakusafw.workflow.model.HadoopTaskInfo
-
- getModuleName() - Method in interface com.asakusafw.workflow.model.TaskInfo
-
Returns the task module name.
- getModuleName() - Method in class com.asakusafw.yaess.core.CommandScript
-
Returns a module name of target command.
- getMonitors() - Method in class com.asakusafw.yaess.core.YaessProfile
-
Returns a monitor provider.
- getMonth() - Method in class com.asakusafw.runtime.value.Date
-
Returns the month of this date.
- getMonth() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the month of this date and time.
- getMonthOfYear(int, boolean) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed days from beginning of the year to the corresponding month.
- getMoreInputAction() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the error action type for extra input fields.
- getName(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the field name of the property.
- getName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the field name.
- getName(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the field name of the property.
- getName() - Method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the field name.
- getName() - Method in interface com.asakusafw.dmdl.semantics.Declaration
-
Returns the name of this declared element.
- getName() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
- getName() - Method in class com.asakusafw.dmdl.semantics.ModelSymbol
-
- getName() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
- getName() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
- getName() - Method in class com.asakusafw.dmdl.semantics.PropertySymbol
-
- getName() - Method in interface com.asakusafw.dmdl.semantics.Symbol
-
Returns the name of this symbol.
- getName() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcColumnTrait
-
Returns the column name.
- getName() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcTableTrait
-
Returns the table name.
- getName() - Method in class com.asakusafw.info.directio.DirectFilePortInfo
-
Returns the port name.
- getName() - Method in class com.asakusafw.info.hive.ColumnInfo
-
Returns the column name.
- getName() - Method in class com.asakusafw.info.hive.HiveInputInfo
-
- getName() - Method in class com.asakusafw.info.hive.HiveOutputInfo
-
- getName() - Method in interface com.asakusafw.info.hive.HivePortInfo
-
Returns the port name.
- getName() - Method in class com.asakusafw.info.hive.SerdeRowFormatInfo
-
Returns the serde name.
- getName() - Method in class com.asakusafw.info.hive.TableInfo
-
Returns the table name.
- getName() - Method in class com.asakusafw.info.operator.InputAttribute
-
- getName() - Method in class com.asakusafw.info.operator.InputGroup.Order
-
Returns the name.
- getName() - Method in interface com.asakusafw.info.operator.InputInfo
-
Returns the port name.
- getName() - Method in class com.asakusafw.info.operator.InputOperatorSpec
-
- getName() - Method in interface com.asakusafw.info.operator.NamedOperatorSpec
-
Returns the name of this operator.
- getName() - Method in class com.asakusafw.info.operator.OutputAttribute
-
- getName() - Method in interface com.asakusafw.info.operator.OutputInfo
-
Returns the port name.
- getName() - Method in class com.asakusafw.info.operator.OutputOperatorSpec
-
- getName() - Method in class com.asakusafw.info.operator.ParameterInfo
-
Returns the parameter name.
- getName() - Method in class com.asakusafw.info.operator.view.InputView
-
- getName() - Method in class com.asakusafw.info.operator.view.OutputView
-
- getName() - Method in class com.asakusafw.info.ParameterInfo
-
Returns the name.
- getName() - Method in class com.asakusafw.info.plan.PlanInputSpec
-
- getName() - Method in class com.asakusafw.info.plan.PlanOutputSpec
-
- getName() - Method in class com.asakusafw.info.plan.PlanVertexSpec
-
- getName() - Method in class com.asakusafw.info.value.ClassInfo
-
Returns the name.
- getName() - Method in class com.asakusafw.info.value.EnumInfo
-
Returns the name.
- getName() - Method in class com.asakusafw.info.windgate.WindGatePortInfo
-
Returns the port name.
- getName() - Method in class com.asakusafw.operator.description.ClassDescription
-
Returns the binary name.
- getName() - Method in class com.asakusafw.operator.description.EnumConstantDescription
-
Returns the constant name.
- getName() - Method in class com.asakusafw.operator.model.ExternMirror
-
Returns the extern name.
- getName() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the name of this node.
- getName() - Method in class com.asakusafw.operator.model.PropertyMirror
-
Returns the name of this property.
- getName() - Method in class com.asakusafw.runtime.directio.FilePattern.Variable
-
Returns the name of this variable.
- getName() - Method in class com.asakusafw.runtime.io.json.PropertyDefinition
-
Returns the name.
- getName() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns the field name.
- getName() - Method in class com.asakusafw.runtime.model.PropertyInfo
-
Returns the property name in snake_case
.
- getName() - Method in class com.asakusafw.runtime.stage.StageOutput
-
Returns the simple name of this output.
- getName() - Method in class com.asakusafw.runtime.stage.StageResource
-
Returns the resource name.
- getName() - Method in class com.asakusafw.testdata.generator.excel.SheetFormat
-
Returns the name of this sheet.
- getName() - Method in class com.asakusafw.testdriver.compiler.basic.BasicPortMirror
-
- getName() - Method in interface com.asakusafw.testdriver.compiler.CompilerToolkit
-
Returns the toolkit name.
- getName() - Method in interface com.asakusafw.testdriver.compiler.PortMirror
-
Returns the port name.
- getName() - Method in class com.asakusafw.testdriver.DriverInputBase
-
Returns the name of this port.
- getName() - Method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem
-
Returns the cell name.
- getName() - Method in class com.asakusafw.testdriver.rule.VerifyRuleBuilder.Property
-
Returns the name of this property.
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocFieldImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodParameterImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldAccessExpressionImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.ImportDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.NamedTypeImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.TypeParameterDeclarationImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
- getName() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMember
-
Returns the member name.
- getName() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethodParameter
-
Returns the parameter name.
- getName() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocNamedType
-
Returns the type name.
- getName() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocQualifiedName
-
Returns the simple name.
- getName() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileResourceFile
-
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.AnnotationElement
-
Returns the annotation element name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.AnnotationElementDeclaration
-
Returns the annotation element name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.DocField
-
Returns the field name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.DocMethod
-
Returns the target method or constructor name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.DocMethodParameter
-
Returns the parameter name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.EnumConstantDeclaration
-
Returns the enum constant name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.FieldAccessExpression
-
Returns the field name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.FormalParameterDeclaration
-
Returns the parameter name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.ImportDeclaration
-
Returns the import target type or member name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.LambdaParameter
-
Returns the parameter name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.MethodInvocationExpression
-
Returns the target method name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorDeclaration
-
Returns the target method or constructor name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.MethodReferenceExpression
-
Returns the target method name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.NamedType
-
Returns the type name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.PackageDeclaration
-
Returns the target package name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.SimpleName
-
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.TypeDeclaration
-
Returns the simple type name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.TypeParameterDeclaration
-
Returns the type variable name.
- getName() - Method in interface com.asakusafw.utils.java.model.syntax.VariableDeclarator
-
Returns the variable name.
- getName() - Method in class com.asakusafw.vocabulary.batch.JobFlowWorkDescription
-
- getName() - Method in class com.asakusafw.vocabulary.batch.ScriptWorkDescription
-
Deprecated.
- getName() - Method in class com.asakusafw.vocabulary.batch.WorkDescription
-
Returns the identifier of this work.
- getName() - Method in class com.asakusafw.vocabulary.flow.builder.DataInfo
-
Returns the target name.
- getName() - Method in class com.asakusafw.vocabulary.flow.builder.EdgeInfo
-
Returns the edge name.
- getName() - Method in class com.asakusafw.vocabulary.flow.builder.ExternInfo
-
Returns the external port name.
- getName() - Method in class com.asakusafw.vocabulary.flow.builder.PortInfo
-
Returns the port name.
- getName() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Returns the name of this element.
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPortDescription
-
Returns the port name.
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription.Parameter
-
Returns the parameter name.
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Declaration
-
Returns the operator method name.
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Parameter
-
Returns the parameter name.
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorHelper
-
Returns the name of the operator helper method.
- getName() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getName() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getName() - Method in class com.asakusafw.windgate.core.GateProfile
-
The name of this profile (for hint).
- getName() - Method in class com.asakusafw.windgate.core.GateScript
-
Return the name of this script (for hint).
- getName() - Method in class com.asakusafw.windgate.core.process.ProcessProfile
-
Returns this name.
- getName() - Method in class com.asakusafw.windgate.core.ProcessScript
-
Returns the name of this process.
- getName() - Method in class com.asakusafw.windgate.core.resource.ResourceManipulator
-
Returns the name of this resource.
- getName() - Method in class com.asakusafw.windgate.core.resource.ResourceMirror
-
Returns the name of this resource.
- getName() - Method in class com.asakusafw.windgate.core.resource.ResourceProfile
-
Returns this name.
- getName() - Method in class com.asakusafw.windgate.file.resource.FileResourceManipulator
-
- getName() - Method in class com.asakusafw.windgate.file.resource.FileResourceMirror
-
- getName() - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsMirror
-
- getName() - Method in class com.asakusafw.windgate.hadoopfs.ssh.AbstractSshHadoopFsMirror
-
- getName() - Method in class com.asakusafw.windgate.jdbc.JdbcResourceManipulator
-
- getName() - Method in class com.asakusafw.windgate.jdbc.JdbcResourceMirror
-
- getName() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
Returns the name of original process.
- getName() - Method in class com.asakusafw.windgate.stream.file.FileResourceManipulator
-
- getName() - Method in class com.asakusafw.windgate.stream.file.FileResourceMirror
-
- getName() - Method in class com.asakusafw.workflow.model.attribute.ParameterInfo
-
Returns the name.
- getName() - Method in class com.asakusafw.yaess.basic.BasicExtension
-
- getName() - Method in class com.asakusafw.yaess.bootstrap.ExtendedArgument
-
Returns the name.
- getName() - Method in interface com.asakusafw.yaess.core.Extension
-
Returns the extension name.
- getNamespace() - Method in class com.asakusafw.dmdl.semantics.trait.NamespaceTrait
-
Returns the specified namespace.
- getNaturalTypeInfo(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the natural type information for the property.
- getNode() - Method in interface com.asakusafw.utils.graph.Graph.Vertex
-
Returns the vertex value.
- getNodeSet() - Method in interface com.asakusafw.utils.graph.Graph
-
Returns the all vertices in this graph.
- getNodeSet() - Method in class com.asakusafw.utils.graph.HashGraph
-
- getNullFormat() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the string representation of null
.
- getNullFormat() - Method in class com.asakusafw.runtime.io.text.value.ValueOptionFieldAdapter.BuilderBase
-
Returns the sequence which represents NULL
field.
- getNullStyle() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the null style.
- getNullSymbol() - Method in class com.asakusafw.info.hive.DelimitedRowFormatInfo
-
Returns the null
character.
- getNumberFormat() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the string representation of numbers.
- getNumberOfFields() - Method in class com.asakusafw.runtime.io.text.driver.RecordDefinition
-
Returns the number of fields in this record.
- getObject() - Method in class com.asakusafw.info.value.AnnotationInfo
-
- getObject() - Method in class com.asakusafw.info.value.BooleanInfo
-
- getObject() - Method in class com.asakusafw.info.value.ByteInfo
-
- getObject() - Method in class com.asakusafw.info.value.CharInfo
-
- getObject() - Method in class com.asakusafw.info.value.ClassInfo
-
- getObject() - Method in class com.asakusafw.info.value.DoubleInfo
-
- getObject() - Method in class com.asakusafw.info.value.EnumInfo
-
- getObject() - Method in class com.asakusafw.info.value.FloatInfo
-
- getObject() - Method in class com.asakusafw.info.value.IntInfo
-
- getObject() - Method in class com.asakusafw.info.value.ListInfo
-
- getObject() - Method in class com.asakusafw.info.value.LongInfo
-
- getObject() - Method in class com.asakusafw.info.value.NullInfo
-
- getObject() - Method in interface com.asakusafw.info.value.NumberInfo
-
- getObject() - Method in class com.asakusafw.info.value.ShortInfo
-
- getObject() - Method in class com.asakusafw.info.value.StringInfo
-
- getObject() - Method in class com.asakusafw.info.value.UnknownInfo
-
- getObject() - Method in interface com.asakusafw.info.value.ValueInfo
-
- getObject() - Method in interface com.asakusafw.runtime.io.util.Union
-
Returns the current object in union.
- getObject() - Method in class com.asakusafw.runtime.io.util.WritableRawComparableUnion
-
- getObject() - Method in class com.asakusafw.runtime.io.util.WritableUnion
-
- getOffset() - Method in class com.asakusafw.runtime.directio.DirectInputFragment
-
Returns the byte offset of this fragment.
- getOnIncompatibleType() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the exception handling strategy for incompatible field type.
- getOnIncompatibleType() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the exception handling strategy for incompatible field type.
- getOnIncompatibleType() - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Returns the exception handling strategy for incompatible field type.
- getOnMalformedInput() - Method in class com.asakusafw.runtime.io.json.PropertyDefinition
-
Returns the error action kind of malformed input for this property.
- getOnMalformedInput() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns the error action for malformed inputs.
- getOnMissingInput() - Method in class com.asakusafw.runtime.io.json.PropertyDefinition
-
Returns the error action kind of missing this property.
- getOnMissingSource() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the exception handling strategy for missing source fields.
- getOnMissingSource() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the exception handling strategy for missing source fields.
- getOnMissingSource() - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Returns the exception handling strategy for missing source fields.
- getOnMissingTarget() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the exception handling strategy for missing target fields.
- getOnMissingTarget() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the exception handling strategy for missing target fields.
- getOnMissingTarget() - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Returns the exception handling strategy for missing target fields.
- getOnUnmappableOutput() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns the error action for un-mappable outputs.
- getOperand() - Method in class com.asakusafw.utils.java.internal.model.syntax.PostfixExpressionImpl
-
- getOperand() - Method in class com.asakusafw.utils.java.internal.model.syntax.UnaryExpressionImpl
-
- getOperand() - Method in interface com.asakusafw.utils.java.model.syntax.PostfixExpression
-
Returns the operand term.
- getOperand() - Method in interface com.asakusafw.utils.java.model.syntax.UnaryExpression
-
Returns the operand term.
- getOperationId() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the job operation ID which this client will invoke.
- getOperator() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
- getOperator() - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
- getOperator() - Method in class com.asakusafw.utils.java.internal.model.syntax.PostfixExpressionImpl
-
- getOperator() - Method in class com.asakusafw.utils.java.internal.model.syntax.UnaryExpressionImpl
-
- getOperator() - Method in interface com.asakusafw.utils.java.model.syntax.AssignmentExpression
-
Returns the simple assignment operator, or an infix operator for compound assignment expression.
- getOperator() - Method in interface com.asakusafw.utils.java.model.syntax.InfixExpression
-
Returns the infix operator.
- getOperator() - Method in interface com.asakusafw.utils.java.model.syntax.PostfixExpression
-
Returns the postfix operator.
- getOperator() - Method in interface com.asakusafw.utils.java.model.syntax.UnaryExpression
-
Returns the unary operator.
- getOperator() - Method in enum com.asakusafw.vocabulary.attribute.ViewInfo.Direction
-
Returns the direction operator.
- getOperatorClassName() - Method in class com.asakusafw.trace.model.Tracepoint
-
Returns the target operator class name.
- getOperatorDrivers() - Method in class com.asakusafw.operator.CompileEnvironment
-
Returns registered operator drivers.
- getOperatorKind() - Method in class com.asakusafw.info.operator.CoreOperatorSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.operator.CustomOperatorSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.operator.FlowOperatorSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.operator.InputOperatorSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.operator.MarkerOperatorSpec
-
- getOperatorKind() - Method in interface com.asakusafw.info.operator.OperatorSpec
-
Returns the kind of this operator.
- getOperatorKind() - Method in class com.asakusafw.info.operator.OutputOperatorSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.operator.UserOperatorSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.plan.PlanInputSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.plan.PlanOutputSpec
-
- getOperatorKind() - Method in class com.asakusafw.info.plan.PlanVertexSpec
-
- getOperatorMap(OperatorSpec.OperatorKind) - Method in class com.asakusafw.info.operator.view.OperatorGraphView
-
Returns the element operators.
- getOperatorMethodName() - Method in class com.asakusafw.trace.model.Tracepoint
-
Returns the target operator method name.
- getOperators() - Method in class com.asakusafw.info.operator.view.OperatorGraphView
-
Returns the element operators.
- getOperators(OperatorSpec.OperatorKind) - Method in class com.asakusafw.info.operator.view.OperatorGraphView
-
Returns the element operators.
- getOpposites() - Method in class com.asakusafw.info.graph.Input
-
- getOpposites() - Method in class com.asakusafw.info.graph.Output
-
- getOpposites() - Method in class com.asakusafw.info.graph.Port
-
Returns the connected opposites.
- getOpposites() - Method in class com.asakusafw.info.operator.view.InputView
-
Returns the opposite ports.
- getOpposites() - Method in class com.asakusafw.info.operator.view.OutputView
-
Returns the opposite ports.
- getOpposites() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementInput
-
Returns the opposite ports of this.
- getOpposites() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementOutput
-
Returns the opposite ports of this.
- getOptimizations() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Returns the optimizations.
- getOptimizeLevel() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getOptimizeLevel() - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns the optimize level.
- getOptional() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns whether the target input is optional or not.
- getOptionGetterName(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded option getter name.
- getOptionNames(Collection<? extends CompileEnvironment.Support>) - Static method in class com.asakusafw.operator.CompilerOption
-
Returns the available option names.
- getOptions() - Method in class com.asakusafw.info.cli.generate.dot.DotParameter
-
Returns the graph options.
- getOptions() - Method in class com.asakusafw.runtime.io.text.driver.BasicFieldOutput
-
- getOptions() - Method in interface com.asakusafw.runtime.io.text.driver.FieldOutput
-
Returns the options of this output.
- getOptions() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getOptions() - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns the options.
- getOptions() - Static method in enum com.asakusafw.testdriver.excel.NullityConditionKind
-
Returns options as text.
- getOptions() - Static method in enum com.asakusafw.testdriver.excel.TotalConditionKind
-
Returns options as text.
- getOptions() - Static method in enum com.asakusafw.testdriver.excel.ValueConditionKind
-
Returns options as text.
- getOptions() - Method in class com.asakusafw.vocabulary.windgate.JdbcExporterDescription
-
Returns WindGate JDBC export options.
- getOptions() - Method in class com.asakusafw.vocabulary.windgate.JdbcImporterDescription
-
Returns WindGate JDBC import options.
- getOptions() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
Returns the WindGate JDBC options.
- getOptionSetterName(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded option setter name.
- getOrder() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns the view of order expression list.
- getOrder() - Method in class com.asakusafw.info.directio.DirectFileOutputInfo
-
Returns the record order.
- getOrder() - Method in class com.asakusafw.info.operator.InputGroup
-
Returns the order.
- getOrder() - Method in class com.asakusafw.operator.model.KeyMirror
-
Returns the ordering key list.
- getOrder() - Method in class com.asakusafw.vocabulary.directio.DirectFileOutputDescription
-
Returns record order in each output file.
- getOrdering() - Method in class com.asakusafw.vocabulary.attribute.ViewInfo
-
Returns the sort expression in each group.
- getOrderings() - Method in class com.asakusafw.vocabulary.flow.graph.ShuffleKey
-
Returns ordering information.
- getOrderObject() - Method in class com.asakusafw.runtime.io.util.ShuffleKey
-
Returns an object for ordering.
- getOrdinal() - Method in class com.asakusafw.runtime.model.PropertyInfo
-
Returns the 0-origin property ordinal.
- getOrigin() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Returns the original description.
- getOrigin() - Method in class com.asakusafw.vocabulary.flow.graph.FlowGraph
-
Returns the original flow graph object.
- getOrigin() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getOrigin() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getOrigin() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getOrigin() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getOrigin() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getOriginal() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.hive.common.BaseTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFieldTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFieldTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait
-
- getOriginalAst() - Method in interface com.asakusafw.dmdl.semantics.Element
-
Returns the corresponded syntactic element of this.
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.ModelSymbol
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.PropertySymbol
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.JoinTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.MappingFactor
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.NamespaceTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.ProjectionsTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.ReduceTerm
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.ReferencesTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.trait.SummarizeTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.type.BasicType
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.semantics.type.CollectionType
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcColumnTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcTableTrait
-
- getOriginalAst() - Method in class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportTrait
-
- getOriginalStderr() - Static method in class com.asakusafw.windgate.hadoopfs.ssh.StdioHelper
-
Returns original standard error output.
- getOriginalStdin() - Static method in class com.asakusafw.windgate.hadoopfs.ssh.StdioHelper
-
Returns original standard input.
- getOriginalStdout() - Static method in class com.asakusafw.windgate.hadoopfs.ssh.StdioHelper
-
Returns original standard output.
- getOsUser() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the current user name in OS.
- getOutput() - Method in class com.asakusafw.dmdl.java.Configuration
-
Returns the Java DOM emitter.
- getOutput(int) - Method in class com.asakusafw.info.graph.Node
-
Returns the output port of this node.
- getOutput() - Method in enum com.asakusafw.runtime.io.text.driver.HeaderType
-
Returns the output.
- getOutput(String) - Method in class com.asakusafw.vocabulary.flow.builder.FlowElementEditor
-
Returns an output port.
- getOutput(String) - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementResolver
-
Returns the output port of the target flow element.
- getOutput() - Method in interface com.asakusafw.yaess.core.ExecutionMonitor
-
Returns output stream for extra information.
- getOutput() - Method in class com.asakusafw.yaess.core.JobMonitor
-
- getOutput() - Method in class com.asakusafw.yaess.core.PhaseMonitor
-
- getOutputCommitter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.BridgeOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.StageOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.TemporaryOutputFormat
-
- getOutputFormatClass() - Method in class com.asakusafw.info.hive.CustomStorageFormatInfo
-
Returns the output format class name.
- getOutputId() - Method in class com.asakusafw.runtime.directio.OutputAttemptContext
-
Returns the output ID corresponding to this output.
- getOutputId() - Method in class com.asakusafw.runtime.directio.OutputTransactionContext
-
Returns the output ID corresponding to this output.
- getOutputName() - Method in class com.asakusafw.runtime.stage.collector.SlotDirectMapper
-
Returns the output name.
- getOutputName() - Method in class com.asakusafw.runtime.stage.preparator.PreparatorMapper
-
Returns the output name.
- getOutputNames() - Method in class com.asakusafw.runtime.stage.collector.SlotSorter
-
Returns the array of names for each slot.
- getOutputOptions() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns the output options.
- getOutputPath(JobContext) - Static method in class com.asakusafw.runtime.stage.output.TemporaryOutputFormat
-
Returns the output path.
- getOutputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElement
-
Returns input ports of this element.
- getOutputPorts() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Returns the output ports of this element.
- getOutputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getOutputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getOutputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getOutputPorts() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getOutputPorts() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getOutputs() - Method in class com.asakusafw.info.cli.generate.ddl.HiveIoParameter
-
Returns the available Direct I/O Hive tables.
- getOutputs() - Method in class com.asakusafw.info.directio.DirectFileIoAttribute
-
Returns the outputs.
- getOutputs() - Method in class com.asakusafw.info.graph.Node
-
Returns the output ports of this node.
- getOutputs() - Method in class com.asakusafw.info.hive.HiveIoAttribute
-
Returns the outputs.
- getOutputs() - Method in class com.asakusafw.info.operator.view.OperatorView
-
Returns views of output ports.
- getOutputs() - Method in class com.asakusafw.info.windgate.WindGateIoAttribute
-
Returns the outputs.
- getOutputs() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns the output datasets.
- getOutputs() - Method in class com.asakusafw.testdriver.compiler.basic.BasicJobflowMirror
-
- getOutputs() - Method in interface com.asakusafw.testdriver.compiler.JobflowMirror
-
Returns the output ports of the jobflow.
- getOutputTransformerClass() - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Returns the output transformer class.
- getOutType(CompileEnvironment, TypeMirror) - Static method in class com.asakusafw.operator.util.TypeHelper
-
Returns the type argument of Out
type.
- getOwner() - Method in interface com.asakusafw.dmdl.semantics.MemberDeclaration
-
Returns owner of this member.
- getOwner() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
- getOwner() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
- getOwner() - Method in class com.asakusafw.dmdl.semantics.PropertySymbol
-
Returns owner of this property.
- getOwner() - Method in class com.asakusafw.info.operator.view.InputView
-
Returns the owner of this port.
- getOwner() - Method in class com.asakusafw.info.operator.view.OutputView
-
Returns the owner of this port.
- getOwner() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPort
-
Returns the owner of this port.
- getOwnerNodeNames() - Method in class com.asakusafw.runtime.directio.DirectInputFragment
-
Returns the node names of this owners.
- getOwnerType() - Method in enum com.asakusafw.utils.java.model.syntax.PropertyKind
-
Returns the interface type of the property owner.
- getPackageDeclaration() - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
- getPackageDeclaration() - Method in interface com.asakusafw.utils.java.model.syntax.CompilationUnit
-
Returns the package declaration.
- getPackageDeclaration() - Method in class com.asakusafw.utils.java.model.util.ImportBuilder
-
Returns the package declaration of this builder.
- getPackageName() - Method in class com.asakusafw.operator.description.ClassDescription
-
Returns package name of the class.
- getPageSize() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter.Options
-
Returns in-memory sort buffer size.
- getPairs() - Method in class com.asakusafw.windgate.core.ParameterList
-
Returns parameters as key value pairs.
- getParameter(String) - Method in class com.asakusafw.operator.util.JavadocHelper
-
Returns the parameter document elements.
- getParameter() - Method in class com.asakusafw.utils.java.internal.model.syntax.CatchClauseImpl
-
- getParameter() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
- getParameter() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryResourceImpl
-
- getParameter() - Method in interface com.asakusafw.utils.java.model.syntax.CatchClause
-
Returns the exception parameter.
- getParameter() - Method in interface com.asakusafw.utils.java.model.syntax.EnhancedForStatement
-
Returns the loop variable declaration.
- getParameter() - Method in interface com.asakusafw.utils.java.model.syntax.TryResource
-
Returns the resource variable declaration.
- getParameterIndex() - Method in class com.asakusafw.vocabulary.flow.builder.EdgeInfo
-
Returns the index where this appears in the target parameters.
- getParameterNames() - Method in class com.asakusafw.windgate.core.DriverScript
-
Returns the required parameter names.
- getParameters() - Method in class com.asakusafw.info.operator.OperatorAttribute
-
- getParameters() - Method in interface com.asakusafw.info.operator.OperatorInfo
-
Returns the parameters.
- getParameters() - Method in class com.asakusafw.info.operator.view.OperatorView
-
- getParameters() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns the parameters, which include input datasets and arguments.
- getParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.LambdaExpressionImpl
-
- getParameters() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethod
-
Returns the method or constructor parameters.
- getParameters() - Method in interface com.asakusafw.utils.java.model.syntax.LambdaExpression
-
Returns the lambda parameters.
- getParameters() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
Returns the parameters for this flow-part.
- getParameters() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
Returns information of the user parameters.
- getParameterTypes() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Declaration
-
Returns the erased parameter types of the operator method.
- getParameterTypes() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorHelper
-
Returns the erased parameter types of the operator helper method.
- getParent() - Method in interface com.asakusafw.info.graph.Element
-
Returns the parent element of this.
- getParent() - Method in class com.asakusafw.info.graph.Node
-
- getParent() - Method in class com.asakusafw.info.graph.Port
-
- getParent() - Method in class com.asakusafw.info.graph.Wire
-
- getPartial() - Method in class com.asakusafw.iterative.common.basic.BasicParameterTable
-
- getPartial() - Method in interface com.asakusafw.iterative.common.ParameterTable
-
Returns the partial parameter names in this set.
- getPartition(ShuffleKey, Object, int) - Method in class com.asakusafw.runtime.io.util.ShuffleKey.Partitioner
-
- getPartition(SortableSlot, Object, int) - Method in class com.asakusafw.runtime.stage.collector.SortableSlot.Partitioner
-
- getPartitionerClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the partitioner class.
- getPassPhrase() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
- getPassPhrase() - Method in class com.asakusafw.yaess.jsch.JschProcessExecutor
-
Returns a pass phrase for private key.
- getPath() - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Returns path.
- getPath() - Method in class com.asakusafw.info.cli.common.ApplicationBaseDirectoryParameter
-
Returns the path.
- getPath() - Method in class com.asakusafw.info.cli.common.BatchInfoParameter
-
Returns the information file path.
- getPath() - Method in class com.asakusafw.operation.tools.directio.common.ConfigurationParameter
-
Returns the configuration path.
- getPath() - Method in class com.asakusafw.operation.tools.directio.DataSourceInfo
-
Returns the data source path.
- getPath() - Method in class com.asakusafw.runtime.directio.DirectDataSourceProfile
-
Returns the path of the target data source is mapped on.
- getPath() - Method in interface com.asakusafw.runtime.directio.DirectDataSourceProvider
-
Returns the container path of this data source.
- getPath() - Method in class com.asakusafw.runtime.directio.DirectInputFragment
-
Returns the path to this fragment.
- getPath() - Method in class com.asakusafw.runtime.directio.ResourceInfo
-
Returns the real path.
- getPath() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Return the path to the target file.
- getPath() - Method in class com.asakusafw.runtime.io.csv.CsvParser
-
Returns the parsing target path.
- getPath() - Method in class com.asakusafw.runtime.io.line.BasicLineInput
-
- getPath() - Method in class com.asakusafw.runtime.io.line.LineInput
-
Returns the parsing target path.
- getPath() - Method in class com.asakusafw.runtime.io.line.Utf8LineInput
-
- getPath() - Method in class com.asakusafw.vocabulary.windgate.FsExporterDescription
-
Returns the path of the export target (relative path from resource.local.basePath
in the profile).
- getPath() - Method in class com.asakusafw.vocabulary.windgate.FsImporterDescription
-
Returns the path of the import target (relative path from resource.local.basePath
in the profile).
- getPath() - Method in class com.asakusafw.workflow.model.basic.BasicDeleteTaskInfo
-
- getPath() - Method in interface com.asakusafw.workflow.model.DeleteTaskInfo
-
Returns the path expression of the target files.
- getPathKind() - Method in class com.asakusafw.workflow.model.basic.BasicDeleteTaskInfo
-
- getPathKind() - Method in interface com.asakusafw.workflow.model.DeleteTaskInfo
-
Returns the path kind.
- getPathSegmentSeparator() - Method in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
Returns the path segment separator.
- getPathString() - Method in class com.asakusafw.operation.tools.directio.BasePath
-
Returns the path string.
- getPathString() - Method in class com.asakusafw.runtime.stage.StageInput
-
Returns the path expression for the input.
- getPattern() - Method in class com.asakusafw.info.ParameterInfo
-
Returns the parameter value pattern in regular expression.
- getPattern() - Method in class com.asakusafw.workflow.model.attribute.ParameterInfo
-
Returns the parameter value pattern in regular expression.
- getPatternElementKinds() - Method in class com.asakusafw.runtime.directio.FilePattern
-
Returns the pattern element kinds appeared in this pattern.
- getPatternString() - Method in class com.asakusafw.runtime.directio.FilePattern
-
Returns a string which represents this pattern.
- getPhase() - Method in class com.asakusafw.info.task.TaskInfo
-
Returns the phase.
- getPhase() - Method in class com.asakusafw.yaess.core.ExecutionContext
-
Returns current execution phase.
- getPhase() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the phase kind for target job.
- getPhases() - Method in class com.asakusafw.info.task.TaskListAttribute
-
Returns the available phases.
- getPluginPath(Path) - Static method in class com.asakusafw.windgate.bootstrap.WindGateConstants
-
Returns the WindGate plug-in files.
- getPollingInterval() - Method in class com.asakusafw.yaess.jobqueue.JobClientProfile
-
Returns the polling interval.
- getPort() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Return the target port.
- getPort() - Method in class com.asakusafw.yaess.jsch.JschProcessExecutor
-
Returns the remote port number.
- getPortKind() - Method in class com.asakusafw.trace.model.Tracepoint
-
Returns the target port kind.
- getPortName() - Method in class com.asakusafw.trace.model.Tracepoint
-
Returns the target port name.
- getPosition() - Method in class com.asakusafw.runtime.io.util.BufferedFileInput
-
Returns the current file position in bytes.
- getPosition() - Method in class com.asakusafw.runtime.io.util.BufferedFileOutput
-
Returns the current file position in bytes.
- getPosition() - Method in interface com.asakusafw.runtime.io.util.Union
-
Returns the current position in union.
- getPosition() - Method in class com.asakusafw.runtime.io.util.WritableRawComparableUnion
-
- getPosition() - Method in class com.asakusafw.runtime.io.util.WritableUnion
-
- getPositionInBlock() - Method in class com.asakusafw.runtime.stage.temporary.TemporaryFileInput
-
Returns the byte position in current block.
- getPrecision() - Method in class com.asakusafw.info.hive.DecimalType
-
Returns the precision.
- getPredicates() - Method in enum com.asakusafw.testdriver.excel.TotalConditionKind
-
Returns predicates corresponded to this.
- getPreferredFragmentSize() - Method in interface com.asakusafw.runtime.directio.FragmentableDataFormat
-
Returns the preferred fragment size (in bytes).
- getPreferredFragmentSize(FragmentableDataFormat<?>) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the preferred fragment size.
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the preferred fragment size.
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormatAdapter
-
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.directio.hadoop.StripedDataFormat.InputContext
-
Returns the preferred fragment size.
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.io.csv.directio.AbstractCsvStreamFormat
-
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.io.json.directio.AbstractJsonStreamFormat
-
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.io.line.directio.AbstractLineStreamFormat
-
- getPreferredFragmentSize() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- getPreferredSize() - Method in interface com.asakusafw.runtime.io.util.InputSplitter
-
Returns the preferred split size.
- getPrefix() - Method in class com.asakusafw.yaess.core.ServiceProfile
-
Returns the key prefix of this profile.
- getPrefix() - Method in class com.asakusafw.yaess.jobqueue.JobClientProfile
-
Returns the current namespace.
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.BooleanOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.ByteOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.CharStringOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.DateOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.DateTimeOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.DecimalOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.DoubleOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.FloatOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.IntOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.LongOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.ShortOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.StringOptionInspector
-
- getPrimitiveJavaObject(Object) - Method in class com.asakusafw.directio.hive.serde.VarcharStringOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.BooleanOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.ByteOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.CharStringOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.DateOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.DateTimeOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.DecimalOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.DoubleOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.FloatOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.IntOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.LongOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.ShortOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.StringOptionInspector
-
- getPrimitiveWritableObject(Object) - Method in class com.asakusafw.directio.hive.serde.VarcharStringOptionInspector
-
- getPriority() - Method in class com.asakusafw.directio.hive.orc.Compatibility
-
returns the priority of this compatibility layer.
- getPriority() - Method in class com.asakusafw.directio.hive.orc.v1.CompatibilityV1
-
- getPriority() - Method in class com.asakusafw.directio.hive.orc.v2.CompatibilityV2
-
- getPriority() - Method in class com.asakusafw.directio.hive.parquet.Compatibility
-
returns the priority of this compatibility layer.
- getPriority() - Method in class com.asakusafw.directio.hive.parquet.v1.CompatibilityV1
-
- getPriority() - Method in class com.asakusafw.directio.hive.parquet.v2.CompatibilityV2
-
- getPrivateKey() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Return the path to the private key file.
- getPrivateKey() - Method in class com.asakusafw.yaess.jsch.JschProcessExecutor
-
Returns the path to the private key file.
- getProcesses() - Method in class com.asakusafw.windgate.core.GateProfile
-
Returns the process segment of this profile.
- getProcesses() - Method in class com.asakusafw.windgate.core.GateScript
-
Returns the member processes.
- getProcessingEnvironment() - Method in class com.asakusafw.operator.CompileEnvironment
-
Returns the current processing environment.
- getProcessType() - Method in class com.asakusafw.windgate.core.ProcessScript
-
Returns the kind of this process.
- getProfileName() - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Returns the profile name.
- getProfileName() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns the profile name.
- getProfileName() - Method in class com.asakusafw.info.task.TaskInfo
-
Returns the profile name.
- getProfileName() - Method in class com.asakusafw.info.windgate.WindGatePortInfo
-
Returns the profile name.
- getProfileName() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
Returns the target profile name.
- getProfileName() - Method in class com.asakusafw.vocabulary.batch.ScriptWorkDescription
-
Deprecated.
Returns the profile name.
- getProfileName() - Method in interface com.asakusafw.vocabulary.windgate.WindGateProcessDescription
-
Returns the WindGate profile name to be used.
- getProfileName() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the profile name.
- getProfileName() - Method in class com.asakusafw.workflow.model.basic.BasicCommandTaskInfo
-
- getProfileName() - Method in interface com.asakusafw.workflow.model.CommandTaskInfo
-
Returns the target profile name.
- getProfileName() - Method in class com.asakusafw.yaess.core.CommandScript
-
Returns the profile name to execute this command.
- getProfileUri(Path, String) - Static method in class com.asakusafw.windgate.bootstrap.WindGateConstants
-
Returns the profile path.
- getProgress() - Method in class com.asakusafw.runtime.mapreduce.simple.ShuffleReader
-
- getProgress() - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullRecordReader
-
- getProgress() - Method in class com.asakusafw.runtime.stage.input.StageInputRecordReader
-
- getProjections() - Method in class com.asakusafw.dmdl.semantics.trait.ProjectionsTrait
-
Returns owned projective models.
- getProperties() - Method in class com.asakusafw.info.hive.SerdeRowFormatInfo
-
Returns the serde properties.
- getProperties() - Method in class com.asakusafw.info.hive.TableInfo
-
Returns the table properties.
- getProperties() - Method in interface com.asakusafw.testdriver.core.DataModelDefinition
-
returns the all public property names.
- getProperties() - Method in class com.asakusafw.testdriver.model.DefaultDataModelDefinition
-
- getProperties() - Method in class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
- getProperties() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Job
-
Deprecated.
Returns the extra Hadoop properties.
- getProperties() - Method in enum com.asakusafw.utils.java.model.syntax.ModelKind
-
Returns property kinds in this model kind.
- getProperties(ExecutionContext, ExecutionScript) - Method in interface com.asakusafw.yaess.core.ExecutionScriptHandler
-
Returns desired system/hadoop properties to execute scripts using this handler.
- getProperties(ExecutionContext, ExecutionScript) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
Returns desired system/hadoop properties to execute scripts using this handler.
- getProperties() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the Hadoop properties map for the target job.
- getProperties(ExecutionContext, ExecutionScript) - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- getProperty() - Method in class com.asakusafw.operator.model.KeyMirror.Group
-
Returns the target property.
- getProperty() - Method in class com.asakusafw.operator.model.KeyMirror.Order
-
Returns the target property.
- getProperty() - Method in class com.asakusafw.vocabulary.flow.graph.ShuffleKey.Order
-
Returns the property name of ordering key.
- getPropertyDescriptors() - Method in class com.asakusafw.directio.hive.serde.DataModelDescriptor
-
Returns the property descriptors in the target data model.
- getPropertyKind() - Method in class com.asakusafw.dmdl.model.AstPropertyDefinition
-
Returns the inferred kind of this property definition.
- getPropertyName() - Method in class com.asakusafw.testdriver.rule.PropertyCondition
-
Returns the target property name.
- getPropertyName() - Method in enum com.asakusafw.utils.java.model.syntax.PropertyKind
-
Returns the name of this property.
- getPropertyName() - Method in class com.asakusafw.vocabulary.attribute.ViewInfo.Ordering
-
Returns the property name.
- getPropertySettings() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatTrait
-
Returns the property settings.
- getProviderClass() - Method in class com.asakusafw.windgate.core.BaseProfile
-
Returns the class of corresponded provider.
- getProviderClass() - Method in class com.asakusafw.windgate.core.process.ProcessProfile
-
- getProviderClass() - Method in class com.asakusafw.windgate.core.resource.ResourceProfile
-
- getProviderClass() - Method in class com.asakusafw.windgate.core.session.SessionProfile
-
- getPutCommand() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the put command.
- getQualifiedName() - Method in class com.asakusafw.info.hive.ArrayType
-
- getQualifiedName() - Method in class com.asakusafw.info.hive.DecimalType
-
- getQualifiedName() - Method in interface com.asakusafw.info.hive.FieldType
-
Returns the qualified type name.
- getQualifiedName() - Method in class com.asakusafw.info.hive.MapType
-
- getQualifiedName() - Method in class com.asakusafw.info.hive.PlainType
-
- getQualifiedName() - Method in class com.asakusafw.info.hive.SequenceType
-
- getQualifiedName() - Method in class com.asakusafw.info.hive.StructType
-
- getQualifiedName() - Method in class com.asakusafw.info.hive.UnionType
-
- getQualifiedTypeName() - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the qualified name of processing type.
- getQualifiedTypeName(ModelSymbol) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the simple name of the target data model class.
- getQualifier() - Method in interface com.asakusafw.dmdl.model.AstName
-
Returns the qualifier of this name.
- getQualifier() - Method in class com.asakusafw.dmdl.model.AstQualifiedName
-
- getQualifier() - Method in class com.asakusafw.dmdl.model.AstSimpleName
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorReferenceExpressionImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldAccessExpressionImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedNameImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedTypeImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.model.syntax.ThisImpl
-
- getQualifier() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocQualifiedName
-
Returns the name qualifier.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.ClassInstanceCreationExpression
-
Returns the qualifier expression.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.ConstructorReferenceExpression
-
Returns the owner type.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.FieldAccessExpression
-
Returns the qualifier expression.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.Keyword
-
Returns the type qualifier.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.MethodInvocationExpression
-
Returns the qualifier expression or type.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorReferenceExpression
-
Returns the qualifier expression or type.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.QualifiedName
-
Returns the name qualifier.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.QualifiedType
-
Returns the type qualifier.
- getQualifier() - Method in interface com.asakusafw.utils.java.model.syntax.SuperConstructorInvocation
-
Returns the qualifier expression.
- getQuoteSettings() - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextTrait
-
Returns the quote settings.
- getQuoteStrategy(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait
-
Returns the quoting strategy for the CSV field property.
- getQuoteStrategy(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait
-
Returns the quoting strategy for the CSV field property.
- getQuoteStyle() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the quote style.
- getRange() - Method in enum com.asakusafw.utils.java.model.syntax.ImportKind
-
Returns the import scope kind.
- getReadLimit() - Method in class com.asakusafw.runtime.io.util.DataBuffer
-
Returns the reading limit position in this buffer.
- getReadPosition() - Method in class com.asakusafw.runtime.io.util.DataBuffer
-
Returns the reading position in this buffer.
- getReadRemaining() - Method in class com.asakusafw.runtime.io.util.DataBuffer
-
Returns the data length in this buffer.
- getReason() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Return the reason of this status.
- getReason() - Method in class com.asakusafw.runtime.io.text.UnmappableOutput
-
Returns the textual reason of this error.
- getReason() - Method in exception com.asakusafw.windgate.core.session.SessionException
-
Returns the reason of this exception.
- getRecordCount() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter
-
Returns the total record count.
- getRecordDefinition() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- getRecordIndex() - Method in interface com.asakusafw.runtime.io.json.JsonInput
-
Returns the record index of the last input.
- getRecordIndex() - Method in class com.asakusafw.runtime.io.text.csv.CsvFieldReader
-
- getRecordIndex() - Method in interface com.asakusafw.runtime.io.text.FieldReader
-
Returns the record index of the current field.
- getRecordIndex() - Method in class com.asakusafw.runtime.io.text.tabular.TabularFieldReader
-
- getRecordIndex() - Method in interface com.asakusafw.runtime.io.text.TextInput
-
Returns the record index of the last input.
- getRecordLineNumber() - Method in class com.asakusafw.runtime.io.text.csv.CsvFieldReader
-
- getRecordLineNumber() - Method in interface com.asakusafw.runtime.io.text.FieldReader
-
Returns the number of line where the current RECORD starts.
- getRecordLineNumber() - Method in class com.asakusafw.runtime.io.text.tabular.TabularFieldReader
-
- getRecordNumber() - Method in class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Returns the current record number (1-origin).
- getRecordWriter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.BridgeOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.EmptyFileOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.StageOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.TemporaryOutputFormat
-
- getReducerClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the reducer class.
- getReference() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
Returns the reference.
- getReference() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the reference to original component.
- getReference() - Method in class com.asakusafw.operator.model.OperatorDescription.ReferenceDocument
-
Returns the reference which represents the document location in original method declaration.
- getReferenceGetterName(PropertyReferenceDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded reference getter name.
- getReferences() - Method in class com.asakusafw.dmdl.semantics.trait.ReferencesTrait
-
Returns referred models.
- getReflectiveObject() - Method in enum com.asakusafw.operator.description.BasicTypeDescription.BasicTypeKind
-
Returns the reflective object.
- getRegion() - Method in class com.asakusafw.dmdl.model.AstAttribute
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstAttributeElement
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstAttributeValueArray
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstAttributeValueMap
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstBasicType
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstCollectionType
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstDescription
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstGrouping
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstJoin
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstLiteral
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstModelDefinition
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstModelFolding
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstModelMapping
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstModelReference
-
- getRegion() - Method in interface com.asakusafw.dmdl.model.AstNode
-
Returns the region of this node.
- getRegion() - Method in class com.asakusafw.dmdl.model.AstPropertyDefinition
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstPropertyFolding
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstPropertyMapping
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstQualifiedName
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstRecordDefinition
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstReferenceType
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstScript
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstSequenceType
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstSimpleName
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstSummarize
-
- getRegion() - Method in class com.asakusafw.dmdl.model.AstUnionExpression
-
- getRelatedDataSource(String) - Method in class com.asakusafw.runtime.directio.DirectDataSourceRepository
-
Returns a data source which related to the specified path.
- getRelatedId(String) - Method in class com.asakusafw.runtime.directio.DirectDataSourceRepository
-
Returns an ID which related to the specified path.
- getRendezvous(KEY) - Method in class com.asakusafw.runtime.flow.SegmentedCombiner
-
Returns the
Rendezvous
object for processing the target segment.
- getRendezvous(KEYIN) - Method in class com.asakusafw.runtime.flow.SegmentedReducer
-
Returns the
Rendezvous
object for processing the target segment.
- getRepository() - Method in class com.asakusafw.operation.tools.directio.file.DataSourceParameter
-
Returns the repository.
- getRepository() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the test tool repository.
- getRepresentation() - Method in enum com.asakusafw.testdriver.core.PropertyType
-
Returns the representation of this type in Java.
- getRepresentation() - Method in enum com.asakusafw.utils.java.model.syntax.WildcardBoundKind
-
Returns the keyword.
- getResourceId(ExecutionContext, ExecutionScript) - Method in interface com.asakusafw.yaess.core.ExecutionScriptHandler
-
Returns the ID of a resource which is used for executing this handler.
- getResourceId(ExecutionContext, ExecutionScript) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
Returns the ID of a resource which is used for executing this handler.
- getResourceId(ExecutionContext) - Method in class com.asakusafw.yaess.core.Job
-
Returns the resource ID which this job requires in execution.
- getResourceId(ExecutionContext) - Method in class com.asakusafw.yaess.core.task.HandlerLifecycleJob
-
- getResourceId(ExecutionContext) - Method in class com.asakusafw.yaess.core.task.ScriptJob
-
- getResourceId(ExecutionContext, ExecutionScript) - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- getResourceName() - Method in class com.asakusafw.info.windgate.WindGatePortInfo
-
Returns the resource name.
- getResourceName() - Method in class com.asakusafw.windgate.core.DriverScript
-
Returns the name of target resource.
- getResourceName() - Method in class com.asakusafw.windgate.hadoopfs.HadoopFsProfile
-
Returns the resource name.
- getResourceName() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the resource name.
- getResourceName() - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Returns the resource name.
- getResourceName() - Method in class com.asakusafw.windgate.stream.file.FileProfile
-
Returns the resource name.
- getResourcePattern() - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Returns the resource pattern.
- getResourcePattern() - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Returns the resource pattern.
- getResourcePattern() - Method in class com.asakusafw.info.directio.DirectFilePortInfo
-
Returns the resource pattern.
- getResourcePattern() - Method in class com.asakusafw.info.hive.LocationInfo
-
Returns the resource/output pattern.
- getResourcePattern() - Method in class com.asakusafw.operation.tools.directio.DirectIoPath
-
Returns the resource pattern.
- getResourcePattern() - Method in class com.asakusafw.vocabulary.directio.DirectFileInputDescription
-
Returns the resource path pattern of target input.
- getResourcePattern() - Method in class com.asakusafw.vocabulary.directio.DirectFileOutputDescription
-
Returns the resource path pattern of target output.
- getResources() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
- getResources() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
Returns the generated resource files.
- getResources() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileCompiler
-
Returns the resource files which are generated by this compiler.
- getResources() - Method in interface com.asakusafw.utils.java.model.syntax.TryStatement
-
Returns the resource statements.
- getResources() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Returns the external resources of this element.
- getResources() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- getResources() - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- getResources() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- getResources() - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- getResources() - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- getResources() - Method in class com.asakusafw.windgate.core.GateProfile
-
Returns the resource segment of this profile.
- getResults() - Method in class com.asakusafw.runtime.testing.MockResult
-
Returns the previously
added
objects.
- getResultSink(String) - Method in class com.asakusafw.runtime.stage.output.StageOutputDriver
-
Returns the result sink object with the specified name.
- getResultSink() - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Returns the result data sink for this output.
- getRetryCount() - Method in class com.asakusafw.windgate.retryable.RetryableProcessProfile
-
Returns the max retry count.
- getRetryInterval() - Method in class com.asakusafw.windgate.retryable.RetryableProcessProfile
-
Returns the retry interval.
- getReturnType() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getReturnType() - Method in interface com.asakusafw.utils.java.model.syntax.MethodDeclaration
-
Returns the return type.
- getRightHandSide() - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
- getRightHandSide() - Method in interface com.asakusafw.utils.java.model.syntax.AssignmentExpression
-
Returns the right hand side term.
- getRightOperand() - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
- getRightOperand() - Method in interface com.asakusafw.utils.java.model.syntax.InfixExpression
-
Returns the right term.
- getRollforwardThreads() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the number of threads to move staged files to committed area.
- getRoot() - Method in class com.asakusafw.info.operator.OperatorGraphAttribute
-
Returns the root node.
- getRoot() - Method in class com.asakusafw.info.operator.view.OperatorGraphView
-
Returns the root node.
- getRoot() - Method in class com.asakusafw.info.plan.PlanAttribute
-
Returns the root node.
- getRootConverter() - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelMaterializer
-
- getRootConverter() - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelMaterializer
-
- getRow() - Method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem
-
Returns the row number.
- getRowCount() - Method in class com.asakusafw.iterative.common.basic.BasicParameterTable
-
- getRowCount() - Method in interface com.asakusafw.iterative.common.ParameterTable
-
Returns the number of rows in this table.
- getRowFormat() - Method in class com.asakusafw.info.hive.TableInfo
-
Returns the table row format.
- getRowIndex() - Method in enum com.asakusafw.testdriver.excel.RuleSheetFormat
-
Returns the row index where this kind assigned in a sheet.
- getRows() - Method in class com.asakusafw.iterative.common.basic.BasicParameterTable
-
- getRows() - Method in interface com.asakusafw.iterative.common.ParameterTable
-
Returns all rows in this table.
- getRuntimeEnvironmentVersion() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the runtime environment version.
- getRuntimeVersion() - Static method in class com.asakusafw.runtime.core.context.RuntimeContext
-
Returns the current runtime version.
- getRuntimeWorkingDirectory() - Static method in class com.asakusafw.testdriver.compiler.CompilerConstants
-
Returns the path to the runtime working directory.
- getScale() - Method in class com.asakusafw.info.hive.DecimalType
-
Returns the scale.
- getScheduler() - Method in class com.asakusafw.yaess.core.YaessProfile
-
Returns a job scheduler.
- getSchema() - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
- getSchema() - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
- getSchema() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getSchema() - Method in class com.asakusafw.info.hive.HiveInputInfo
-
- getSchema() - Method in class com.asakusafw.info.hive.HiveOutputInfo
-
- getSchema() - Method in interface com.asakusafw.info.hive.HivePortInfo
-
Returns the schema information.
- getSchema() - Method in interface com.asakusafw.info.hive.TableInfo.Provider
-
- getScriptPath() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the script path.
- getScripts() - Method in class com.asakusafw.yaess.core.FlowScript
-
- getSecond() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the second of this date time.
- getSecondFromCalendar(Calendar) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the date and time as the number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
.
- getSecondFromDate(Date) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the date and time as the number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
.
- getSecondFromTime(int, int, int) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the time as the number of elapsed seconds from 00:00:00
.
- getSecondOfDay(long) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
to
the number of elapsed seconds from beginning of the corresponding date.
- getSegmentId() - Method in interface com.asakusafw.runtime.flow.SegmentedWritable
-
Returns the segment ID of this object.
- getSegments() - Method in class com.asakusafw.operation.tools.directio.BasePath
-
Returns the path segments.
- getSegments() - Method in class com.asakusafw.operator.model.JavaName
-
Returns name segments as lower case characters.
- getSegments() - Method in class com.asakusafw.runtime.directio.FilePattern
-
Returns segments of this pattern.
- getSelf() - Method in class com.asakusafw.vocabulary.flow.builder.DataInfo
-
- getSelf() - Method in class com.asakusafw.vocabulary.flow.builder.EdgeInfo
-
Returns this.
- getSelf() - Method in class com.asakusafw.vocabulary.flow.builder.PortInfo
-
- getSemantics() - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the root semantics model.
- getSeparatorChar() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Returns the field separator character.
- getSequence() - Method in enum com.asakusafw.runtime.io.json.LineSeparator
-
Returns the line separator sequence.
- getSequence() - Method in enum com.asakusafw.runtime.io.text.LineSeparator
-
Returns the line separator sequence.
- getSequence() - Method in class com.asakusafw.runtime.io.text.UnmappableOutput
-
Returns the erroneous sequence.
- getSequences() - Method in class com.asakusafw.dmdl.directio.text.EscapeSettings
-
Returns the escape sequence map.
- getServiceClass() - Method in class com.asakusafw.yaess.core.ServiceProfile
-
Returns the service class.
- getServiceClassLoader() - Method in class com.asakusafw.dmdl.java.Configuration
-
Returns the service class loader.
- getServiceLabel() - Method in class com.asakusafw.yaess.core.Job
-
Returns the service label which actually executes this job.
- getServiceLabel() - Method in class com.asakusafw.yaess.core.task.CleanupJob
-
- getServiceLabel() - Method in class com.asakusafw.yaess.core.task.ScriptJob
-
- getServiceLabel() - Method in class com.asakusafw.yaess.core.task.SetupJob
-
- getSession() - Method in class com.asakusafw.windgate.core.GateProfile
-
Returns the session segment of this profile.
- getSessionId() - Method in exception com.asakusafw.windgate.core.session.SessionException
-
Returns the target session ID.
- getSessionKind() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the session kind.
- getSettings(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the field settings of the property.
- getSettings() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait
-
Returns the settings.
- getSettings(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the field settings of the property.
- getSettings() - Method in class com.asakusafw.dmdl.directio.text.TextFieldTrait
-
Returns the settings.
- getSheets() - Method in enum com.asakusafw.testdata.generator.excel.WorkbookFormat
-
Returns the format of each sheet.
- getShuffleKey() - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementPortDescription
-
Returns information of the shuffle operation which will performs on this port.
- getShuffleKeyClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the shuffle key class.
- getShuffleValueClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the shuffle value class.
- getSideDataInputs() - Method in interface com.asakusafw.vocabulary.flow.graph.FlowResourceDescription
-
Returns the descriptions of source inputs.
- getSimpleName() - Method in interface com.asakusafw.dmdl.model.AstName
-
Returns the simple name of this name.
- getSimpleName() - Method in class com.asakusafw.dmdl.model.AstQualifiedName
-
- getSimpleName() - Method in class com.asakusafw.dmdl.model.AstSimpleName
-
- getSimpleName() - Method in class com.asakusafw.info.value.ClassInfo
-
Returns the class simple name.
- getSimpleName() - Method in class com.asakusafw.operator.description.ClassDescription
-
Returns the class simple name.
- getSimpleName() - Method in class com.asakusafw.operator.model.ConcreteDataModelMirror
-
- getSimpleName() - Method in interface com.asakusafw.operator.model.DataModelMirror
-
Returns the simple name of this data model.
- getSimpleName() - Method in class com.asakusafw.operator.model.PartialDataModelMirror
-
- getSimpleName() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedNameImpl
-
- getSimpleName() - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedTypeImpl
-
- getSimpleName() - Method in interface com.asakusafw.utils.java.model.syntax.QualifiedName
-
Returns the simple name on the tail.
- getSimpleName() - Method in interface com.asakusafw.utils.java.model.syntax.QualifiedType
-
Returns the simple type name.
- getSize() - Method in class com.asakusafw.runtime.directio.DirectInputFragment
-
Returns the byte length of this fragment.
- getSize() - Method in class com.asakusafw.runtime.io.util.BufferedFileInput
-
Returns the file size in bytes.
- getSize() - Method in class com.asakusafw.runtime.io.util.BufferedFileOutput
-
Returns the file size in bytes.
- getSize() - Method in class com.asakusafw.yaess.basic.FileBlob
-
- getSize() - Method in interface com.asakusafw.yaess.core.Blob
-
Returns the object size in bytes.
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.io.util.InvertOrder
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.io.util.NullWritableRawComparable
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.io.util.ShuffleKey
-
- getSizeInBytes(byte[], int) - Method in interface com.asakusafw.runtime.io.util.WritableRawComparable
-
Computes and returns size in bytes.
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableTuple
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableUnion
-
- getSizeInBytes() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter
-
Returns the total size in bytes.
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.stage.directio.StringTemplate
-
Computes and returns size in bytes.
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.BooleanOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.ByteOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.DateOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.DateTimeOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.DecimalOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.DoubleOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.FloatOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.IntOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.LongOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.ShortOption
-
- getSizeInBytes(byte[], int) - Method in class com.asakusafw.runtime.value.StringOption
-
- getSkipEmptyInput() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns whether or not skips empty input field.
- getSkipEmptyInput() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns whether or not this skips empty inputs.
- getSliceLength() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Returns the slice length.
- getSliceOffset() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Returns the slice offset in #getBytes()
.
- getSlot() - Method in class com.asakusafw.runtime.stage.collector.SortableSlot
-
Returns the current slot number.
- getSortComparatorClassOrNull() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the sort comparator class (for shuffle keys).
- getSource() - Method in class com.asakusafw.dmdl.java.Configuration
-
Returns DMDL source repository.
- getSource() - Method in class com.asakusafw.dmdl.semantics.trait.MappingFactor
-
Returns the source property.
- getSource() - Method in class com.asakusafw.dmdl.semantics.trait.ReduceTerm
-
Returns a symbol of source model.
- getSource() - Method in class com.asakusafw.info.graph.Wire
-
Returns the source output.
- getSource() - Method in class com.asakusafw.operation.tools.directio.DirectIoPath
-
Returns the container data source information.
- getSource() - Method in class com.asakusafw.operator.model.ExternMirror
-
Returns the source annotation.
- getSource() - Method in class com.asakusafw.operator.model.KeyMirror
-
Returns the source annotation.
- getSource() - Method in class com.asakusafw.operator.model.KeyMirror.Group
-
Returns the representation source.
- getSource() - Method in class com.asakusafw.operator.model.KeyMirror.Order
-
Returns the representation source.
- getSource() - Method in class com.asakusafw.testdriver.DriverInputBase
-
Returns the data source for this input.
- getSourceFields() - Method in class com.asakusafw.directio.hive.serde.DataModelDriver
-
Returns source field references which will be actually mapped into the data model.
- getSourceInspector() - Method in class com.asakusafw.directio.hive.serde.DataModelDriver
-
Returns the source object inspector.
- getSources() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
Returns the sources.
- getSources() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
Returns the generated Java source files.
- getSources() - Method in class com.asakusafw.utils.java.jsr199.testing.VolatileCompiler
-
Returns the Java source files which are generated by this compiler.
- getSourceScript() - Method in class com.asakusafw.windgate.core.ProcessScript
-
Returns the script which describes a source driver.
- getSpec() - Method in class com.asakusafw.info.operator.OperatorAttribute
-
- getSpec() - Method in interface com.asakusafw.info.operator.OperatorInfo
-
Returns the operator body.
- getSpec() - Method in class com.asakusafw.info.operator.view.OperatorView
-
- getSplit() - Method in class com.asakusafw.runtime.stage.input.StageInputSplit.Source
-
Returns the InputSplit
.
- getSplitCombinerClass(JobContext) - Static method in class com.asakusafw.runtime.stage.input.StageInputFormat
-
- getSplits(JobContext) - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat
-
Deprecated.
- getSplits(JobContext, List<StageInput>) - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat
-
Computes and returns splits for the specified inputs.
- getSplits(JobContext) - Method in class com.asakusafw.runtime.stage.input.StageInputFormat
-
- getSplits(JobContext) - Method in class com.asakusafw.runtime.stage.input.TemporaryInputFormat
-
- getSplits(JobContext, List<StageInput>) - Method in class com.asakusafw.runtime.stage.input.TemporaryInputFormat
-
Computes and returns splits for the specified inputs.
- getSpreadsheetVersion(String) - Static method in class com.asakusafw.testdata.generator.excel.WorkbookGenerator
-
Returns spreadsheet version for the target workbook.
- getSpreadsheetVersion(Workbook) - Static method in class com.asakusafw.testdata.generator.excel.WorkbookGenerator
-
Returns spreadsheet version for the target workbook.
- getStageId() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the stage ID.
- getStageId() - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Returns the stage ID for target job.
- getStageInputs() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the stage inputs.
- getStageOutputPath() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the base path of stage output.
- getStageOutputs() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the stage outputs.
- getStageResources() - Method in class com.asakusafw.runtime.stage.AbstractStageClient
-
Returns the stage resources.
- getStandard() - Method in class com.asakusafw.yaess.bootstrap.ArgumentList
-
Returns the standard arguments.
- getStandardAsArray() - Method in class com.asakusafw.yaess.bootstrap.ArgumentList
-
Returns the standard arguments.
- getStart() - Method in class com.asakusafw.runtime.directio.hadoop.BlockInfo
-
Returns the start byte position of this block in the file.
- getStartPosition() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrLocation
-
Returns the starting position.
- getStartPosition() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.JavadocToken
-
Returns the starting position (0-origin).
- getStatements() - Method in class com.asakusafw.utils.java.internal.model.syntax.BlockImpl
-
- getStatements() - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchStatementImpl
-
- getStatements() - Method in interface com.asakusafw.utils.java.model.syntax.Block
-
Returns the element statements.
- getStatements() - Method in interface com.asakusafw.utils.java.model.syntax.SwitchStatement
-
Returns the switch
body statements.
- getStatus() - Method in exception com.asakusafw.runtime.io.csv.CsvFormatException
-
Returns the status of this exception.
- getStatus(JobId) - Method in class com.asakusafw.yaess.jobqueue.client.HttpJobClient
-
- getStatus(JobId) - Method in interface com.asakusafw.yaess.jobqueue.client.JobClient
-
Obtains and returns the job information.
- getStepUnit() - Method in class com.asakusafw.yaess.flowlog.FlowLoggerProfile
-
Returns the step unit.
- getStorageFormat() - Method in class com.asakusafw.info.hive.TableInfo
-
Returns the table storage format.
- getStreamSettings() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatTrait
-
Returns the I/O stream settings.
- getStreamSupport() - Method in class com.asakusafw.vocabulary.windgate.FsExporterDescription
-
- getStreamSupport() - Method in class com.asakusafw.vocabulary.windgate.FsImporterDescription
-
- getString() - Method in class com.asakusafw.runtime.stage.directio.StringTemplate.FormatSpec
-
Returns the format string.
- getString() - Method in class com.asakusafw.utils.java.internal.model.syntax.BlockCommentImpl
-
- getString() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocTextImpl
-
- getString() - Method in class com.asakusafw.utils.java.internal.model.syntax.LineCommentImpl
-
- getString() - Method in interface com.asakusafw.utils.java.model.syntax.BlockComment
-
Returns the comment text.
- getString() - Method in interface com.asakusafw.utils.java.model.syntax.DocText
-
Returns the comment text.
- getString() - Method in interface com.asakusafw.utils.java.model.syntax.LineComment
-
Returns the comment text.
- getStringLength() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the explicit char/varchar length.
- getStripeSize() - Method in class com.asakusafw.directio.hive.orc.OrcFormatConfiguration
-
Returns the ORCFile stripe size (in bytes).
- getStructFieldData(Object, StructField) - Method in class com.asakusafw.directio.hive.serde.DataModelInspector
-
- getStructFieldRef(String) - Method in class com.asakusafw.directio.hive.serde.DataModelInspector
-
- getStructFieldsDataAsList(Object) - Method in class com.asakusafw.directio.hive.serde.DataModelInspector
-
- getStub() - Static method in class com.asakusafw.runtime.core.BatchContext
-
Returns the API stub.
- getStub() - Static method in class com.asakusafw.runtime.core.Report
-
Returns the API stub.
- getStub() - Static method in class com.asakusafw.runtime.directio.api.DirectIo
-
Returns the API stub.
- getSuffix(String, Blob) - Static method in class com.asakusafw.yaess.basic.BlobUtil
-
Returns the file suffix for the extension.
- getSuperClass() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getSuperClass() - Method in interface com.asakusafw.utils.java.model.syntax.ClassDeclaration
-
Returns the super class.
- getSuperInterfaceTypes() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getSuperInterfaceTypes() - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
- getSuperInterfaceTypes() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getSuperInterfaceTypes() - Method in interface com.asakusafw.utils.java.model.syntax.ClassDeclaration
-
Returns the super interface types.
- getSuperInterfaceTypes() - Method in interface com.asakusafw.utils.java.model.syntax.EnumDeclaration
-
Returns the super interface types.
- getSuperInterfaceTypes() - Method in interface com.asakusafw.utils.java.model.syntax.InterfaceDeclaration
-
Returns the super interface types.
- getSupport() - Method in class com.asakusafw.operator.model.OperatorDescription
-
Returns the support method for this operator.
- getSupport() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
- getSupportClassName() - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Returns the format class name.
- getSupportClassName() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns the format class name.
- getSupportedAnnotationTypes() - Method in class com.asakusafw.operator.flowpart.FlowPartAnnotationProcessor
-
- getSupportedAnnotationTypes() - Method in class com.asakusafw.operator.method.OperatorAnnotationProcessor
-
- getSupportedAnnotationTypes() - Method in class com.asakusafw.utils.java.jsr199.testing.SafeProcessor
-
- getSupportedExtensions() - Method in class com.asakusafw.yaess.core.CommandScript
-
- getSupportedExtensions() - Method in interface com.asakusafw.yaess.core.ExecutionScript
-
Returns the supported extension names.
- getSupportedExtensions() - Method in class com.asakusafw.yaess.core.HadoopScript
-
- getSupportedFeatures() - Method in class com.asakusafw.operator.AbstractOperatorAnnotationProcessor
-
Returns the supported features.
- getSupportedFeatures() - Method in class com.asakusafw.operator.flowpart.FlowPartAnnotationProcessor
-
- getSupportedFeatures() - Method in class com.asakusafw.operator.method.OperatorAnnotationProcessor
-
- getSupportedKinds() - Method in enum com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait.TypeKind
-
Returns the supported kinds.
- getSupportedOptions() - Method in class com.asakusafw.operator.AbstractOperatorAnnotationProcessor
-
- getSupportedOptions() - Method in class com.asakusafw.utils.java.jsr199.testing.SafeProcessor
-
- getSupportedSourceVersion() - Method in class com.asakusafw.operator.AbstractOperatorAnnotationProcessor
-
- getSupportedSourceVersion() - Static method in class com.asakusafw.operator.Constants
-
Returns the current supported source version.
- getSupportedSourceVersion() - Method in class com.asakusafw.utils.java.jsr199.testing.SafeProcessor
-
- getSupportedType() - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
- getSupportedType() - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
- getSupportedType() - Method in interface com.asakusafw.runtime.directio.DataFormat
-
Returns the supported data model type.
- getSupportedType() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopFileFormatAdapter
-
- getSupportedType() - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelJdbcSupport
-
Returns the supported data model type.
- getSupportedType() - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelStreamSupport
-
Returns the supported data model type.
- getSymbol() - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
Returns the symbol refer to this declaration.
- getSymbol() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
Returns the symbol refer to this declaration.
- getSymbol() - Method in enum com.asakusafw.info.task.TaskInfo.Phase
-
Returns the symbol of this phase.
- getSymbol() - Method in enum com.asakusafw.runtime.core.context.RuntimeContext.ExecutionMode
-
Returns the symbol of this mode.
- getSymbol() - Method in enum com.asakusafw.runtime.directio.FilePattern.PatternElementKind
-
Returns a general symbol of this element kind.
- getSymbol() - Method in enum com.asakusafw.testdriver.rule.CompareOperator
-
Returns the symbol.
- getSymbol() - Method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.IrBasicTypeKind
-
Returns the symbol of this type kind.
- getSymbol() - Method in enum com.asakusafw.utils.java.model.syntax.InfixOperator
-
Returns the infix operator symbol.
- getSymbol() - Method in enum com.asakusafw.utils.java.model.syntax.PostfixOperator
-
Returns the operator symbol.
- getSymbol() - Method in enum com.asakusafw.utils.java.model.syntax.UnaryOperator
-
Returns the operator symbol.
- getSymbol() - Method in interface com.asakusafw.vocabulary.windgate.JdbcAttribute
-
Returns the symbol of this attribute.
- getSymbol() - Method in enum com.asakusafw.vocabulary.windgate.JdbcExporterDescription.Option
-
- getSymbol() - Method in enum com.asakusafw.vocabulary.windgate.JdbcImporterDescription.Option
-
- getSymbol() - Method in enum com.asakusafw.workflow.executor.basic.BasicCommandLauncher.OutputChannel
-
Returns the symbol.
- getSymbol() - Method in enum com.asakusafw.yaess.core.ExecutionLock.Scope
-
Returns the symbol of this scope.
- getSymbol() - Method in enum com.asakusafw.yaess.core.ExecutionPhase
-
Returns the symbol of this phase.
- getSymbol() - Method in enum com.asakusafw.yaess.core.ExecutionScript.Kind
-
Returns the symbol of this phase.
- getSymbol() - Method in interface com.asakusafw.yaess.core.Symbolic
-
Returns the symbol of this element.
- getSymbol() - Method in enum com.asakusafw.yaess.jobqueue.client.JobStatus.Kind
-
Returns the symbol of this kind.
- getSystemDir(Configuration) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Returns the system directory.
- getSystemDir(Configuration, boolean) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Returns the system directory.
- getTable() - Method in class com.asakusafw.info.cli.generate.ddl.HiveIoParameter.TableLocationInfo
-
Returns the table.
- getTableInfo() - Method in interface com.asakusafw.info.hive.syntax.HiveCreateTable
-
Returns the target table information.
- getTableInfo() - Method in class com.asakusafw.info.hive.syntax.SimpleCreateTable
-
- getTableName() - Method in class com.asakusafw.directio.hive.orc.AbstractOrcFileFormat
-
Returns the table name.
- getTableName() - Method in class com.asakusafw.directio.hive.orc.OrcFileFormat
-
- getTableName() - Method in class com.asakusafw.directio.hive.parquet.AbstractParquetFileFormat
-
Returns the table name.
- getTableName() - Method in class com.asakusafw.directio.hive.parquet.ParquetFileFormat
-
- getTableName() - Method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileTrait
-
Returns the explicit table name.
- getTableName(ModelDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileTrait
-
Returns the explicit/inferred table name.
- getTableName() - Method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileTrait
-
Returns the explicit table name.
- getTableName(ModelDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileTrait
-
Returns the explicit/inferred table name.
- getTableName() - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Returns table name.
- getTableName() - Method in class com.asakusafw.vocabulary.windgate.JdbcExporterDescription
-
Returns the target table name.
- getTableName() - Method in class com.asakusafw.vocabulary.windgate.JdbcImporterDescription
-
Returns the target table name.
- getTableName() - Method in class com.asakusafw.windgate.jdbc.JdbcScript
-
Returns the target table name.
- getTableNamePattern() - Method in class com.asakusafw.info.cli.generate.ddl.HiveTableParameter
-
Returns the target table name pattern.
- getTableNamePatternString() - Method in class com.asakusafw.info.cli.generate.ddl.HiveTableParameter
-
Returns the table name pattern string.
- getTag() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocBlockImpl
-
- getTag() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBlock
-
Returns the block tag.
- getTag() - Method in interface com.asakusafw.utils.java.model.syntax.DocBlock
-
Returns the tag name.
- getTagName() - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockInfo
-
Returns the tag name.
- getTagName() - Method in exception com.asakusafw.utils.java.parser.javadoc.MissingJavadocBlockParserException
-
Returns the target tag name.
- getTarget() - Method in class com.asakusafw.dmdl.semantics.trait.MappingFactor
-
Returns the target property.
- getTarget() - Method in class com.asakusafw.runtime.util.lock.LocalFileLockObject
-
- getTarget() - Method in interface com.asakusafw.runtime.util.lock.LockObject
-
Returns the lock target.
- getTarget() - Method in class com.asakusafw.utils.java.internal.model.syntax.BreakStatementImpl
-
- getTarget() - Method in class com.asakusafw.utils.java.internal.model.syntax.ContinueStatementImpl
-
- getTarget() - Method in interface com.asakusafw.utils.java.model.syntax.BranchStatement
-
Returns the target label.
- getTarget() - Method in enum com.asakusafw.utils.java.model.syntax.ImportKind
-
Returns the import target kind.
- getTarget() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Return the remote installation path.
- getTargetClass() - Method in class com.asakusafw.runtime.directio.DirectDataSourceProfile
-
Returns the target data source class.
- getTargetName() - Method in class com.asakusafw.dmdl.analyzer.driver.AutoProjectionDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.analyzer.driver.NamespaceDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFieldDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFileNameDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvIgnoreDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvLineNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvRecordNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveCharDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveDecimalDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveIgnoreDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveStringDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveTimestampDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveVarcharDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFileNameDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonIgnoreDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonLineNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonRecordNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.line.driver.LineBodyDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFileNameDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.line.driver.LineLineNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.TextFieldDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.TextFileNameDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.TextIgnoreDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.TextLineNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.text.TextRecordNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFieldDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFileNameDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvIgnoreDriver
-
- getTargetName() - Method in interface com.asakusafw.dmdl.spi.AttributeDriver
-
Returns the qualified name of the target attribute.
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvFieldDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvFileNameDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvIgnoreDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvLineNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvRecordNumberDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.ColumnDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcColumnDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.jdbc.driver.JdbcTableDriver
-
- getTargetName() - Method in class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportDriver
-
- getTaskContext() - Method in class com.asakusafw.operation.tools.directio.common.ExecutorParameter
-
Returns the task execution context.
- getTaskExecutors(ExecutionContext) - Method in class com.asakusafw.workflow.cli.run.ExecutorParameter
-
Returns the task executors.
- getTaskKind() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Command
-
Deprecated.
- getTaskKind() - Method in class com.asakusafw.testdriver.TestExecutionPlan.Job
-
Deprecated.
- getTaskKind() - Method in interface com.asakusafw.testdriver.TestExecutionPlan.Task
-
Deprecated.
Returns the kind of this task.
- getTasks() - Method in class com.asakusafw.info.task.TaskListAttribute
-
Returns the tasks.
- getTasks(TaskInfo.Phase) - Method in class com.asakusafw.workflow.model.basic.BasicJobflowInfo
-
- getTasks(TaskInfo.Phase) - Method in interface com.asakusafw.workflow.model.JobflowInfo
-
Returns tasks of this jobflow.
- getTemporaryBlobPrefix() - Method in class com.asakusafw.yaess.jsch.JschProcessExecutor
-
Returns the BLOB storage remote path prefix.
- getTemporaryDirectory() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter.Options
-
Returns the temporary directory for storing spill-out block files.
- getTemporaryFileSystemPath() - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Returns the temporary root path.
- getTerms() - Method in class com.asakusafw.dmdl.semantics.trait.JoinTrait
-
Returns each join term.
- getTerms() - Method in class com.asakusafw.dmdl.semantics.trait.SummarizeTrait
-
Returns each summarize term.
- getTerms() - Method in class com.asakusafw.vocabulary.attribute.ViewInfo
-
Returns the property terms.
- getTestContext() - Method in class com.asakusafw.testdriver.core.VerifyContext
-
Returns the corresponded test context.
- getTestContext() - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
- getTestFinished() - Method in class com.asakusafw.testdriver.core.VerifyContext
-
Returns the test finished time.
- getTestStarted() - Method in class com.asakusafw.testdriver.core.VerifyContext
-
Returns the test started time.
- getTestTools() - Method in class com.asakusafw.testdriver.DriverElementBase
-
Returns the test tools.
- getTestTools() - Method in class com.asakusafw.testdriver.DriverInputBase
-
- getTestTools() - Method in class com.asakusafw.testdriver.DriverToolBase
-
- getTestTools() - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
- getTestTools() - Method in class com.asakusafw.testdriver.TestDriverBase
-
- getTestTools() - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
- getText() - Method in class com.asakusafw.dmdl.model.AstDescription
-
Returns the string value of this description.
- getText() - Method in class com.asakusafw.operator.model.OperatorDescription.TextDocument
-
Return the text of this document.
- getText() - Method in enum com.asakusafw.testdriver.excel.NullityConditionKind
-
Returns a textual representation of this kind.
- getText() - Method in enum com.asakusafw.testdriver.excel.ValueConditionKind
-
Returns a textual representation of this kind.
- getText() - Method in class com.asakusafw.utils.java.internal.model.util.LiteralToken
-
Returns the token image.
- getText() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.JavadocToken
-
Returns the token image.
- getTextFormat() - Method in class com.asakusafw.runtime.io.text.directio.AbstractTextStreamFormat
-
- getThenExpression() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
- getThenExpression() - Method in interface com.asakusafw.utils.java.model.syntax.ConditionalExpression
-
Returns the truth term.
- getThenStatement() - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
- getThenStatement() - Method in interface com.asakusafw.utils.java.model.syntax.IfStatement
-
Returns the truth statement.
- getThis() - Method in class com.asakusafw.testdriver.FlowDriverInput
-
Returns this object.
- getThis() - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Returns this object.
- getThis() - Method in class com.asakusafw.testdriver.FlowPartDriverInput
-
- getThis() - Method in class com.asakusafw.testdriver.FlowPartDriverOutput
-
- getThis() - Method in class com.asakusafw.testdriver.JobFlowDriverInput
-
- getThis() - Method in class com.asakusafw.testdriver.JobFlowDriverOutput
-
- getThis() - Method in class com.asakusafw.windgate.core.BaseProfile
-
Returns this object.
- getThis() - Method in class com.asakusafw.windgate.core.process.ProcessProfile
-
- getThis() - Method in class com.asakusafw.windgate.core.resource.ResourceProfile
-
- getThis() - Method in class com.asakusafw.windgate.core.session.SessionProfile
-
- getTimeOfDayNanos(Date) - Static method in class com.asakusafw.directio.hive.util.TemporalUtil
-
Returns the nano time of the julian day.
- getTimeOfDayNanos(DateTime) - Static method in class com.asakusafw.directio.hive.util.TemporalUtil
-
Returns the nano time of the julian day.
- getTimeout() - Method in class com.asakusafw.yaess.jobqueue.JobClientProfile
-
Returns the timeout duration.
- getTimestamp() - Method in class com.asakusafw.runtime.directio.hadoop.DirectIoTransactionEditor.TransactionInfo
-
Returns the commit start timestamp.
- getTimeZone() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Returns the time zone.
- getTimeZone() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the time zone.
- getTitle() - Method in class com.asakusafw.testdata.generator.excel.WorkbookGenerator
-
- getTitle() - Method in interface com.asakusafw.testdata.generator.TemplateGenerator
-
Returns the title of this generator.
- getTitle() - Method in enum com.asakusafw.testdriver.excel.NullityConditionKind
-
Returns a title of this kind.
- getTitle() - Method in enum com.asakusafw.testdriver.excel.RuleSheetFormat
-
Returns the title of this kind.
- getTitle() - Method in enum com.asakusafw.testdriver.excel.TotalConditionKind
-
Returns a title of this kind.
- getTitle() - Method in enum com.asakusafw.testdriver.excel.ValueConditionKind
-
Returns a title of this kind.
- getTo() - Method in class com.asakusafw.runtime.io.text.tabular.EscapeSequence.Entry
-
Returns the replacement character.
- getToken() - Method in class com.asakusafw.dmdl.model.AstLiteral
-
Returns the token of this literal.
- getToken() - Method in interface com.asakusafw.runtime.directio.FilePattern.PatternElement
-
Returns the token of this element.
- getToken() - Method in class com.asakusafw.runtime.directio.FilePattern.Selection
-
- getToken() - Method in class com.asakusafw.runtime.directio.FilePattern.Variable
-
- getToken() - Method in class com.asakusafw.utils.java.internal.model.syntax.LiteralImpl
-
- getToken() - Method in class com.asakusafw.utils.java.internal.model.syntax.SimpleNameImpl
-
- getToken() - Method in interface com.asakusafw.utils.java.model.syntax.Literal
-
Returns the literal token.
- getToken() - Method in interface com.asakusafw.utils.java.model.syntax.SimpleName
-
Returns the identifier.
- getToken() - Method in class com.asakusafw.yaess.jobqueue.client.JobId
-
Returns the token which represents this ID.
- getTokenKind() - Method in class com.asakusafw.workflow.model.CommandToken
-
Returns the token kind.
- getTokens() - Method in class com.asakusafw.utils.java.parser.javadoc.DefaultJavadocScanner
-
- getTokens() - Method in interface com.asakusafw.utils.java.parser.javadoc.JavadocScanner
-
Returns the tokens.
- getTokens() - Method in class com.asakusafw.workflow.model.basic.BasicConfigurationResolver
-
Returns the template tokens.
- getTracepoint() - Method in class com.asakusafw.trace.model.TraceSetting
-
Returns the tracepoint.
- getTrackingId(ExecutionContext) - Method in class com.asakusafw.yaess.core.Job
-
Returns the tracking ID of this job.
- getTrackingId(ExecutionContext) - Method in class com.asakusafw.yaess.core.task.HandlerLifecycleJob
-
- getTrackingId(ExecutionContext) - Method in class com.asakusafw.yaess.core.task.ScriptJob
-
- getTrait(Class<T>) - Method in interface com.asakusafw.dmdl.semantics.Declaration
-
Returns the specified trait of this declaration.
- getTrait(Class<T>) - Method in class com.asakusafw.dmdl.semantics.ModelDeclaration
-
- getTrait(Class<T>) - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
- getTrait(Class<T>) - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
- getTransactionContext() - Method in class com.asakusafw.runtime.directio.OutputAttemptContext
-
Returns the corresponded transaction context.
- getTransactionId() - Method in class com.asakusafw.runtime.directio.OutputAttemptContext
-
Returns the transaction ID corresponding to this output.
- getTransactionId() - Method in class com.asakusafw.runtime.directio.OutputTransactionContext
-
Returns the transaction ID corresponding to this output.
- getTransactionInfoExecutionId(Path) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Extracts an execution ID from the transaction info.
- getTransactionInfoPath(Configuration, String) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Returns the transaction info path.
- getTrimInput() - Method in class com.asakusafw.runtime.io.text.driver.FieldDefinition
-
Returns whether or not leading/trailing white-space characters are trimmed.
- getTrimInputWhitespaces() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns whether or not trims input field leading/trailing white-space characters.
- getTrueFormat() - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Returns the "true"
representation.
- getTrueFormat() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the string representation of true
.
- getTrueFormat() - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Returns the "true"
representation.
- getTrueFormat() - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
The boolean true
format.
- getTruncateStatement(String) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Returns the truncate statement.
- getTryBlock() - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
- getTryBlock() - Method in interface com.asakusafw.utils.java.model.syntax.TryStatement
-
Returns the body block of try
clause.
- getType(String) - Method in class com.asakusafw.directio.hive.parquet.v1.DecimalValueDriver
-
- getType(String) - Method in class com.asakusafw.directio.hive.parquet.v1.LimitedStringValueDriver
-
- getType(String) - Method in interface com.asakusafw.directio.hive.parquet.v1.ParquetValueDriver
-
Returns a parquet data type for this driver.
- getType(String) - Method in enum com.asakusafw.directio.hive.parquet.v1.ParquetValueDrivers
-
- getType(String) - Method in enum com.asakusafw.directio.hive.parquet.v1.StringValueDrivers
-
- getType(String) - Method in enum com.asakusafw.directio.hive.parquet.v1.TimestampValueDrivers
-
- getType(String) - Method in class com.asakusafw.directio.hive.parquet.v2.DecimalValueDriver
-
- getType(String) - Method in class com.asakusafw.directio.hive.parquet.v2.LimitedStringValueDriver
-
- getType(String) - Method in interface com.asakusafw.directio.hive.parquet.v2.ParquetValueDriver
-
Returns a parquet data type for this driver.
- getType(String) - Method in enum com.asakusafw.directio.hive.parquet.v2.ParquetValueDrivers
-
- getType(String) - Method in enum com.asakusafw.directio.hive.parquet.v2.StringValueDrivers
-
- getType(String) - Method in enum com.asakusafw.directio.hive.parquet.v2.TimestampValueDrivers
-
- getType() - Method in class com.asakusafw.dmdl.semantics.PropertyDeclaration
-
Returns the type of this property.
- getType() - Method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
Returns the type of each referent property.
- getType() - Method in class com.asakusafw.info.hive.ColumnInfo
-
Returns the column type.
- getType() - Method in class com.asakusafw.info.operator.ParameterInfo
-
Returns the parameter type.
- getType() - Method in class com.asakusafw.operator.model.OperatorDescription.Node
-
Returns the type of this node.
- getType() - Method in class com.asakusafw.operator.model.PropertyMirror
-
Returns the type of this property.
- getType() - Method in class com.asakusafw.runtime.model.PropertyInfo
-
Returns the property type.
- getType(PropertyName) - Method in interface com.asakusafw.testdriver.core.DataModelDefinition
-
Returns the property type.
- getType(PropertyName) - Method in class com.asakusafw.testdriver.model.DefaultDataModelDefinition
-
- getType(PropertyName) - Method in class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
- getType(PropertyName, Class<?>) - Static method in class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
Returns property type kind corresponded to the property name and type.
- getType() - Method in class com.asakusafw.testdriver.rule.VerifyRuleBuilder.Property
-
Returns the type of this property.
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.CastExpressionImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassLiteralImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocFieldImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodParameterImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.InstanceofExpressionImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.MarkerAnnotationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.NormalAnnotationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.ParameterizedTypeImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.model.syntax.SingleElementAnnotationImpl
-
- getType() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethodParameter
-
Returns the parameter type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.Annotation
-
Returns the annotation type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.AnnotationElementDeclaration
-
Returns the annotation element type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.ArrayCreationExpression
-
Returns the target array type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.CastExpression
-
Returns the target type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.ClassInstanceCreationExpression
-
Returns the target type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.ClassLiteral
-
Returns the target type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.DocField
-
Returns the owner type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.DocMethod
-
Returns the owner type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.DocMethodParameter
-
Returns the parameter type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.FieldDeclaration
-
Returns the field type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.FormalParameterDeclaration
-
Returns the variable type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.InstanceofExpression
-
Returns the target type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.LocalVariableDeclaration
-
Returns the variable type.
- getType() - Method in interface com.asakusafw.utils.java.model.syntax.ParameterizedType
-
Returns the non-parameterized type.
- getType() - Method in class com.asakusafw.vocabulary.flow.builder.Constant
-
Returns the type.
- getType() - Method in class com.asakusafw.vocabulary.flow.builder.PortInfo
-
Returns the data type on the port.
- getType() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription.Parameter
-
Returns the parameter type.
- getType() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Parameter
-
Returns the parameter type.
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveDataModelEmitter
-
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.CompositeDataModelDriver
-
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.GeneratorInfoDriver
-
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.JoinDriver
-
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.PropertyOrderDriver
-
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.driver.SummarizeDriver
-
- getTypeAnnotations(EmitContext, ModelDeclaration) - Method in class com.asakusafw.dmdl.java.spi.JavaDataModelDriver
-
Returns the type annotations to attach to the model.
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.AlternateConstructorInvocationImpl
-
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorReferenceExpressionImpl
-
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.ParameterizedTypeImpl
-
- getTypeArguments() - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
- getTypeArguments() - Method in interface com.asakusafw.utils.java.model.syntax.ClassInstanceCreationExpression
-
Returns the type arguments.
- getTypeArguments() - Method in interface com.asakusafw.utils.java.model.syntax.ConstructorInvocation
-
Returns the type arguments.
- getTypeArguments() - Method in interface com.asakusafw.utils.java.model.syntax.MethodInvocationExpression
-
Returns the type arguments.
- getTypeArguments() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorReferenceExpression
-
Returns the type arguments.
- getTypeArguments() - Method in interface com.asakusafw.utils.java.model.syntax.ParameterizedType
-
Returns the type arguments.
- getTypeBound() - Method in class com.asakusafw.utils.java.internal.model.syntax.WildcardImpl
-
- getTypeBound() - Method in interface com.asakusafw.utils.java.model.syntax.Wildcard
-
Returns the bound type.
- getTypeBounds() - Method in class com.asakusafw.utils.java.internal.model.syntax.TypeParameterDeclarationImpl
-
- getTypeBounds() - Method in interface com.asakusafw.utils.java.model.syntax.TypeParameterDeclaration
-
Returns the bound types.
- getTypeDeclarations() - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
- getTypeDeclarations() - Method in interface com.asakusafw.utils.java.model.syntax.CompilationUnit
-
Returns the type declarations.
- getTypeInfo() - Method in enum com.asakusafw.directio.hive.parquet.v1.ParquetValueDrivers
-
Returns the Hive type information for this driver.
- getTypeInfo() - Method in enum com.asakusafw.directio.hive.parquet.v2.ParquetValueDrivers
-
Returns the Hive type information for this driver.
- getTypeInfo() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getTypeInfo() - Method in enum com.asakusafw.directio.hive.serde.StringValueSerdeFactory
-
- getTypeInfo() - Method in enum com.asakusafw.directio.hive.serde.TimestampValueSerdeFactory
-
- getTypeInfo() - Method in interface com.asakusafw.directio.hive.serde.ValueSerde
-
Returns the type info.
- getTypeInfo() - Method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
- getTypeInfo(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the type information for the property.
- getTypeKind() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Returns the type kind.
- getTypeKind() - Method in class com.asakusafw.operator.description.ArrayTypeDescription
-
- getTypeKind() - Method in class com.asakusafw.operator.description.BasicTypeDescription
-
- getTypeKind() - Method in class com.asakusafw.operator.description.ClassDescription
-
- getTypeKind() - Method in interface com.asakusafw.operator.description.TypeDescription
-
Returns the type kind.
- getTypeKind() - Method in class com.asakusafw.utils.java.internal.model.syntax.BasicTypeImpl
-
- getTypeKind() - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBasicType
-
Returns the type kind.
- getTypeKind() - Method in interface com.asakusafw.utils.java.model.syntax.BasicType
-
Returns the type kind.
- getTypeName() - Method in class com.asakusafw.directio.hive.serde.DataModelInspector
-
- getTypeName() - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the simple name of processing type.
- getTypeName(ModelSymbol) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the simple name of the target data model class.
- getTypeName() - Method in class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportTrait
-
Returns the format name.
- getTypeName() - Method in class com.asakusafw.info.hive.ArrayType
-
- getTypeName() - Method in class com.asakusafw.info.hive.DecimalType
-
- getTypeName() - Method in interface com.asakusafw.info.hive.FieldType
-
Returns the type name.
- getTypeName() - Method in class com.asakusafw.info.hive.MapType
-
- getTypeName() - Method in class com.asakusafw.info.hive.PlainType
-
- getTypeName() - Method in class com.asakusafw.info.hive.SequenceType
-
- getTypeName() - Method in class com.asakusafw.info.hive.StructType
-
- getTypeName() - Method in class com.asakusafw.info.hive.UnionType
-
- getTypeParameter(String) - Method in class com.asakusafw.operator.util.JavadocHelper
-
Returns the type parameter document elements.
- getTypeParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
- getTypeParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
- getTypeParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
- getTypeParameters() - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
- getTypeParameters() - Method in interface com.asakusafw.utils.java.model.syntax.ClassDeclaration
-
Returns the type parameter declarations.
- getTypeParameters() - Method in interface com.asakusafw.utils.java.model.syntax.InterfaceDeclaration
-
Returns the type parameter declarations.
- getTypeParameters() - Method in interface com.asakusafw.utils.java.model.syntax.MethodOrConstructorDeclaration
-
Returns the type parameter declarations.
- getUniqueJobflow() - Method in class com.asakusafw.info.cli.common.JobflowInfoParameter
-
Returns the target jobflow, and must be it is unique in the current context.
- getUnit() - Method in class com.asakusafw.dmdl.model.AstJoin
-
- getUnit() - Method in class com.asakusafw.dmdl.model.AstModelReference
-
- getUnit() - Method in class com.asakusafw.dmdl.model.AstRecordDefinition
-
- getUnit() - Method in class com.asakusafw.dmdl.model.AstSummarize
-
- getUnit() - Method in interface com.asakusafw.dmdl.model.AstTerm
-
Returns itself.
- getUnknownPropertyAction() - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Returns the unknown property action.
- getUnmappableCharacterAction() - Method in class com.asakusafw.runtime.io.line.LineConfiguration
-
Returns the action type for unmappable inputs.
- getUnmappableOutputAction() - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Returns the error action of unmappable outputs.
- getUpdate() - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
- getUpdate() - Method in interface com.asakusafw.utils.java.model.syntax.ForStatement
-
Returns the loop update part.
- getUpstream() - Method in class com.asakusafw.vocabulary.flow.graph.PortConnection
-
Returns the upstream port.
- getUri() - Method in class com.asakusafw.windgate.hadoopfs.ssh.FileInfo
-
Returns the URI of the target file.
- getUser() - Method in class com.asakusafw.runtime.stage.BaseStageClient
-
Returns the current user name.
- getUser() - Method in class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Returns the user name.
- getUser() - Method in class com.asakusafw.yaess.jobqueue.client.HttpJobClient
-
Returns the target user name for auth.
- getUser() - Method in class com.asakusafw.yaess.jsch.JschProcessExecutor
-
Returns the remote user name.
- getUserHome(ExecutionContext) - Static method in class com.asakusafw.workflow.executor.TaskExecutors
-
Returns the current user home directory.
- getUserName(ExecutionContext) - Static method in class com.asakusafw.workflow.executor.TaskExecutors
-
Returns the current user name.
- getValue() - Method in class com.asakusafw.dmdl.directio.util.MapValue.Entry
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.operator.ParameterInfo
-
Returns the argument.
- getValue() - Method in class com.asakusafw.info.value.BooleanInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.ByteInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.CharInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.DoubleInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.FloatInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.IntInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.LongInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.ShortInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.StringInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.info.value.UnknownInfo
-
Returns the value.
- getValue() - Method in class com.asakusafw.operator.description.ImmediateDescription
-
Returns the value.
- getValue(CompileEnvironment, AnnotationMirror, String) - Static method in class com.asakusafw.operator.util.AnnotationHelper
-
Returns the value of annotation member.
- getValue() - Method in class com.asakusafw.runtime.mapreduce.simple.ShuffleReader
-
- getValue(PropertyName) - Method in class com.asakusafw.testdriver.core.DataModelReflection
-
Returns the property value.
- getValue() - Method in class com.asakusafw.utils.java.internal.model.util.LiteralToken
-
Returns the value which this literal represent to.
- getValue() - Method in class com.asakusafw.vocabulary.flow.builder.Constant
-
Returns the constant value.
- getValue() - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription.Parameter
-
Returns the argument value.
- getValue() - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Parameter
-
Returns the parameter value.
- getValue() - Method in class com.asakusafw.yaess.bootstrap.ExtendedArgument
-
Returns the value.
- getValueClass() - Method in class com.asakusafw.directio.hive.serde.PropertyDescriptor
-
- getValueClass() - Method in enum com.asakusafw.directio.hive.serde.StringValueSerdeFactory
-
- getValueClass() - Method in enum com.asakusafw.directio.hive.serde.TimestampValueSerdeFactory
-
- getValueClass() - Method in interface com.asakusafw.directio.hive.serde.ValueSerde
-
- getValueClass() - Method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
- getValueClass() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter
-
Returns the target value class.
- getValueClass() - Method in class com.asakusafw.runtime.stage.StageOutput
-
Returns the value class of this output.
- getValueGetterName(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded value getter name.
- getValueKind() - Method in class com.asakusafw.operator.description.AnnotationDescription
-
- getValueKind() - Method in class com.asakusafw.operator.description.ArrayDescription
-
- getValueKind() - Method in class com.asakusafw.operator.description.EnumConstantDescription
-
- getValueKind() - Method in class com.asakusafw.operator.description.ImmediateDescription
-
- getValueKind() - Method in class com.asakusafw.operator.description.ObjectDescription
-
- getValueKind() - Method in class com.asakusafw.operator.description.ReifiableTypeDescription
-
- getValueKind() - Method in class com.asakusafw.operator.description.UnknownValueDescription
-
- getValueKind() - Method in interface com.asakusafw.operator.description.ValueDescription
-
Returns the value kind.
- getValueLength() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Returns the value length.
- getValueOffset() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
- getValueOptionClass() - Method in enum com.asakusafw.directio.hive.parquet.v1.ParquetValueDrivers
-
Returns the Asakusa type information for this driver.
- getValueOptionClass() - Method in enum com.asakusafw.directio.hive.parquet.v2.ParquetValueDrivers
-
Returns the Asakusa type information for this driver.
- getValues(CompileEnvironment, AnnotationMirror) - Static method in class com.asakusafw.operator.util.AnnotationHelper
-
Returns the name-value pairs in annotation.
- getValueSetterName(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded value setter name.
- getValueType(PropertyDeclaration) - Method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property value type.
- getValueType() - Method in class com.asakusafw.info.hive.MapType
-
Returns the value type.
- getValueType() - Method in class com.asakusafw.operator.description.AnnotationDescription
-
- getValueType() - Method in class com.asakusafw.operator.description.ArrayDescription
-
- getValueType() - Method in class com.asakusafw.operator.description.EnumConstantDescription
-
- getValueType() - Method in class com.asakusafw.operator.description.ImmediateDescription
-
- getValueType() - Method in class com.asakusafw.operator.description.ObjectDescription
-
- getValueType() - Method in class com.asakusafw.operator.description.ReifiableTypeDescription
-
- getValueType() - Method in class com.asakusafw.operator.description.UnknownValueDescription
-
- getValueType() - Method in interface com.asakusafw.operator.description.ValueDescription
-
Returns the value type.
- getValueTypeAsClass(PropertyDeclaration) - Static method in class com.asakusafw.dmdl.java.emitter.EmitContext
-
Returns the corresponded property value type as related class object.
- getVarchar(int) - Static method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
- getVariableDeclarators() - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
- getVariableDeclarators() - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
- getVariableDeclarators() - Method in interface com.asakusafw.utils.java.model.syntax.FieldDeclaration
-
Returns the field variable declarators.
- getVariableDeclarators() - Method in interface com.asakusafw.utils.java.model.syntax.LocalVariableDeclaration
-
Returns the variable declarators.
- getVariables() - Method in class com.asakusafw.runtime.util.VariableTable
-
Returns the variables names and their replacements in this table.
- getVariables() - Method in class com.asakusafw.vocabulary.batch.ScriptWorkDescription
-
Deprecated.
Returns the environment variables.
- getVerifier() - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Returns the verifier.
- getVerifyRuleFactory(URI, List<? extends TestRule>) - Method in interface com.asakusafw.testdriver.core.TestDataToolProvider
-
- getVerifyRuleFactory(URI, List<? extends TestRule>) - Method in class com.asakusafw.testdriver.core.TestToolRepository
-
- getVersion() - Method in class com.asakusafw.info.BatchInfo
-
Returns the schema version.
- getVersion() - Method in enum com.asakusafw.testdata.generator.excel.WorkbookFormat
-
Returns the target spreadsheet version.
- getVersion() - Method in class com.asakusafw.yaess.core.CoreProfile
-
Returns the profile version.
- getWarningAction() - Method in class com.asakusafw.operator.CompileEnvironment
-
Returns the warning action type.
- getWindGateArguments() - Method in class com.asakusafw.windgate.bootstrap.Context
-
Returns the serialized WindGate arguments.
- getWire(int) - Method in class com.asakusafw.info.graph.Node
-
Returns the wire on this node.
- getWires() - Method in class com.asakusafw.info.graph.Input
-
- getWires() - Method in class com.asakusafw.info.graph.Node
-
Returns the wires on this node.
- getWires() - Method in class com.asakusafw.info.graph.Output
-
- getWires() - Method in class com.asakusafw.info.graph.Port
-
Returns the connected wires.
- getWordList() - Method in class com.asakusafw.dmdl.model.AstSimpleName
-
Returns the words in this name.
- getWords() - Method in class com.asakusafw.testdriver.core.PropertyName
-
Returns the words which consists this property name.
- getWorkingDirectory() - Method in class com.asakusafw.testdriver.compiler.basic.BasicCompilerConfiguration
-
- getWorkingDirectory() - Method in interface com.asakusafw.testdriver.compiler.CompilerConfiguration
-
Returns the working directory.
- getWorks() - Method in class com.asakusafw.vocabulary.batch.BatchDescription
-
Returns a collection of Unit-of-Works which is represented in this batch.
- getWorld() - Method in class com.asakusafw.dmdl.analyzer.Context
-
Returns the root semantics model of current context.
- getWrapperType() - Method in enum com.asakusafw.operator.description.BasicTypeDescription.BasicTypeKind
-
Returns the corresponded wrapper type.
- getWritePosition() - Method in class com.asakusafw.runtime.io.util.DataBuffer
-
Returns the next write position in this buffer.
- getWriter() - Method in class com.asakusafw.directio.hive.parquet.v1.DecimalValueDriver
-
- getWriter() - Method in class com.asakusafw.directio.hive.parquet.v1.LimitedStringValueDriver
-
- getWriter() - Method in interface com.asakusafw.directio.hive.parquet.v1.ParquetValueDriver
-
- getWriter() - Method in class com.asakusafw.directio.hive.parquet.v2.DecimalValueDriver
-
- getWriter() - Method in class com.asakusafw.directio.hive.parquet.v2.LimitedStringValueDriver
-
- getWriter() - Method in interface com.asakusafw.directio.hive.parquet.v2.ParquetValueDriver
-
- getWriterVersion() - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the writer version.
- getWriterVersion(Class<T>) - Method in class com.asakusafw.directio.hive.parquet.ParquetFormatConfiguration
-
Returns the writer version.
- getWriterVersion() - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Returns the writer version.
- getWriterVersion() - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Returns the writer version.
- getYear() - Method in class com.asakusafw.runtime.value.Date
-
Returns the year of this date.
- getYear() - Method in class com.asakusafw.runtime.value.DateTime
-
Returns the year of this date and time.
- getYearFromDay(int) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
to the corresponding year.
- gradle(String...) - Method in class com.asakusafw.utils.gradle.BaseProject
-
Launches Gradle tasks.
- gradle(TryConsumer<? super GradleAdapter, IOException>) - Method in class com.asakusafw.utils.gradle.BaseProject
-
Proceeds Gradle actions on this project.
- GradleAdapter - Class in com.asakusafw.utils.gradle
-
Utilities about Gradle project.
- GradleAdapter(ProjectContext, ProjectConnection) - Constructor for class com.asakusafw.utils.gradle.GradleAdapter
-
Creates a new instance.
- Graph<V> - Interface in com.asakusafw.utils.graph
-
Represents a directed graph.
- Graph.Vertex<V> - Interface in com.asakusafw.utils.graph
-
Represents a vertex and its successor.
- GraphElement<S extends GraphElement<S>> - Interface in com.asakusafw.workflow.model
-
An abstract super interface for execution graph elements.
- Graphs - Class in com.asakusafw.utils.graph
-
- group(String...) - Method in class com.asakusafw.testdriver.loader.BasicDataLoader
-
- group(String...) - Method in interface com.asakusafw.testdriver.loader.DataLoader
-
Configures the grouping key of the organizing dataset.
- group(String) - Method in class com.asakusafw.vocabulary.flow.builder.KeyInfo
-
Adds a grouping key.
- groupByMapper(List<StageInputSplit>) - Static method in class com.asakusafw.runtime.stage.input.SplitCombiner.Util
-
- grouping - Variable in class com.asakusafw.dmdl.model.AstJoin
-
The grouping properties for each equivalent join.
- grouping - Variable in class com.asakusafw.dmdl.model.AstSummarize
-
The grouping properties for aggregation.
- GroupLoader<T> - Interface in com.asakusafw.testdriver.loader
-
Loads a dataset and organize a set of groups for operator inputs.
- groupOf(String...) - Static method in class com.asakusafw.vocabulary.attribute.ViewInfo
-
Creates a new group view information instance from the given grouping term list.
- GroupSort - Annotation Type in com.asakusafw.vocabulary.operator
-
グループ整列演算子を表すメソッドに付与する注釈。
- GroupSortOperatorDriver - Class in com.asakusafw.operator.builtin
-
- GroupSortOperatorDriver() - Constructor for class com.asakusafw.operator.builtin.GroupSortOperatorDriver
-
- GroupUsageCommand - Class in com.asakusafw.utils.jcommander.common
-
An abstract super class of displaying usage of the group.
- GroupUsageCommand() - Constructor for class com.asakusafw.utils.jcommander.common.GroupUsageCommand
-
- GroupView<T> - Interface in com.asakusafw.runtime.core
-
Represents a data-flow view, which partitioned by each sorted group.
- S_WHITE - Static variable in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockParserUtil
-
The white-space token kinds.
- SafeCloser<T extends Closeable> - Class in com.asakusafw.windgate.core.util
-
Closes objects safely.
- SafeCloser() - Constructor for class com.asakusafw.windgate.core.util.SafeCloser
-
Creates a new empty instance.
- SafeCloser(T) - Constructor for class com.asakusafw.windgate.core.util.SafeCloser
-
Creates a new instance with target
Closeable
.
- SafeProcessor - Class in com.asakusafw.utils.java.jsr199.testing
-
An annotation processor that handles occurred exceptions.
- SafeProcessor(Processor) - Constructor for class com.asakusafw.utils.java.jsr199.testing.SafeProcessor
-
Creates a new instance.
- satisfies(T, T) - Method in enum com.asakusafw.testdriver.rule.CompareOperator
-
Returns whether a <operator> b
is satisfied or not.
- save(OutputStream, ParameterTable) - Static method in class com.asakusafw.iterative.common.IterativeExtensions
-
Stores the parameter table into the target stream.
- save(Class<?>, ExporterDescription, DataModelSinkFactory) - Method in class com.asakusafw.testdriver.core.TestModerator
-
Saves the target exporter's output into the specified sink.
- save(Class<?>, Iterable<Difference>, DifferenceSinkFactory) - Method in class com.asakusafw.testdriver.core.TestModerator
-
Saves difference list into the specified sink.
- scan(DataModelDefinition<?>, C) - Method in class com.asakusafw.testdriver.core.DataModelScanner
-
Starts scan and visits each property method.
- scan(DataModelDefinition<?>, PropertyName, C) - Method in class com.asakusafw.testdriver.core.DataModelScanner
-
Scans about single property.
- SchemaUtil - Class in com.asakusafw.directio.hive.util
-
Utilities about Hive schema.
- SCHEME - Static variable in class com.asakusafw.utils.java.jsr199.testing.VolatileClassFile
-
The schema name of this kind of resources.
- SCHEME_CLASSPATH - Static variable in class com.asakusafw.windgate.cli.CommandLineUtil
-
The scheme name of Java class path.
- SCHEME_CLASSPATH - Static variable in class com.asakusafw.yaess.bootstrap.CommandLineUtil
-
The scheme name of Java class path.
- SCHEME_CLASSPATH - Static variable in class com.asakusafw.yaess.tools.CommandLineUtil
-
The scheme name of Java class path.
- ScriptJob<T extends ExecutionScript> - Class in com.asakusafw.yaess.core.task
-
Job to execute a script.
- ScriptJob(T, ExecutionScriptHandler<? super T>) - Constructor for class com.asakusafw.yaess.core.task.ScriptJob
-
Creates a new instance.
- ScriptWorkDescription - Class in com.asakusafw.vocabulary.batch
-
- ScriptWorkDescription(String, String, String, Map<String, String>) - Constructor for class com.asakusafw.vocabulary.batch.ScriptWorkDescription
-
Deprecated.
Creates a new instance.
- search(FileSystem, Path, FilePattern) - Static method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceUtil
-
Searches file/directories by pattern.
- second - Variable in class com.asakusafw.utils.collections.Tuple2
-
The second element.
- SECOND_FIELD_LENGTH - Static variable in class com.asakusafw.runtime.io.tsv.TsvConstants
-
The character length of second fields.
- see(DocElement) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts @see
tag block about the specified element in this builder.
- seeField(String) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target field in this builder.
- seeField(Type, String) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target field in this builder.
- seeField(SimpleName) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target field in this builder.
- seeField(Type, SimpleName) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target field in this builder.
- seek(long) - Method in class com.asakusafw.runtime.io.util.BufferedFileInput
-
Sets cursor in the target file.
- seek(long) - Method in class com.asakusafw.runtime.io.util.BufferedFileOutput
-
Sets cursor in the target file.
- seek(int) - Method in class com.asakusafw.utils.java.parser.javadoc.DefaultJavadocScanner
-
- seek(int) - Method in interface com.asakusafw.utils.java.parser.javadoc.JavadocScanner
-
Sets the index of the current scanner position.
- seeMethod(String, Type...) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target method in this builder.
- seeMethod(String, List<? extends Type>) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target method in this builder.
- seeMethod(SimpleName, Type...) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target method in this builder.
- seeMethod(SimpleName, List<? extends Type>) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target method in this builder.
- seeMethod(Type, String, Type...) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target method in this builder.
- seeMethod(Type, String, List<? extends Type>) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target method in this builder.
- seeMethod(Type, SimpleName, Type...) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts @see
tag block about the specified element in this builder.
- seeMethod(Type, SimpleName, List<? extends Type>) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts @see
tag block about the specified element in this builder.
- seeType(Type) - Method in class com.asakusafw.utils.java.model.util.JavadocBuilder
-
Starts a @see
tag block for the target type in this builder.
- SEGMENT_SEPARATOR - Static variable in class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
The path name separator character.
- SegmentedCombiner<KEY extends SegmentedWritable,VALUE extends SegmentedWritable> - Class in com.asakusafw.runtime.flow
-
A skeletal implementation of Hadoop Combiner class which uses
SegmentedWritable
as it key/value.
- SegmentedCombiner() - Constructor for class com.asakusafw.runtime.flow.SegmentedCombiner
-
- SegmentedReducer<KEYIN extends SegmentedWritable,VALUEIN extends SegmentedWritable,KEYOUT extends org.apache.hadoop.io.Writable,VALUEOUT extends org.apache.hadoop.io.Writable> - Class in com.asakusafw.runtime.flow
-
A skeletal implementation of Hadoop Reducer class which uses
SegmentedWritable
as it input key/value.
- SegmentedReducer() - Constructor for class com.asakusafw.runtime.flow.SegmentedReducer
-
- SegmentedWritable - Interface in com.asakusafw.runtime.flow
-
A Writable
object with its segment ID.
- select(JobflowInfo, OperatorGraphView) - Method in class com.asakusafw.info.cli.common.FlowPartSelectorParameter
-
Returns the target flow-part operator view.
- select(JobflowInfo, OperatorGraphView) - Method in class com.asakusafw.info.cli.common.VertexSelectorParameter
-
Returns the target vertex.
- self() - Method in class com.asakusafw.runtime.io.json.value.ValueOptionPropertyAdapter.BuilderBase
-
Returns this
object.
- self() - Method in class com.asakusafw.runtime.io.text.value.ValueOptionFieldAdapter.BuilderBase
-
Returns this
object.
- self() - Method in class com.asakusafw.utils.gradle.BaseProject
-
Returns this object.
- separator(String) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Emits a separator symbol.
- separator(String) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- Sequence - Class in com.asakusafw.testdriver.core
-
Sequence of values.
- Sequence() - Constructor for class com.asakusafw.testdriver.core.Sequence
-
- SequenceFileFormat<K,V,T> - Class in com.asakusafw.runtime.directio.hadoop
-
- SequenceFileFormat() - Constructor for class com.asakusafw.runtime.directio.hadoop.SequenceFileFormat
-
- SequenceFileFormatDriver - Class in com.asakusafw.dmdl.directio.sequencefile.driver
-
Processes @directio.csv
attributes.
- SequenceFileFormatDriver() - Constructor for class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatDriver
-
- SequenceFileFormatEmitter - Class in com.asakusafw.dmdl.directio.sequencefile.driver
-
- SequenceFileFormatEmitter() - Constructor for class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatEmitter
-
- SequenceFileFormatTrait - Class in com.asakusafw.dmdl.directio.sequencefile.driver
-
Attributes for SequenceFile supported data models.
- SequenceFileFormatTrait(AstNode, SequenceFileFormatTrait.Configuration) - Constructor for class com.asakusafw.dmdl.directio.sequencefile.driver.SequenceFileFormatTrait
-
Creates and returns a new instance.
- SequenceFileFormatTrait.Configuration - Class in com.asakusafw.dmdl.directio.sequencefile.driver
-
The SequenceFile format configuration.
- SequenceFileModelInput<T extends org.apache.hadoop.io.Writable> - Class in com.asakusafw.runtime.io.sequencefile
-
A bridge implementation to
SequenceFile
into
ModelInput
.
- SequenceFileModelInput(SequenceFile.Reader) - Constructor for class com.asakusafw.runtime.io.sequencefile.SequenceFileModelInput
-
Creates a new instance.
- SequenceFileModelInput(SequenceFile.Reader, Closeable) - Constructor for class com.asakusafw.runtime.io.sequencefile.SequenceFileModelInput
-
Creates a new instance.
- SequenceFileModelOutput<T> - Class in com.asakusafw.runtime.io.sequencefile
-
- SequenceFileModelOutput(SequenceFile.Writer) - Constructor for class com.asakusafw.runtime.io.sequencefile.SequenceFileModelOutput
-
Creates a new instance.
- SequenceFileModelOutput(SequenceFile.Writer, Closeable) - Constructor for class com.asakusafw.runtime.io.sequencefile.SequenceFileModelOutput
-
Creates a new instance.
- SequenceFileUtil - Class in com.asakusafw.runtime.io.sequencefile
-
Accessors for SequenceFile
.
- sequenceProperty(PropertyName, C) - Method in class com.asakusafw.testdriver.core.DataModelScanner
-
- SequenceType - Class in com.asakusafw.info.hive
-
Represents a Hive sequence type.
- SequenceType(FieldType.TypeName, int) - Constructor for class com.asakusafw.info.hive.SequenceType
-
Creates a new instance.
- SerdeRowFormatInfo - Class in com.asakusafw.info.hive
-
Represents Hive SERDE row format.
- SerdeRowFormatInfo(String, Map<String, String>) - Constructor for class com.asakusafw.info.hive.SerdeRowFormatInfo
-
Creates a new instance.
- SerdeRowFormatInfo(String) - Constructor for class com.asakusafw.info.hive.SerdeRowFormatInfo
-
Creates a new instance.
- SerialFieldBlockParser - Class in com.asakusafw.utils.java.parser.javadoc
-
- SerialFieldBlockParser() - Constructor for class com.asakusafw.utils.java.parser.javadoc.SerialFieldBlockParser
-
Creates a new instance.
- SerialFieldBlockParser(String, String...) - Constructor for class com.asakusafw.utils.java.parser.javadoc.SerialFieldBlockParser
-
Creates a new instance.
- Serialization<T> - Interface in com.asakusafw.utils.io
-
An abstract super interface of object serialization facilities.
- serialize(Collection<? extends TraceSetting>) - Static method in class com.asakusafw.trace.io.TraceSettingSerializer
-
Serializes trace settings.
- Service - Interface in com.asakusafw.yaess.core
-
A common interface for configurable services.
- ServiceProfile<T extends Service> - Class in com.asakusafw.yaess.core
-
A common service profile format for configurable instances.
- ServiceProfile(String, Class<? extends T>, Map<String, String>, ProfileContext) - Constructor for class com.asakusafw.yaess.core.ServiceProfile
-
Creates a new instance.
- session(ClassLoader) - Method in class com.asakusafw.windgate.bootstrap.Classpath
-
Returns a new classpath session.
- SessionException - Exception in com.asakusafw.windgate.core.session
-
An exception that describes failed to attach to a session.
- SessionException(String, SessionException.Reason, Throwable) - Constructor for exception com.asakusafw.windgate.core.session.SessionException
-
Creates a new instance.
- SessionException(String, SessionException.Reason) - Constructor for exception com.asakusafw.windgate.core.session.SessionException
-
Creates a new instance.
- SessionException.Reason - Enum in com.asakusafw.windgate.core.session
-
The reason of the exception.
- SessionMirror - Class in com.asakusafw.windgate.core.session
-
An abstract superclass of session mirror.
- SessionMirror() - Constructor for class com.asakusafw.windgate.core.session.SessionMirror
-
- SessionMirror.Null - Class in com.asakusafw.windgate.core.session
-
- SessionProfile - Class in com.asakusafw.windgate.core.session
-
A configuration for sessions.
- SessionProfile(Class<? extends SessionProvider>, ProfileContext, Map<String, String>) - Constructor for class com.asakusafw.windgate.core.session.SessionProfile
-
Creates a new instance.
- SessionProvider - Class in com.asakusafw.windgate.core.session
-
An abstract super class of session provider.
- SessionProvider() - Constructor for class com.asakusafw.windgate.core.session.SessionProvider
-
- set(ValueOption<?>) - Method in class com.asakusafw.directio.hive.parquet.v1.ValueConverter
-
- set(ValueOption<?>) - Method in class com.asakusafw.directio.hive.parquet.v2.ValueConverter
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.BooleanOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.ByteOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.CharStringOptionDriver
-
- set(Object, Object) - Method in class com.asakusafw.directio.hive.serde.DataModelDriver
-
Sets data model properties from the source object.
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.DateOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.DateTimeOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.DecimalOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.DoubleOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.FloatOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.IntOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.LongOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.ShortOptionDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.StringOptionDriver
-
- set(ValueOption<?>, Object) - Method in interface com.asakusafw.directio.hive.serde.ValueDriver
-
- set(ValueOption<?>, Object) - Method in class com.asakusafw.directio.hive.serde.VarcharStringOptionDriver
-
- set(CompileEnvironment, boolean) - Method in enum com.asakusafw.operator.CompileEnvironment.Support
-
Sets this feature.
- set(RuntimeContext) - Static method in class com.asakusafw.runtime.core.context.RuntimeContext
-
Replaces the global context.
- set(String, String) - Method in class com.asakusafw.runtime.core.HadoopConfiguration
-
- set(String, String) - Method in interface com.asakusafw.runtime.core.ResourceConfiguration
-
Sets a configuration value for the specified key.
- set(T) - Method in class com.asakusafw.runtime.core.util.Shared
-
Manually sets a shared value.
- set(CharSequence) - Method in class com.asakusafw.runtime.io.text.driver.BasicFieldOutput
-
Clears the last output and set the contents.
- set(BigDecimal, ByteOption) - Method in class com.asakusafw.runtime.io.text.value.ByteOptionFieldAdapter
-
- set(BigDecimal, DecimalOption) - Method in class com.asakusafw.runtime.io.text.value.DecimalOptionFieldAdapter
-
- set(BigDecimal, DoubleOption) - Method in class com.asakusafw.runtime.io.text.value.DoubleOptionFieldAdapter
-
- set(BigDecimal, FloatOption) - Method in class com.asakusafw.runtime.io.text.value.FloatOptionFieldAdapter
-
- set(BigDecimal, IntOption) - Method in class com.asakusafw.runtime.io.text.value.IntOptionFieldAdapter
-
- set(BigDecimal, LongOption) - Method in class com.asakusafw.runtime.io.text.value.LongOptionFieldAdapter
-
- set(BigDecimal, T) - Method in class com.asakusafw.runtime.io.text.value.NumericOptionFieldAdapter
-
Sets the given number into the property.
- set(BigDecimal, ShortOption) - Method in class com.asakusafw.runtime.io.text.value.ShortOptionFieldAdapter
-
- set(byte[], int, int, int) - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Sets slice range.
- set(int, int, int) - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSlice
-
Sets slice range.
- set(Object) - Method in class com.asakusafw.runtime.stage.directio.DirectOutputOrder
-
Sets object.
- set(Object) - Method in class com.asakusafw.runtime.stage.directio.StringTemplate
-
Sets an object for generating a name.
- set(Job, List<StageInput>) - Static method in class com.asakusafw.runtime.stage.input.StageInputDriver
-
Sets the input specification for this job.
- set(JobContext, List<StageOutput>) - Static method in class com.asakusafw.runtime.stage.output.BridgeOutputFormat
-
Sets current output information into the current context.
- set(Job, String, Collection<StageOutput>) - Static method in class com.asakusafw.runtime.stage.output.StageOutputDriver
-
Sets the output specification for this job.
- set(int, E) - Method in class com.asakusafw.runtime.value.ValueOptionList
-
- set(T) - Method in class com.asakusafw.windgate.core.util.SafeCloser
-
Sets the target object.
- setAccessMode(JobContext, StageResourceDriver.AccessMode) - Static method in class com.asakusafw.runtime.stage.resource.StageResourceDriver
-
Sets the access mode for stage resources in the job.
- setAllowLinefeed(boolean) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Sets whether each value can contain linefeed.
- setAllowLinefeed(boolean) - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
Sets whether each value can contain linefeed.
- setAlternativeTypes(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.UnionTypeImpl
-
Sets the alternatives.
- setAnnotations(List<? extends Annotation>) - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
Sets the annotations.
- setArguments(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.AlternateConstructorInvocationImpl
-
Sets the actual arguments.
- setArguments(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
Sets the actual arguments.
- setArguments(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
Sets the constructor arguments.
- setArguments(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
Sets the actual arguments.
- setArguments(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
Sets the actual arguments.
- setArguments(Map<String, String>) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the batch arguments map for the target job.
- setArray(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayAccessExpressionImpl
-
Sets the array expression.
- setArrayInitializer(ArrayInitializer) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
Sets the array initializer.
- setAttributes(Collection<? extends Element.Attribute>) - Method in class com.asakusafw.workflow.model.basic.AbstractElement
-
Sets the attributes.
- setBasePath(String) - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Sets the base path.
- setBasePath(String) - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Sets the base path.
- setBatchApplicationsInstallationPath(File) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets the path to the batch applications installation location.
- setBatchArg(String, String) - Method in class com.asakusafw.testdriver.OperatorTestEnvironment
-
Adds a batch argument.
- setBatchArg(String, String) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Adds a batch argument.
- setBatchGetUnit(int) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
- setBatchId(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the batch ID of target job.
- setBatchPutUnit(long) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
- setBlockers(Collection<? extends S>) - Method in class com.asakusafw.workflow.model.basic.AbstractGraphElement
-
Sets blocker elements.
- setBlockParsers(List<? extends JavadocBlockParser>) - Method in class com.asakusafw.utils.java.parser.javadoc.JavadocBaseParser
-
Sets the block parsers.
- setBlocks(List<? extends DocBlock>) - Method in class com.asakusafw.utils.java.internal.model.syntax.JavadocImpl
-
Sets the documentation blocks.
- setBlocks(List<? extends IrDocBlock>) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocComment
-
Sets the element blocks.
- setBlockSize(int) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets the block size (in bytes).
- setBlockSize(int) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets the block size (in bytes).
- setBody(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.CatchClauseImpl
-
Sets the catch
block body.
- setBody(ClassBody) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
Sets the anonymous class body.
- setBody(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the constructor body block.
- setBody(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.DoStatementImpl
-
Sets the loop body.
- setBody(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
Sets the loop body.
- setBody(ClassBody) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
Sets the class body.
- setBody(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
Sets the loop body.
- setBody(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
Sets the initializer body block.
- setBody(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.LabeledStatementImpl
-
Sets the body statement.
- setBody(LambdaBody) - Method in class com.asakusafw.utils.java.internal.model.syntax.LambdaExpressionImpl
-
Sets a body.
- setBody(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the method body.
- setBody(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.SynchronizedStatementImpl
-
Sets the body block.
- setBody(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.WhileStatementImpl
-
Sets the loop body.
- setBodyDeclarations(List<? extends TypeBodyDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
Sets the type member declarations.
- setBodyDeclarations(List<? extends TypeBodyDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassBodyImpl
-
Sets the type member declarations.
- setBodyDeclarations(List<? extends TypeBodyDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the type member declarations.
- setBodyDeclarations(List<? extends TypeBodyDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
Sets the type member declarations.
- setBodyDeclarations(List<? extends TypeBodyDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
Sets the type member declarations.
- setBoundKind(WildcardBoundKind) - Method in class com.asakusafw.utils.java.internal.model.syntax.WildcardImpl
-
Sets the type bound kind.
- setCatchClauses(List<? extends CatchClause>) - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
Sets the catch
clauses.
- setCharsetName(String) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Sets the charset name.
- setCharsetName(String) - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait.Configuration
-
Sets the charset name.
- setCharsetName(String) - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
Sets the charset name.
- setCharsetName(String) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Sets the charset name.
- setCharTypeInfo(int) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets the char type info.
- setCodecName(String) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Sets the codec name.
- setCodecName(String) - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatTrait.Configuration
-
Sets the codec name.
- setCodecName(String) - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
Sets the codec name.
- setColumnName(String) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets the explicit column name.
- setColumnNames(List<String>) - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Sets column names.
- setColumnPresent(boolean) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets whether this field is a table column or not.
- setCombineBlocks(boolean) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Sets whether combines blocks for optimization.
- setComments(List<? extends Comment>) - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
Sets the comments.
- setCompilerDebugLevel(CompilerConfiguration.DebugLevel) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets the compiler debug level.
- setCompilerOptimizeLevel(CompilerConfiguration.OptimizeLevel) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets the compiler optimization level.
- setCompilerWorkingDirectory(File) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets the explicit compiler working directory.
- setCompilerWorkingDirectory(File) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets the compiler working directory.
- setComponentType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayTypeImpl
-
Sets the element type.
- setComponentType(IrDocType) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocArrayType
-
Sets the the element type.
- setCompressionCodecName(CompressionCodecName) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets the compression codec name.
- setCompressionCodecName(CompressionCodecName) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets the compression codec name.
- setCondition(String) - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Sets the condition.
- setCondition(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
Sets the condition term.
- setCondition(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.DoStatementImpl
-
Sets the condition expression.
- setCondition(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
Sets the loop condition expression.
- setCondition(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
Sets the condition expression.
- setCondition(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.WhileStatementImpl
-
Sets the condition expression.
- setConf(Configuration) - Method in class com.asakusafw.runtime.directio.hadoop.ConfigurableBinaryStreamFormat
-
- setConf(Configuration) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- setConf(Configuration) - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.BridgeInputSplit
-
- setConf(Configuration) - Method in class com.asakusafw.runtime.stage.input.BridgeInputFormat.NullInputSplit
-
- setConf(Configuration) - Method in class com.asakusafw.runtime.stage.input.StageInputSplit
-
- setConnectRetryCount(int) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
- setConnectRetryInterval(int) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
- setConstantDeclarations(List<? extends EnumConstantDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
Sets the enum constant declarations.
- setContent(String) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocText
-
Sets the contents.
- setCurrentBatchId(String) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Configures the current batch ID.
- setCurrentExecutionId(String) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Returns the current execution ID.
- setCurrentFlowId(String) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Configures the current flow ID.
- setDataPageSize(int) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets the data page size (in bytes).
- setDataPageSize(int) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets the data page size (in bytes).
- setDataSize(ImporterDescription.DataSize) - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Sets the data size.
- setDataSize(ImporterDescription.DataSize) - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Sets the data size.
- setDataSize(ImporterDescription.DataSize) - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Sets the data size.
- setDateFormat(String) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Configures the
Date
representation.
- setDateFormat(String) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Configures the
Date
representation.
- setDateTimeFormat(String) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
- setDateTimeFormat(String) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
- setDayToCalendar(int, Calendar) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed days from 0001/01/01 (YYYY/MM/DD)
to the corresponded date,
and set it to the target calendar object.
- setDebug(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether compiler should keep debugging information or not.
- setDecimalTypeInfo(int, int) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets the decimal type info.
- setDeclaration(ClassDeclaration) - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalClassDeclarationImpl
-
Sets the declaring class.
- setDeclaringType(IrDocNamedType) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMember
-
Sets the declaring type.
- setDefaultExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
Sets the default annotation element value.
- setDelegate(Report.Delegate) - Static method in class com.asakusafw.runtime.core.legacy.LegacyReport
-
Sets a custom implementation for the current thread.
- setDictionaryPageSize(int) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets the dictionary page size (in bytes).
- setDictionaryPageSize(int) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets the dictionary page size (in bytes).
- setDifferenceSink(DifferenceSinkFactory) - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Sets the difference information sink for this output.
- setDimensionExpressions(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
Sets expressions which represent the number of dimensions for the creating array.
- setElapsedDays(int) - Method in class com.asakusafw.runtime.value.Date
-
Sets the date as number of elapsed days from 0001/01/01
.
- setElapsedSeconds(long) - Method in class com.asakusafw.runtime.value.DateTime
-
Sets the date and time as number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
.
- setElements(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayInitializerImpl
-
Sets the element expressions.
- setElements(List<? extends DocElement>) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocBlockImpl
-
Sets the inline elements.
- setElements(List<? extends AnnotationElement>) - Method in class com.asakusafw.utils.java.internal.model.syntax.NormalAnnotationImpl
-
Sets the annotation elements.
- setElseExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
Sets the false term.
- setElseStatement(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
Sets the false statement.
- setEnableDictionary(boolean) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets whether the dictionary is enabled or not.
- setEnableDictionary(boolean) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets whether the dictionary is enabled or not.
- setEnableHeader(boolean) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Configures whether the header is required.
- setEnableHeader(boolean) - Method in class com.asakusafw.dmdl.directio.tsv.driver.TsvFormatTrait.Configuration
-
Configures whether the header is required.
- setEnableHeader(boolean) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Configures whether the header is required.
- setEnableValidation(boolean) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets whether the schema validation is enabled or not.
- setEnableValidation(boolean) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets whether the schema validation is enabled or not.
- setEnvironmentVariables(Map<String, String>) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the environment variables map of target job.
- setError(JobClient) - Method in class com.asakusafw.yaess.jobqueue.JobClientProvider
-
Tells the error occurred while using the client.
- setErrorCode(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Sets the error code for target job.
- setErrorMessage(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Sets the error message for target job.
- setExceptionTypes(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the exception types.
- setExceptionTypes(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the exception types.
- setExecutionId(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the execution ID of target job.
- setExitCode(Integer) - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Sets the exit code of target job.
- setExplicitCommandPath(File) - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Sets the explicit Hadoop command path.
- setExplicitConfigurationPath(File) - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Sets the explicit Hadoop configuration path.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementImpl
-
Sets the annotation element value.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.AssertStatementImpl
-
Sets the assertion expression.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.CastExpressionImpl
-
Sets the target term.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
Sets the loop target expression.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ExpressionStatementImpl
-
Sets the element expression.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.InstanceofExpressionImpl
-
Sets the target term.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ParenthesizedExpressionImpl
-
Sets the element expression.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ReturnStatementImpl
-
Sets the return value.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.SingleElementAnnotationImpl
-
Sets the value for value
element.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchCaseLabelImpl
-
Sets the case
label value.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchStatementImpl
-
Sets the switch
selector expression.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.SynchronizedStatementImpl
-
Sets the monitor object.
- setExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ThrowStatementImpl
-
Sets the thrown object.
- setExpressions(List<? extends Expression>) - Method in class com.asakusafw.utils.java.internal.model.syntax.StatementExpressionListImpl
-
Sets the expression list.
- setExtraCompilerOption(String, String) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets an extra compiler option.
- setExtraDimensions(int) - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
Sets the extra variable dimensions.
- setExtraDimensions(int) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the number of extra dimensions of the return type.
- setExtraDimensions(int) - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
Sets the extra variable dimensions.
- setFalseFormat(String) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Configures the "false"
representation.
- setFalseFormat(String) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Configures the "false"
representation.
- setFieldMappingStrategy(DataModelMapping.FieldMappingStrategy) - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Sets the field mapping strategy.
- setFinallyBlock(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
Sets the body block of finally
clause.
- setFlowId(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the flow ID of target job.
- setForceConsumeHeader(boolean) - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Sets whether forcibly consumes header cells or not.
- setForceHeader(boolean) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Sets whether the header is always required.
- setForceHeader(boolean) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Sets whether the header is always required.
- setForceQuoteColumns(int...) - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Sets column indices which quoting is always required.
- setFormalParameters(List<? extends FormalParameterDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the formal parameter declarations.
- setFormalParameters(List<? extends DocMethodParameter>) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
Sets the formal parameter declarations.
- setFormalParameters(List<? extends FormalParameterDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the formal parameter declarations.
- setFormatClassName(Name) - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Sets the format class name.
- setFormatClassName(Name) - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Sets the format class name.
- setFragments(List<? extends IrDocFragment>) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBlock
-
Sets the element fragments.
- setFrameworkHomePath(File) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets the Asakusa framework installation path (a.k.a. $ASAKUSA_HOME
).
- setFrameworkHomePath(File) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets the path to the framework installed location.
- setIdentifier(String) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocSimpleName
-
Sets the identifier.
- setImportDeclarations(List<? extends ImportDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
Sets the import declarations.
- setImportKind(ImportKind) - Method in class com.asakusafw.utils.java.internal.model.syntax.ImportDeclarationImpl
-
Sets the import kind.
- setIndex(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayAccessExpressionImpl
-
Sets the index expression.
- setInitialization(ForInitializer) - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
Sets the loop initialization part.
- setInitializer(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.TryResourceImpl
-
Sets the resource expression.
- setInitializer(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
Sets the variable initializer expression.
- setInputPaths(Job, List<Path>) - Static method in class com.asakusafw.runtime.stage.input.TemporaryInputFormat
-
Configures input paths.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the documentation comment.
- setJavadoc(Javadoc) - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
Sets the documentation comment.
- setJobExecutorFactory(JobExecutorFactory) - Method in class com.asakusafw.testdriver.TestDriverBase
-
- setJobId(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Sets the target job ID on current operation.
- setKeepAliveInterval(long) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Sets keep-alive interval.
- setKind(JobStatus.Kind) - Method in class com.asakusafw.yaess.jobqueue.client.JobStatus
-
Sets the kind of this status.
- setLabel(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.LabeledStatementImpl
-
Sets the label name.
- setLeftHandSide(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
Sets the left hand side term.
- setLeftOperand(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
Sets the left term.
- setLibrariesPath(File) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets the search path of the external library files.
- setLibrariesPath(File) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets the path to the external dependency libraries folder.
- setLineBreakInValue(boolean) - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Sets whether allows line breaks in value.
- setLocalFileSystemClassName(String) - Method in class com.asakusafw.testdriver.hadoop.ConfigurationFactory.Preferences
-
Sets the implementation class name of LocalFileSystem
.
- setLocation(IrLocation) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.AbstractIrDocElement
-
- setLocation(IrLocation) - Method in interface com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElement
-
Sets the location where this element appears.
- setLocation(T, JavadocToken, JavadocToken) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockParserUtil
-
Sets the location information for the target element.
- setLocation(T, IrLocation, IrLocation) - Static method in class com.asakusafw.utils.java.parser.javadoc.JavadocBlockParserUtil
-
Sets the location information for the target element.
- setMainClassName(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the main class name of target job.
- setMessage(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.AssertStatementImpl
-
Sets the message expression.
- setMinimumFragmentSize(long) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Configures the minimum fragment size in bytes.
- setModifierKind(ModifierKind) - Method in class com.asakusafw.utils.java.internal.model.syntax.ModifierImpl
-
Sets the modifier kind.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.InitializerDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
Sets the modifiers and annotations.
- setModifiers(List<? extends Attribute>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the modifiers and annotations.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationDeclarationImpl
-
Sets the simple type name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
Sets annotation element name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementImpl
-
Sets annotation element name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the simple type name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the constructor name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocFieldImpl
-
Sets the field name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
Sets the target method or constructor name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodParameterImpl
-
Sets the parameter name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumConstantDeclarationImpl
-
Sets the enum constant name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
Sets the simple type name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldAccessExpressionImpl
-
Sets the field name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
Sets the parameter name.
- setName(Name) - Method in class com.asakusafw.utils.java.internal.model.syntax.ImportDeclarationImpl
-
Sets the import target type or member name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
Sets the simple type name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the method name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
Sets the target method name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
Sets the target method name.
- setName(Name) - Method in class com.asakusafw.utils.java.internal.model.syntax.NamedTypeImpl
-
Sets the type name.
- setName(Name) - Method in class com.asakusafw.utils.java.internal.model.syntax.PackageDeclarationImpl
-
Sets the target package name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.TypeParameterDeclarationImpl
-
Sets the type variable name.
- setName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
Sets the variable name.
- setName(IrDocSimpleName) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMember
-
Sets the member name.
- setName(IrDocSimpleName) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethodParameter
-
Sets the parameter name.
- setName(IrDocName) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocNamedType
-
Sets the type name.
- setName(IrDocSimpleName) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocQualifiedName
-
Sets the simple name.
- setName(String) - Method in interface com.asakusafw.vocabulary.flow.graph.FlowElementDescription
-
Sets name of this element.
- setName(String) - Method in class com.asakusafw.vocabulary.flow.graph.FlowElementResolver
-
Sets the flow element name.
- setName(String) - Method in class com.asakusafw.vocabulary.flow.graph.FlowPartDescription
-
- setName(String) - Method in class com.asakusafw.vocabulary.flow.graph.InputDescription
-
- setName(String) - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription
-
- setName(String) - Method in class com.asakusafw.vocabulary.flow.graph.OutputDescription
-
- setName(String) - Method in class com.asakusafw.vocabulary.flow.util.PseudElementDescription
-
- setNextRecord(Object) - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelMaterializer
-
Sets the next record.
- setNextRecord(Object) - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelMaterializer
-
Sets the next record.
- setNull() - Method in class com.asakusafw.runtime.value.ValueOption
-
- setObject(Object) - Method in class com.asakusafw.runtime.stage.directio.AbstractDirectOutputKey
-
Sets an object for the current position.
- setOnIncompatibleType(DataModelMapping.ExceptionHandlingStrategy) - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Sets the exception handling strategy for incompatible field type.
- setOnMissingSource(DataModelMapping.ExceptionHandlingStrategy) - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Sets the exception handling strategy for missing source fields.
- setOnMissingTarget(DataModelMapping.ExceptionHandlingStrategy) - Method in class com.asakusafw.directio.hive.serde.DataModelMapping
-
Sets the exception handling strategy for missing target fields.
- setOperand(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.PostfixExpressionImpl
-
Sets the operand term.
- setOperand(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.UnaryExpressionImpl
-
Sets the operand term.
- setOperator(InfixOperator) - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
Sets the simple assignment operator, or an infix operator for compound assignment expression.
- setOperator(InfixOperator) - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
Sets the infix operator.
- setOperator(PostfixOperator) - Method in class com.asakusafw.utils.java.internal.model.syntax.PostfixExpressionImpl
-
Sets the postfix operator.
- setOperator(UnaryOperator) - Method in class com.asakusafw.utils.java.internal.model.syntax.UnaryExpressionImpl
-
Sets the unary operator.
- setOptimizations(Collection<String>) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
Sets the enabled optimization symbols.
- setOptimize(int) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Configures the compiler optimization level.
- setOptional(Boolean) - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Sets whether the target input is optional or not.
- setOrigin(FlowGraph) - Method in class com.asakusafw.vocabulary.flow.graph.FlowGraph
-
Sets the original flow graph object.
- setOrigin(FlowElementDescription) - Method in class com.asakusafw.vocabulary.flow.graph.OperatorDescription.Builder
-
Sets the original description for the building description.
- setOriginalAst(AstNode, boolean) - Method in class com.asakusafw.dmdl.directio.hive.common.BaseTrait
-
Sets the original AST.
- setOutputPath(JobContext, Path) - Static method in class com.asakusafw.runtime.stage.output.TemporaryOutputFormat
-
Configures output path.
- setOutputStaging(boolean) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Sets whether output staging is required.
- setOutputStreaming(boolean) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Sets whether output streaming is required.
- setPackageDeclaration(PackageDeclaration) - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
Sets the package declaration.
- setParameter(FormalParameterDeclaration) - Method in class com.asakusafw.utils.java.internal.model.syntax.CatchClauseImpl
-
Sets the exception parameter.
- setParameter(FormalParameterDeclaration) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnhancedForStatementImpl
-
Sets the loop variable declaration.
- setParameter(FormalParameterDeclaration) - Method in class com.asakusafw.utils.java.internal.model.syntax.TryResourceImpl
-
Sets the resource variable declaration.
- setParameters(List<? extends LambdaParameter>) - Method in class com.asakusafw.utils.java.internal.model.syntax.LambdaExpressionImpl
-
Sets a parameters.
- setParameters(List<? extends IrDocMethodParameter>) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethod
-
Sets the method or constructor parameters.
- setParameters(T) - Method in interface com.asakusafw.windgate.core.vocabulary.DataModelJdbcSupport.DataModelPreparedStatement
-
Sets the parameters to corresponding
PreparedStatement
using the specified data model.
- setPath(String) - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Sets the path.
- setPhase(ExecutionPhase) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the phase kind of target job.
- setPosition(int) - Method in class com.asakusafw.runtime.stage.directio.AbstractDirectOutputKey
-
Sets new position.
- setPreferredFragmentSize(long) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Configures the preferred fragment size in bytes.
- setProfileName(String) - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Sets the profile name.
- setProfileName(String) - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Sets the profile name.
- setProgress(double) - Method in class com.asakusafw.yaess.basic.LoggingExecutionMonitor
-
- setProgress(double) - Method in interface com.asakusafw.yaess.core.ExecutionMonitor
-
Sets the progress of current task and notify this event to the corresponding receiver.
- setProgress(double) - Method in class com.asakusafw.yaess.core.JobMonitor
-
- setProgress(double) - Method in class com.asakusafw.yaess.flowlog.FlowLogger
-
- setProperties(Map<String, String>) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the Hadoop properties map of target job.
- setProperty(int, Object) - Method in class com.asakusafw.runtime.stage.directio.StringTemplate
-
Sets a property value.
- setQualifier(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
Sets the qualifier expression.
- setQualifier(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorReferenceExpressionImpl
-
Sets the owner type.
- setQualifier(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldAccessExpressionImpl
-
Sets the qualifier expression.
- setQualifier(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
Sets the qualifier expression or type.
- setQualifier(TypeOrExpression) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
Sets the qualifier expression or type.
- setQualifier(Name) - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedNameImpl
-
Sets the name qualifier.
- setQualifier(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedTypeImpl
-
Sets the type qualifier.
- setQualifier(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
Sets the qualifier expression.
- setQualifier(NamedType) - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperImpl
-
Sets the type qualifier.
- setQualifier(NamedType) - Method in class com.asakusafw.utils.java.internal.model.syntax.ThisImpl
-
Sets the type qualifier.
- setQualifier(IrDocName) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocQualifiedName
-
Sets the name qualifier.
- setResourceGenerated(ClassDescription) - Method in class com.asakusafw.operator.CompileEnvironment
-
Sets the target resources is generated.
- setResourcePattern(String) - Method in class com.asakusafw.dmdl.directio.util.DirectFileInputDescriptionGenerator.Description
-
Sets the resource pattern.
- setResourcePattern(String) - Method in class com.asakusafw.dmdl.directio.util.DirectFileOutputDescriptionGenerator.Description
-
Sets the resource pattern.
- setResources(List<? extends TryResource>) - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
Sets the resources.
- setResultFilter(UnaryOperator<DataModelSource>) - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Sets the data model source filter for actual results of this output.
- setResultSink(DataModelSinkFactory) - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Sets the result data sink for this output.
- setReturnType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the return type.
- setRightHandSide(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.AssignmentExpressionImpl
-
Sets the right hand side term.
- setRightOperand(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.InfixExpressionImpl
-
Sets the right term.
- setRollforwardThreads(int) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Sets the number of threads to move staged files to committed area.
- Sets - Class in com.asakusafw.utils.collections
-
- setSecondToCalendar(long, Calendar) - Static method in class com.asakusafw.runtime.value.DateUtil
-
Converts the number of elapsed seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
to the corresponded date,
and set it to the target calendar object.
- setSeparatorChar(char) - Method in class com.asakusafw.runtime.io.csv.CsvConfiguration
-
Sets the field separator character.
- setSimpleName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedNameImpl
-
Sets the simple name on the tail.
- setSimpleName(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.QualifiedTypeImpl
-
Sets the simple type name.
- setSkipCleanInput(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to cleanup input data source (default: false
).
- setSkipCleanOutput(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to cleanup output data source (default: false
).
- setSkipPrepareInput(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to prepare input data source (default: false
).
- setSkipPrepareOutput(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to prepare output data source (default: false
).
- setSkipRunJobflow(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to execute jobflows (default: false
).
- setSkipValidateCondition(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to cleanup input data source (default: false
).
- setSkipVerify(boolean) - Method in class com.asakusafw.testdriver.TestDriverContext
-
Sets whether this test skips to verify the testing result (default: false
).
- setSlotSpec(T, SortableSlot) - Method in class com.asakusafw.runtime.stage.collector.SlotDistributor
-
Sets sorting information into the target slot.
- setSource(DataModelSourceFactory) - Method in class com.asakusafw.testdriver.DriverInputBase
-
Sets the data source for this input.
- setSpecial(CharSequence, Number, DoubleOption) - Method in class com.asakusafw.runtime.io.text.value.DoubleOptionFieldAdapter
-
- setSpecial(CharSequence, Number, FloatOption) - Method in class com.asakusafw.runtime.io.text.value.FloatOptionFieldAdapter
-
- setSpecial(CharSequence, Number, T) - Method in class com.asakusafw.runtime.io.text.value.NumericOptionFieldAdapter
-
Sets the given special number into the property.
- setSplitBlocks(boolean) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceProfile
-
Sets whether splits blocks for optimization.
- setSplitCombinerClass(JobContext, Class<? extends SplitCombiner>) - Static method in class com.asakusafw.runtime.stage.input.StageInputFormat
-
- setStageId(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobScript
-
Sets the stage ID of target job.
- setStatements(List<? extends Statement>) - Method in class com.asakusafw.utils.java.internal.model.syntax.BlockImpl
-
Sets the element statements.
- setStatements(List<? extends Statement>) - Method in class com.asakusafw.utils.java.internal.model.syntax.SwitchStatementImpl
-
Sets the switch
body statements.
- setString(String) - Method in class com.asakusafw.utils.java.internal.model.syntax.BlockCommentImpl
-
Sets the comment text.
- setString(String) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocTextImpl
-
Sets the comment text.
- setString(String) - Method in class com.asakusafw.utils.java.internal.model.syntax.LineCommentImpl
-
Sets the comment text.
- setStringTypeInfo() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets the string type info.
- setSuperClass(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the super class.
- setSuperInterfaceTypes(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the super interface types.
- setSuperInterfaceTypes(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.EnumDeclarationImpl
-
Sets the super interface types.
- setSuperInterfaceTypes(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
Sets the super interface types.
- setSupportClassName(Name) - Method in class com.asakusafw.dmdl.windgate.util.FsProcessDescriptionGenerator.Description
-
Sets the format class name.
- setSupportClassName(Name) - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Sets the format class name.
- setTableName(String) - Method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileTrait
-
Sets the explicit table name.
- setTableName(String) - Method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileTrait
-
Sets the explicit table name.
- setTableName(String) - Method in class com.asakusafw.dmdl.windgate.util.JdbcProcessDescriptionGenerator.Description
-
Sets the table name.
- setTag(String) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocBlockImpl
-
Sets the tag text.
- setTag(String) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBlock
-
Sets the block tag.
- setTarget(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.BreakStatementImpl
-
Sets the target label.
- setTarget(SimpleName) - Method in class com.asakusafw.utils.java.internal.model.syntax.ContinueStatementImpl
-
Sets the target label.
- setTestFinished(Date) - Method in class com.asakusafw.testdriver.core.VerifyContext
-
Set time when test was finished.
- setThenExpression(Expression) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConditionalExpressionImpl
-
Sets the truth term.
- setThenStatement(Statement) - Method in class com.asakusafw.utils.java.internal.model.syntax.IfStatementImpl
-
Sets the truth statement.
- setTimestampTypeInfo() - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets the timestamp type info.
- setToken(String) - Method in class com.asakusafw.utils.java.internal.model.syntax.LiteralImpl
-
Sets the literal token.
- setToken(String) - Method in class com.asakusafw.utils.java.internal.model.syntax.SimpleNameImpl
-
Sets the identifier.
- setToken(String) - Method in class com.asakusafw.yaess.jobqueue.client.JobId
-
Sets the token for this ID.
- setTrueFormat(String) - Method in class com.asakusafw.dmdl.directio.csv.driver.CsvFormatTrait.Configuration
-
Configures the "true"
representation.
- setTrueFormat(String) - Method in class com.asakusafw.dmdl.windgate.csv.driver.CsvSupportTrait.Configuration
-
Configures the "true"
representation.
- setTruncateStatement(String) - Method in class com.asakusafw.windgate.jdbc.JdbcProfile
-
- setTryBlock(Block) - Method in class com.asakusafw.utils.java.internal.model.syntax.TryStatementImpl
-
Sets the body block of try
clause.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.AnnotationElementDeclarationImpl
-
Sets annotation element type.
- setType(ArrayType) - Method in class com.asakusafw.utils.java.internal.model.syntax.ArrayCreationExpressionImpl
-
Sets the target array type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.CastExpressionImpl
-
Sets the target type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
Sets the target type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassLiteralImpl
-
Sets the target type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocFieldImpl
-
Sets the owner type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodImpl
-
Sets the owner type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodParameterImpl
-
Sets the parameter type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
Sets the field type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
Sets the variable type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.InstanceofExpressionImpl
-
Sets the target type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
Sets the variable type.
- setType(NamedType) - Method in class com.asakusafw.utils.java.internal.model.syntax.MarkerAnnotationImpl
-
Sets the annotation type.
- setType(NamedType) - Method in class com.asakusafw.utils.java.internal.model.syntax.NormalAnnotationImpl
-
Sets the annotation type.
- setType(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.ParameterizedTypeImpl
-
Sets the non-parameterized type.
- setType(NamedType) - Method in class com.asakusafw.utils.java.internal.model.syntax.SingleElementAnnotationImpl
-
Sets the annotation type.
- setType(IrDocType) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethodParameter
-
Sets the parameter type.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.AlternateConstructorInvocationImpl
-
Sets the type arguments.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassInstanceCreationExpressionImpl
-
Sets the type arguments.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorReferenceExpressionImpl
-
Sets the type arguments.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodInvocationExpressionImpl
-
Sets the type arguments.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodReferenceExpressionImpl
-
Sets the type arguments.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ParameterizedTypeImpl
-
Sets the type arguments.
- setTypeArguments(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
Sets the type arguments.
- setTypeBound(Type) - Method in class com.asakusafw.utils.java.internal.model.syntax.WildcardImpl
-
Sets the bound type.
- setTypeBounds(List<? extends Type>) - Method in class com.asakusafw.utils.java.internal.model.syntax.TypeParameterDeclarationImpl
-
Sets the bound types.
- setTypeDeclarations(List<? extends TypeDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.CompilationUnitImpl
-
Sets the type declarations.
- setTypeKind(BasicTypeKind) - Method in class com.asakusafw.utils.java.internal.model.syntax.BasicTypeImpl
-
Sets the type kind.
- setTypeKind(IrBasicTypeKind) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocBasicType
-
Sets the type kind.
- setTypeParameters(List<? extends TypeParameterDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ClassDeclarationImpl
-
Sets the type parameter declarations.
- setTypeParameters(List<? extends TypeParameterDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.ConstructorDeclarationImpl
-
Sets the type parameter declarations.
- setTypeParameters(List<? extends TypeParameterDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.InterfaceDeclarationImpl
-
Sets the type parameter declarations.
- setTypeParameters(List<? extends TypeParameterDeclaration>) - Method in class com.asakusafw.utils.java.internal.model.syntax.MethodDeclarationImpl
-
Sets the type parameter declarations.
- Setup - Class in com.asakusafw.operation.tools.setup
-
Validates Asakusa framework installation.
- setup(ResourceConfiguration) - Method in class com.asakusafw.runtime.core.legacy.LegacyBatchContext.Initializer
-
- setup(ResourceConfiguration) - Method in class com.asakusafw.runtime.core.legacy.RuntimeResource.DelegateRegisterer
-
- setup(ResourceConfiguration) - Method in interface com.asakusafw.runtime.core.legacy.RuntimeResource
-
Initializes this resource.
- setup(ResourceConfiguration) - Method in class com.asakusafw.runtime.directio.api.legacy.LegacyDirectIo.Initializer
-
- setup(JobContext) - Method in interface com.asakusafw.runtime.flow.FlowResource
-
Initializes this resource.
- setup(JobContext) - Method in class com.asakusafw.runtime.flow.join.JoinResource
-
- setup() - Method in class com.asakusafw.runtime.flow.RuntimeResourceManager
-
Initializes the managed resources.
- setup(Mapper<Object, Writable, SortableSlot, WritableSlot>.Context) - Method in class com.asakusafw.runtime.stage.collector.SlotDirectMapper
-
- setup(Reducer<SortableSlot, WritableSlot, Object, Object>.Context) - Method in class com.asakusafw.runtime.stage.collector.SlotSorter
-
- setup(Reducer<AbstractDirectOutputKey, AbstractDirectOutputValue, Object, Object>.Context) - Method in class com.asakusafw.runtime.stage.directio.DirectOutputReducer
-
- setup(Mapper.Context) - Method in class com.asakusafw.runtime.stage.input.StageInputMapper
-
- setup(Mapper<Object, T, Object, T>.Context) - Method in class com.asakusafw.runtime.stage.preparator.PreparatorMapper
-
- setUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.basic.ProcessCommandScriptHandler
-
- setUp(ExecutionMonitor, ExecutionContext) - Method in interface com.asakusafw.yaess.core.ExecutionScriptHandler
-
Setup the target environment.
- setUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
Setup the target environment.
- setUp(ExecutionMonitor, ExecutionContext) - Method in class com.asakusafw.yaess.multidispatch.ExecutionScriptHandlerDispatcher
-
- setupAttemptOutput(OutputAttemptContext) - Method in interface com.asakusafw.runtime.directio.DirectDataSource
-
Prepares output area for the attempt.
- setupAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- setupAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceCore
-
- setupAttemptOutput(OutputAttemptContext) - Method in class com.asakusafw.runtime.directio.keepalive.KeepAliveDataSource
-
- setUpdate(StatementExpressionList) - Method in class com.asakusafw.utils.java.internal.model.syntax.ForStatementImpl
-
Sets the loop update part.
- setupJob(JobContext) - Method in class com.asakusafw.runtime.stage.output.LegacyBridgeOutputCommitter
-
- SetupJob - Class in com.asakusafw.yaess.core.task
-
- SetupJob(ExecutionScriptHandler<?>) - Constructor for class com.asakusafw.yaess.core.task.SetupJob
-
Creates a new instance.
- setupTask(TaskAttemptContext) - Method in class com.asakusafw.runtime.stage.output.LegacyBridgeOutputCommitter
-
- setupTransactionOutput(OutputTransactionContext) - Method in interface com.asakusafw.runtime.directio.DirectDataSource
-
Prepares output area for the transaction.
- setupTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSource
-
- setupTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.hadoop.HadoopDataSourceCore
-
- setupTransactionOutput(OutputTransactionContext) - Method in class com.asakusafw.runtime.directio.keepalive.KeepAliveDataSource
-
- setVarcharTypeInfo(int) - Method in class com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait
-
Sets the varchar type info.
- setVariableArity(boolean) - Method in class com.asakusafw.utils.java.internal.model.syntax.DocMethodParameterImpl
-
Sets whether this parameter is variable arity or not.
- setVariableArity(boolean) - Method in class com.asakusafw.utils.java.internal.model.syntax.FormalParameterDeclarationImpl
-
Sets whether the parameter is variable arity or not.
- setVariableArity(boolean) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocMethodParameter
-
Sets the whether this parameter is variable arity.
- setVariableDeclarators(List<? extends VariableDeclarator>) - Method in class com.asakusafw.utils.java.internal.model.syntax.FieldDeclarationImpl
-
Sets the field variable declarators.
- setVariableDeclarators(List<? extends VariableDeclarator>) - Method in class com.asakusafw.utils.java.internal.model.syntax.LocalVariableDeclarationImpl
-
Sets the variable declarators.
- setVerifier(VerifierFactory) - Method in class com.asakusafw.testdriver.DriverOutputBase
-
Sets the verify rule for this output.
- setWriterVersion(ParquetProperties.WriterVersion) - Method in class com.asakusafw.directio.hive.parquet.v1.ParquetFileOutput.Options
-
Sets the writer version.
- setWriterVersion(ParquetProperties.WriterVersion) - Method in class com.asakusafw.directio.hive.parquet.v2.ParquetFileOutput.Options
-
Sets the writer version.
- Shared<T> - Class in com.asakusafw.runtime.core.util
-
An abstract super class of shared object holder for operator classes.
- Shared() - Constructor for class com.asakusafw.runtime.core.util.Shared
-
- Shared.InitializationException - Exception in com.asakusafw.runtime.core.util
-
Represents an exception occurred while
initializing
shared values.
- SharedObjectCleaner - Class in com.asakusafw.testdriver
-
Test helper for operator classes with
Shared
class fields.
- SharedObjectCleaner() - Constructor for class com.asakusafw.testdriver.SharedObjectCleaner
-
- SheetBuilder - Class in com.asakusafw.testdata.generator.excel
-
Appends test data/rule sheets to the workbook.
- SheetBuilder(Workbook, ModelDeclaration) - Constructor for class com.asakusafw.testdata.generator.excel.SheetBuilder
-
Creates a new instance.
- SheetBuilder(Workbook, SpreadsheetVersion, ModelDeclaration) - Constructor for class com.asakusafw.testdata.generator.excel.SheetBuilder
-
Creates a new instance.
- SheetEditor - Class in com.asakusafw.testdata.generator.excel
-
Excel sheet editor for adding test data/rule sheets to the workbook.
- SheetEditor(Workbook) - Constructor for class com.asakusafw.testdata.generator.excel.SheetEditor
-
Creates a new instance.
- SheetFormat - Class in com.asakusafw.testdata.generator.excel
-
Generating format of each Excel sheet.
- SheetFormat.Kind - Enum in com.asakusafw.testdata.generator.excel
-
Kind of sheet style.
- ShortInfo - Class in com.asakusafw.info.value
-
Represents a short
value.
- ShortOption - Class in com.asakusafw.runtime.value
-
Represents a short
value which can be null
.
- ShortOption() - Constructor for class com.asakusafw.runtime.value.ShortOption
-
Creates a new instance which represents null
value.
- ShortOption(short) - Constructor for class com.asakusafw.runtime.value.ShortOption
-
Creates a new instance which represents the specified value.
- ShortOptionDriver - Class in com.asakusafw.directio.hive.serde
-
- ShortOptionDriver(ShortObjectInspector) - Constructor for class com.asakusafw.directio.hive.serde.ShortOptionDriver
-
Creates a new instance.
- ShortOptionFieldAdapter - Class in com.asakusafw.runtime.io.text.value
-
- ShortOptionFieldAdapter.Builder - Class in com.asakusafw.runtime.io.text.value
-
- ShortOptionInspector - Class in com.asakusafw.directio.hive.serde
-
- ShortOptionInspector() - Constructor for class com.asakusafw.directio.hive.serde.ShortOptionInspector
-
Creates a new instance.
- ShortOptionPropertyAdapter - Class in com.asakusafw.runtime.io.json.value
-
- ShortOptionPropertyAdapter.Builder - Class in com.asakusafw.runtime.io.json.value
-
- shortProperty(PropertyName, C) - Method in class com.asakusafw.testdriver.core.DataModelScanner
-
Invoked each
Short
property.
- shortProperty(PropertyName, JsonObject) - Method in class com.asakusafw.testdriver.json.JsonObjectDriver
-
- ShowAllParameter - Class in com.asakusafw.info.cli.generate.dot
-
Provides verbose flag for draw group.
- ShowAllParameter() - Constructor for class com.asakusafw.info.cli.generate.dot.ShowAllParameter
-
- shrink() - Method in class com.asakusafw.runtime.flow.ArrayListBuffer
-
- shrink() - Method in class com.asakusafw.runtime.flow.FileMapListBuffer
-
- shrink() - Method in interface com.asakusafw.runtime.flow.ListBuffer
-
Shrinks this buffer.
- ShuffleKey<TGroup extends WritableRawComparable,TOrder extends WritableRawComparable> - Class in com.asakusafw.runtime.io.util
-
An abstract implementation of shuffling keys.
- ShuffleKey(Class<TGroup>, Class<TOrder>) - Constructor for class com.asakusafw.runtime.io.util.ShuffleKey
-
Creates a new instance.
- ShuffleKey(TGroup, TOrder) - Constructor for class com.asakusafw.runtime.io.util.ShuffleKey
-
Creates a new instance.
- ShuffleKey - Class in com.asakusafw.vocabulary.flow.graph
-
Represents shuffle key properties.
- ShuffleKey(List<String>, List<ShuffleKey.Order>) - Constructor for class com.asakusafw.vocabulary.flow.graph.ShuffleKey
-
Creates a new instance.
- ShuffleKey.AbstractGroupComparator - Class in com.asakusafw.runtime.io.util
-
An abstract implementation of grouping comparator for
ShuffleKey
.
- ShuffleKey.AbstractOrderComparator - Class in com.asakusafw.runtime.io.util
-
An abstract implementation of ordering comparator for
ShuffleKey
.
- ShuffleKey.Direction - Enum in com.asakusafw.vocabulary.flow.graph
-
Represents ordering direction.
- ShuffleKey.Order - Class in com.asakusafw.vocabulary.flow.graph
-
Represents ordering information.
- ShuffleKey.Partitioner - Class in com.asakusafw.runtime.io.util
-
- ShuffleReader - Class in com.asakusafw.runtime.mapreduce.simple
-
Read shuffle outputs.
- ShuffleReader(KeyValueSorter<?, ?>, Progress) - Constructor for class com.asakusafw.runtime.mapreduce.simple.ShuffleReader
-
Creates a new instance.
- ShuffleWriter<K,V> - Class in com.asakusafw.runtime.mapreduce.simple
-
A RecordWriter
for shuffle input.
- ShuffleWriter(KeyValueSorter<K, V>) - Constructor for class com.asakusafw.runtime.mapreduce.simple.ShuffleWriter
-
Creates a new instance.
- SimpleCreateTable - Class in com.asakusafw.info.hive.syntax
-
Represents CREATE TABLE
statement in Hive.
- SimpleCreateTable(TableInfo) - Constructor for class com.asakusafw.info.hive.syntax.SimpleCreateTable
-
Creates a new instance.
- SimpleDataDefinition<T> - Class in com.asakusafw.runtime.directio
-
- SimpleDataModelDefinition<T> - Class in com.asakusafw.testdriver.model
-
- SimpleDataModelDefinition(Class<T>) - Constructor for class com.asakusafw.testdriver.model.SimpleDataModelDefinition
-
Creates a new instance.
- SimpleJobRunner - Class in com.asakusafw.runtime.mapreduce.simple
-
An implementation of
JobRunner
using simplified map-reduce engine.
- SimpleJobRunner() - Constructor for class com.asakusafw.runtime.mapreduce.simple.SimpleJobRunner
-
- simpleName - Variable in class com.asakusafw.dmdl.model.AstQualifiedName
-
The simple name of this name in tail.
- SimpleName - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents simple names.
- SimpleNameImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SimpleNameImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SimpleNameImpl
-
- SimulationSupport - Annotation Type in com.asakusafw.runtime.core.context
-
A marker annotation which represents the component supports simulated execution.
- SingleElementAnnotation - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents single element annotations which only can have value
element.
- SingleElementAnnotationImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SingleElementAnnotationImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SingleElementAnnotationImpl
-
- SingleLinkedList<E> - Class in com.asakusafw.utils.collections
-
Unmodifiable linked list.
- SingleLinkedList() - Constructor for class com.asakusafw.utils.collections.SingleLinkedList
-
Creates a new instance without elements.
- SingleLinkedList(List<? extends E>) - Constructor for class com.asakusafw.utils.collections.SingleLinkedList
-
Creates a new instance from
List
.
- SingleLinkedList(Iterable<? extends E>) - Constructor for class com.asakusafw.utils.collections.SingleLinkedList
-
- Sink<T> - Interface in com.asakusafw.utils.io
-
An abstract super interface of object sinks.
- size() - Method in class com.asakusafw.runtime.flow.ArrayListBuffer
-
- size() - Method in class com.asakusafw.runtime.flow.FileMapListBuffer
-
- size() - Method in interface com.asakusafw.runtime.io.util.Tuple
-
Returns the number of elements in this tuple.
- size() - Method in class com.asakusafw.runtime.io.util.WritableRawComparableTuple
-
- size() - Method in class com.asakusafw.runtime.value.ValueOptionMap
-
- size() - Method in class com.asakusafw.utils.collections.SingleLinkedList
-
Returns number of elements in this list.
- skip(long) - Method in class com.asakusafw.runtime.directio.util.CountInputStream
-
- skip(long) - Method in class com.asakusafw.runtime.directio.util.DelimiterRangeInputStream
-
Deprecated.
- skip(long) - Method in class com.asakusafw.runtime.io.tsv.DelimiterRangeInputStream
-
- skip(long) - Method in class com.asakusafw.runtime.io.util.DataBufferInputStream
-
- skip(long) - Method in class com.asakusafw.runtime.io.util.ZipEntryInputStream
-
- skip(long) - Method in class com.asakusafw.windgate.hadoopfs.ssh.ZipEntryInputStream
-
- skip(long) - Method in class com.asakusafw.windgate.stream.CountingInputStream
-
- skipBytes(int) - Method in class com.asakusafw.runtime.io.util.BufferedFileInput
-
- skipBytes(int) - Method in class com.asakusafw.runtime.io.util.DataBuffer
-
- skipBytes(int) - Method in class com.asakusafw.runtime.io.util.DataBufferInputStream
-
- skipCleanInput(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips truncating test input data.
- skipCleanOutput(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips truncating test output data.
- skipPrepareInput(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips preparing test input data.
- skipPrepareOutput(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips preparing test output data.
- skipRunJobflow(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips executing jobflows.
- skipValidateCondition(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips verifying test conditions.
- skipVerify(boolean) - Method in class com.asakusafw.testdriver.TestDriverBase
-
Sets whether skips verifying test results.
- SlotDirectMapper - Class in com.asakusafw.runtime.stage.collector
-
The skeletal implementation to output values directly.
- SlotDirectMapper() - Constructor for class com.asakusafw.runtime.stage.collector.SlotDirectMapper
-
- SlotDistributor<T extends org.apache.hadoop.io.Writable> - Class in com.asakusafw.runtime.stage.collector
-
The skeletal implementation of Hadoop Mapper for distributing values into
SlotSorter
.
- SlotDistributor() - Constructor for class com.asakusafw.runtime.stage.collector.SlotDistributor
-
- SlotSorter - Class in com.asakusafw.runtime.stage.collector
-
A skeletal implementation of Hadoop Reducer for partitioning by their slot.
- SlotSorter() - Constructor for class com.asakusafw.runtime.stage.collector.SlotSorter
-
- SnappyConfigurator - Class in com.asakusafw.testdriver.configurator
-
Configures testing environment for snappy.
- SnappyConfigurator() - Constructor for class com.asakusafw.testdriver.configurator.SnappyConfigurator
-
- soon() - Method in class com.asakusafw.vocabulary.batch.BatchDescription.DependencyBuilder
-
Completes registering job without any dependencies.
- sort() - Method in class com.asakusafw.runtime.mapreduce.simple.KeyValueSorter
-
Sort previously added key-value pairs.
- sort(Comparator<? super E>) - Method in class com.asakusafw.runtime.value.ValueOptionList
-
- SortableSlot - Class in com.asakusafw.runtime.stage.collector
-
A sortable data slot.
- SortableSlot() - Constructor for class com.asakusafw.runtime.stage.collector.SortableSlot
-
- SortableSlot.Comparator - Class in com.asakusafw.runtime.stage.collector
-
- SortableSlot.Partitioner - Class in com.asakusafw.runtime.stage.collector
-
- sortPostOrder(Graph<? extends V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Sorts the vertices from the tail to head topologically, and returns their list.
- source - Variable in class com.asakusafw.dmdl.model.AstPropertyFolding
-
The property name from the source model.
- source - Variable in class com.asakusafw.dmdl.model.AstPropertyMapping
-
The property name from the source model.
- Source(InputSplit, Class<? extends InputFormat<?, ?>>) - Constructor for class com.asakusafw.runtime.stage.input.StageInputSplit.Source
-
Creates a new instance.
- Source<T> - Interface in com.asakusafw.utils.io
-
An abstract super interface of object sources.
- Source<T> - Interface in com.asakusafw.vocabulary.flow
-
Represents an abstract data source for downstream operators and flow outputs.
- SourceDataModelSource<T> - Class in com.asakusafw.testdriver.core
-
- SourceDataModelSource(DataModelDefinition<T>, Source<? extends T>) - Constructor for class com.asakusafw.testdriver.core.SourceDataModelSource
-
Creates a new instance.
- SourceDataModelSourceFactory - Class in com.asakusafw.testdriver.core
-
- SourceDataModelSourceFactory(Class<T>, Provider<? extends Source<? extends T>>) - Constructor for class com.asakusafw.testdriver.core.SourceDataModelSourceFactory
-
Creates a new instance.
- SourceDataModelSourceFactory(Provider<? extends Source<?>>) - Constructor for class com.asakusafw.testdriver.core.SourceDataModelSourceFactory
-
Creates a new instance.
- SourceDriver<T> - Interface in com.asakusafw.windgate.core.resource
-
An abstract super interface of data source driver.
- sourceFile - Variable in class com.asakusafw.dmdl.Region
-
The source file identifier.
- SourceProvider - Interface in com.asakusafw.testdriver.core
-
- Sources - Class in com.asakusafw.utils.io
-
- special(String) - Static method in class com.asakusafw.operator.model.OperatorDescription.Reference
-
Creates a new instance.
- SpecialReference(String) - Constructor for class com.asakusafw.operator.model.OperatorDescription.SpecialReference
-
Creates a new instance.
- SpiDataModelAdapter - Class in com.asakusafw.testdriver.core
-
- SpiDataModelAdapter(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiDataModelAdapter
-
Creates a new instance.
- SpiDataModelSinkProvider - Class in com.asakusafw.testdriver.core
-
- SpiDataModelSinkProvider(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiDataModelSinkProvider
-
Creates a new instance.
- SpiDataModelSourceProvider - Class in com.asakusafw.testdriver.core
-
- SpiDataModelSourceProvider(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiDataModelSourceProvider
-
Creates a new instance.
- SpiDifferenceSinkProvider - Class in com.asakusafw.testdriver.core
-
- SpiDifferenceSinkProvider(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiDifferenceSinkProvider
-
Creates a new instance.
- SpiExporterRetriever - Class in com.asakusafw.testdriver.core
-
- SpiExporterRetriever(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiExporterRetriever
-
Creates a new instance.
- SpiExporterRetriever(List<? extends ExporterRetriever<?>>) - Constructor for class com.asakusafw.testdriver.core.SpiExporterRetriever
-
Creates a new instance.
- SpiImporterPreparator - Class in com.asakusafw.testdriver.core
-
- SpiImporterPreparator(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiImporterPreparator
-
Creates a new instance.
- SpiImporterPreparator(List<? extends ImporterPreparator<?>>) - Constructor for class com.asakusafw.testdriver.core.SpiImporterPreparator
-
Creates a new instance.
- Spill - Annotation Type in com.asakusafw.vocabulary.model
-
An annotation represents which the annotated element can spill its contents into backing store.
- SpiVerifyRuleProvider - Class in com.asakusafw.testdriver.core
-
- SpiVerifyRuleProvider(ClassLoader) - Constructor for class com.asakusafw.testdriver.core.SpiVerifyRuleProvider
-
Creates a new instance.
- Split - Annotation Type in com.asakusafw.vocabulary.operator
-
分割演算子を表すメソッドに付与する注釈。
- SplitCombiner - Class in com.asakusafw.runtime.stage.input
-
- SplitCombiner() - Constructor for class com.asakusafw.runtime.stage.input.SplitCombiner
-
- SplitCombiner.Util - Class in com.asakusafw.runtime.stage.input
-
- splitInto(A, B) - Method in interface com.asakusafw.vocabulary.model.JoinedModel.Interface
-
Deprecated.
Sets properties of the joined result into original data models.
- SplitOperatorDriver - Class in com.asakusafw.operator.builtin
-
- SplitOperatorDriver() - Constructor for class com.asakusafw.operator.builtin.SplitOperatorDriver
-
- SshCommandScriptHandler - Class in com.asakusafw.yaess.jsch
-
- SshCommandScriptHandler() - Constructor for class com.asakusafw.yaess.jsch.SshCommandScriptHandler
-
- SshConnection - Interface in com.asakusafw.windgate.hadoopfs.ssh
-
A remote command execution via SSH.
- SshHadoopScriptHandler - Class in com.asakusafw.yaess.jsch
-
- SshHadoopScriptHandler() - Constructor for class com.asakusafw.yaess.jsch.SshHadoopScriptHandler
-
- SshProfile - Class in com.asakusafw.windgate.hadoopfs.ssh
-
- SshProfile(String, String, String, String, int, String, String, CompressionCodec, Map<String, String>) - Constructor for class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
- SshProfile(String, String, String, String, int, String, String, Map<String, String>) - Constructor for class com.asakusafw.windgate.hadoopfs.ssh.SshProfile
-
Creates a new instance.
- StageConfigurator - Class in com.asakusafw.runtime.stage
-
Configures a Job
in stages.
- StageConfigurator() - Constructor for class com.asakusafw.runtime.stage.StageConfigurator
-
- StageConstants - Class in com.asakusafw.runtime.stage
-
Constants for each stage.
- StageInput - Class in com.asakusafw.runtime.stage
-
Represents a stage input.
- StageInput(String, Class<? extends InputFormat>, Class<? extends Mapper>) - Constructor for class com.asakusafw.runtime.stage.StageInput
-
Creates a new instance without any attributes.
- StageInput(String, Class<? extends InputFormat>, Class<? extends Mapper>, Map<String, String>) - Constructor for class com.asakusafw.runtime.stage.StageInput
-
Creates a new instance.
- StageInputDriver - Class in com.asakusafw.runtime.stage.input
-
A driver for configuring stage inputs.
- StageInputFormat - Class in com.asakusafw.runtime.stage.input
-
An implementation of Hadoop InputFormat
for handling handling multiple Map operations.
- StageInputFormat() - Constructor for class com.asakusafw.runtime.stage.input.StageInputFormat
-
- StageInputMapper - Class in com.asakusafw.runtime.stage.input
-
An implementation of Hadoop Mapper
for dispatching multiple Map operations.
- StageInputMapper() - Constructor for class com.asakusafw.runtime.stage.input.StageInputMapper
-
- StageInputRecordReader - Class in com.asakusafw.runtime.stage.input
-
An implementation of Hadoop RecordReader
for handling multiple Map operations.
- StageInputRecordReader() - Constructor for class com.asakusafw.runtime.stage.input.StageInputRecordReader
-
- StageInputSplit - Class in com.asakusafw.runtime.stage.input
-
An implementation of Hadoop InputSplit
for handling multiple Map operations.
- StageInputSplit() - Constructor for class com.asakusafw.runtime.stage.input.StageInputSplit
-
Creates a new instance for the serialization framework.
- StageInputSplit(InputSplit, Class<? extends InputFormat<?, ?>>, Class<? extends Mapper<?, ?, ?, ?>>) - Constructor for class com.asakusafw.runtime.stage.input.StageInputSplit
-
- StageInputSplit(Class<? extends Mapper<?, ?, ?, ?>>, List<StageInputSplit.Source>) - Constructor for class com.asakusafw.runtime.stage.input.StageInputSplit
-
Creates a new instance.
- StageInputSplit(Class<? extends Mapper<?, ?, ?, ?>>, List<StageInputSplit.Source>, String[]) - Constructor for class com.asakusafw.runtime.stage.input.StageInputSplit
-
Creates a new instance.
- StageInputSplit.Source - Class in com.asakusafw.runtime.stage.input
-
Represents a pair of InputSplit
and its InputFormat
class.
- StageOutput - Class in com.asakusafw.runtime.stage
-
Represents a stage output.
- StageOutput(String, Class<?>, Class<?>, Class<? extends OutputFormat>) - Constructor for class com.asakusafw.runtime.stage.StageOutput
-
Creates a new instance without any attributes.
- StageOutput(String, Class<?>, Class<?>, Class<? extends OutputFormat>, Map<String, String>) - Constructor for class com.asakusafw.runtime.stage.StageOutput
-
Creates a new instance.
- StageOutputDriver - Class in com.asakusafw.runtime.stage.output
-
A driver for configuring stage outputs.
- StageOutputDriver(TaskInputOutputContext<?, ?, ?, ?>) - Constructor for class com.asakusafw.runtime.stage.output.StageOutputDriver
-
Creates a new instance.
- StageOutputFormat - Class in com.asakusafw.runtime.stage.output
-
A bridge implementation for Hadoop OutputFormat
.
- StageOutputFormat() - Constructor for class com.asakusafw.runtime.stage.output.StageOutputFormat
-
- StageResource - Class in com.asakusafw.runtime.stage
-
Represents a stage resource.
- StageResource(String, String) - Constructor for class com.asakusafw.runtime.stage.StageResource
-
Creates a new instance.
- StageResourceDriver - Class in com.asakusafw.runtime.stage.resource
-
A driver for configuring stage resources.
- StageResourceDriver(JobContext) - Constructor for class com.asakusafw.runtime.stage.resource.StageResourceDriver
-
Creates a new instance.
- StageResourceDriver.AccessMode - Enum in com.asakusafw.runtime.stage.resource
-
- StageUtil - Class in com.asakusafw.runtime.stage
-
Utilities for MapReduce stages.
- StandardFieldOutputOption - Enum in com.asakusafw.runtime.io.text.driver
-
- start() - Method in class com.asakusafw.directio.hive.parquet.v1.DataModelConverter
-
- start() - Method in class com.asakusafw.directio.hive.parquet.v2.DataModelConverter
-
- start() - Method in class com.asakusafw.vocabulary.batch.BatchDescription
-
- start() - Method in class com.asakusafw.vocabulary.flow.FlowDescription
-
- startSummarization(O) - Method in interface com.asakusafw.vocabulary.model.SummarizedModel.Interface
-
Deprecated.
Initializes this object with the target model object as the first one.
- startsWith(String) - Method in class com.asakusafw.runtime.value.StringOption
-
Returns whether or not this text starts with the given prefix.
- startsWith(StringOption) - Method in class com.asakusafw.runtime.value.StringOption
-
Returns whether or not this text starts with the given prefix.
- statement(EmitDirection) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Emits a begin or end of a statement.
- statement(EmitDirection) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- Statement - Interface in com.asakusafw.utils.java.model.syntax
-
An abstract super interface of statement.
- statementBlock(EmitDirection) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Emits a begin or end of a statement block.
- statementBlock(EmitDirection) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- StatementExpressionList - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents expression list (in initializer part) of for
statement.
- StatementExpressionListImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- StatementExpressionListImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.StatementExpressionListImpl
-
- Static() - Method in class com.asakusafw.utils.java.model.util.AttributeBuilder
-
Appends static
modifier to this builder.
- Status(CsvFormatException.Reason, String, long, long, int, String, String) - Constructor for class com.asakusafw.runtime.io.csv.CsvFormatException.Status
-
Creates a new instance.
- StdioHelper - Class in com.asakusafw.windgate.hadoopfs.ssh
-
Provides standard I/Os safely.
- StdoutEscapeMain - Class in com.asakusafw.windgate.hadoopfs.ssh
-
Invokes a main method of the class specified in first program argument by its FQN.
- Sticky - Annotation Type in com.asakusafw.vocabulary.operator
-
省略に関する最適化を抑止すべきメソッドに付与する注釈。
- stop(Source<?>) - Method in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
Terminates the upstream source.
- stop(Source<?>) - Static method in class com.asakusafw.vocabulary.flow.util.CoreOperators
-
Terminates the upstream source.
- Stop - Annotation Type in com.asakusafw.vocabulary.operator
-
Represents stop operator annotation.
- STOP_NAME - Static variable in class com.asakusafw.vocabulary.flow.util.CoreOperatorFactory
-
The common instance name of stop operator.
- StorageFormatInfo - Interface in com.asakusafw.info.hive
-
Represents a storage format (STORED AS ...
) in Hive.
- StorageFormatInfo.Category - Enum in com.asakusafw.info.hive
-
Represents a storage format category.
- StorageFormatInfo.FormatKind - Enum in com.asakusafw.info.hive
-
Represents a storage format kind.
- store(Writable) - Method in class com.asakusafw.runtime.stage.collector.WritableSlot
-
Stores the copy of the target object.
- storeTo(Properties) - Method in class com.asakusafw.windgate.core.CoreProfile
-
Stores this profile into the specified properties.
- storeTo(Properties) - Method in class com.asakusafw.windgate.core.GateScript
-
Stores this script into the specified properties.
- storeTo(Properties) - Method in class com.asakusafw.windgate.core.process.ProcessProfile
-
Stores this profile into the specified properties.
- storeTo(Properties) - Method in class com.asakusafw.windgate.core.resource.ResourceProfile
-
Stores this profile into the specified properties.
- storeTo(Properties) - Method in class com.asakusafw.windgate.core.session.SessionProfile
-
Stores this profile into the specified properties.
- storeTo(Properties) - Method in class com.asakusafw.yaess.core.FlowScript
-
Stores this script into the specified object.
- storeTo(Properties) - Method in class com.asakusafw.yaess.core.ServiceProfile
-
Merges this profile into the specified properties.
- StreamDrainDriver<T> - Class in com.asakusafw.windgate.stream
-
- StreamDrainDriver(String, String, OutputStreamProvider, DataModelStreamSupport<? super T>) - Constructor for class com.asakusafw.windgate.stream.StreamDrainDriver
-
Creates a new instance.
- StreamProcess - Enum in com.asakusafw.windgate.core.vocabulary
-
WindGate stream resource configuration.
- StreamRedirectTask - Class in com.asakusafw.yaess.core.util
-
Redirects an input stream into other output stream.
- StreamRedirectTask(InputStream, OutputStream) - Constructor for class com.asakusafw.yaess.core.util.StreamRedirectTask
-
Creates a new instance.
- StreamRedirectTask(InputStream, OutputStream, boolean, boolean) - Constructor for class com.asakusafw.yaess.core.util.StreamRedirectTask
-
Creates a new instance.
- StreamResourceUtil - Class in com.asakusafw.windgate.stream
-
Common utilities for this package.
- StreamSourceDriver<T> - Class in com.asakusafw.windgate.stream
-
- StreamSourceDriver(String, String, InputStreamProvider, DataModelStreamSupport<? super T>, T) - Constructor for class com.asakusafw.windgate.stream.StreamSourceDriver
-
Creates a new instance.
- StreamSupportDriver - Class in com.asakusafw.dmdl.windgate.stream.driver
-
Processes @windgate.stream_format
attributes.
- StreamSupportDriver() - Constructor for class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportDriver
-
- StreamSupportEmitter - Class in com.asakusafw.dmdl.windgate.stream.driver
-
- StreamSupportEmitter() - Constructor for class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportEmitter
-
- StreamSupportTrait - Class in com.asakusafw.dmdl.windgate.stream.driver
-
Trait for holding format name.
- StreamSupportTrait(AstNode, String) - Constructor for class com.asakusafw.dmdl.windgate.stream.driver.StreamSupportTrait
-
Creates and returns a new instance.
- STRICT - Static variable in class com.asakusafw.yaess.core.JobScheduler
-
Terminate execution on exception occurred.
- Strictfp() - Method in class com.asakusafw.utils.java.model.util.AttributeBuilder
-
Appends strictfp
modifier to this builder.
- StrictVisitor<R,C,E extends Throwable> - Class in com.asakusafw.utils.java.model.syntax
-
- StrictVisitor() - Constructor for class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- StringInfo - Class in com.asakusafw.info.value
-
Represents a String
value.
- stringLiteralOf(String) - Static method in class com.asakusafw.utils.java.internal.model.util.LiteralAnalyzer
-
Returns a literal token for the String
value.
- Stringnizer - Interface in com.asakusafw.directio.hive.tools.cli
-
- StringOption - Class in com.asakusafw.runtime.value
-
Represents a character string value which can be null
.
- StringOption() - Constructor for class com.asakusafw.runtime.value.StringOption
-
Creates a new instance which represents null
value.
- StringOption(String) - Constructor for class com.asakusafw.runtime.value.StringOption
-
Creates a new instance which represents the specified value.
- StringOptionDriver - Class in com.asakusafw.directio.hive.serde
-
- StringOptionDriver(StringObjectInspector) - Constructor for class com.asakusafw.directio.hive.serde.StringOptionDriver
-
Creates a new instance.
- StringOptionFieldAdapter - Class in com.asakusafw.runtime.io.text.value
-
- StringOptionFieldAdapter.Builder - Class in com.asakusafw.runtime.io.text.value
-
- StringOptionInspector - Class in com.asakusafw.directio.hive.serde
-
- StringOptionInspector() - Constructor for class com.asakusafw.directio.hive.serde.StringOptionInspector
-
Creates a new instance.
- StringOptionPropertyAdapter - Class in com.asakusafw.runtime.io.json.value
-
- StringOptionPropertyAdapter(StringOptionPropertyAdapter.Builder) - Constructor for class com.asakusafw.runtime.io.json.value.StringOptionPropertyAdapter
-
Creates a new instance.
- StringOptionPropertyAdapter.Builder - Class in com.asakusafw.runtime.io.json.value
-
- StringOptionUtil - Class in com.asakusafw.runtime.value
-
- stringProperty(PropertyName, C) - Method in class com.asakusafw.testdriver.core.DataModelScanner
-
- stringProperty(PropertyName, JsonObject) - Method in class com.asakusafw.testdriver.json.JsonObjectDriver
-
- StringPropertyDriver - Class in com.asakusafw.dmdl.java.emitter.driver
-
Implements *AsString
methods.
- StringPropertyDriver() - Constructor for class com.asakusafw.dmdl.java.emitter.driver.StringPropertyDriver
-
- StringTemplate - Class in com.asakusafw.runtime.stage.directio
-
Generates a string for the object.
- StringTemplate(StringTemplate.FormatSpec...) - Constructor for class com.asakusafw.runtime.stage.directio.StringTemplate
-
Creates a new instance.
- StringTemplate.Format - Enum in com.asakusafw.runtime.stage.directio
-
Format of each generator element.
- StringTemplate.FormatSpec - Class in com.asakusafw.runtime.stage.directio
-
The format spec.
- StringValueDrivers - Enum in com.asakusafw.directio.hive.parquet.v1
-
- StringValueDrivers - Enum in com.asakusafw.directio.hive.parquet.v2
-
- stringValueOf(String) - Static method in class com.asakusafw.utils.java.internal.model.util.LiteralAnalyzer
-
Analyzes a literal which represents a value of
String
and returns its value.
- StringValueSerdeFactory - Enum in com.asakusafw.directio.hive.serde
-
- StripedDataFormat<T> - Interface in com.asakusafw.runtime.directio.hadoop
-
Data model format which has striping information in the format.
- StripedDataFormat.InputContext - Class in com.asakusafw.runtime.directio.hadoop
-
- StructType - Class in com.asakusafw.info.hive
-
Represents a Hive struct type.
- StructType(List<? extends ColumnInfo>) - Constructor for class com.asakusafw.info.hive.StructType
-
Creates a new instance.
- StructType(ColumnInfo...) - Constructor for class com.asakusafw.info.hive.StructType
-
Creates a new instance.
- stub(PropertyReferenceDeclaration.ReferenceKind) - Static method in class com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration
-
Returns a stub instance.
- subgraph(Graph<? extends V>, Predicate<? super V>) - Static method in class com.asakusafw.utils.graph.Graphs
-
Creates a new subgraph from the target graph.
- submit(Task) - Method in interface com.asakusafw.operation.tools.directio.common.Task.Context
-
Submits the given task.
- submit(ExecutionMonitor, ExecutionContext, Job, BlockingQueue<JobExecutor.Executing>) - Method in interface com.asakusafw.yaess.basic.JobExecutor
-
Submits a job.
- submit(ExecutionMonitor, ExecutionContext, Job, BlockingQueue<JobExecutor.Executing>) - Method in class com.asakusafw.yaess.basic.ThreadedJobExecutor
-
- submit(JobId) - Method in class com.asakusafw.yaess.jobqueue.client.HttpJobClient
-
- submit(JobId) - Method in interface com.asakusafw.yaess.jobqueue.client.JobClient
-
Request to execute the registered job.
- submit(ExecutionMonitor, ExecutionContext, Job, BlockingQueue<JobExecutor.Executing>) - Method in class com.asakusafw.yaess.paralleljob.ParallelJobExecutor
-
- Summarize - Annotation Type in com.asakusafw.vocabulary.operator
-
単純集計演算子を表すメソッドに付与する注釈。
- Summarized - Annotation Type in com.asakusafw.vocabulary.model
-
Annotation for summarized models.
- Summarized.Aggregator - Enum in com.asakusafw.vocabulary.model
-
Aggregator functions.
- Summarized.Folding - Annotation Type in com.asakusafw.vocabulary.model
-
Property folding.
- Summarized.Term - Annotation Type in com.asakusafw.vocabulary.model
-
Source term.
- SummarizedModel - Annotation Type in com.asakusafw.vocabulary.model
-
- SummarizedModel.Interface<T,O> - Interface in com.asakusafw.vocabulary.model
-
Deprecated.
An interface that provides skeletal information of summarized models.
- SummarizeDriver - Class in com.asakusafw.dmdl.java.emitter.driver
-
Implements summarized-model feature.
- SummarizeDriver() - Constructor for class com.asakusafw.dmdl.java.emitter.driver.SummarizeDriver
-
- SummarizeOperatorDriver - Class in com.asakusafw.operator.builtin
-
- SummarizeOperatorDriver() - Constructor for class com.asakusafw.operator.builtin.SummarizeOperatorDriver
-
- SummarizeTrait - Class in com.asakusafw.dmdl.semantics.trait
-
Summarize trait for summarized models.
- SummarizeTrait(AstExpression<AstSummarize>, List<ReduceTerm<AstSummarize>>) - Constructor for class com.asakusafw.dmdl.semantics.trait.SummarizeTrait
-
Creates and returns a new instance.
- Super - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents super
qualifier (pseudo-expression).
- SuperConstructorInvocation - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents super constructor statement.
- SuperConstructorInvocationImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SuperConstructorInvocationImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SuperConstructorInvocationImpl
-
- SuperImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
An implementation of
Super
.
- SuperImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SuperImpl
-
- support(String, Class<?>...) - Static method in class com.asakusafw.vocabulary.flow.builder.Attributes
-
- SUPPORTED_FORMATS - Static variable in class com.asakusafw.testdriver.excel.DefaultExcelRuleExtractor
-
Format IDs which this extractor supports.
- supports(Sheet) - Method in class com.asakusafw.testdriver.excel.DefaultExcelRuleExtractor
-
- supports(Sheet) - Method in interface com.asakusafw.testdriver.excel.ExcelRuleExtractor
-
Returns true
iff this extractor supports the sheet.
- supports(Sheet) - Method in class com.asakusafw.testdriver.excel.legacy.LegacyExcelRuleExtractor
-
- SwitchCaseLabel - Interface in com.asakusafw.utils.java.model.syntax
-
* An interface which represents case
labels in switch statements.
- SwitchCaseLabelImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SwitchCaseLabelImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SwitchCaseLabelImpl
-
- switchContextClassLoader(ClassLoader) - Static method in class com.asakusafw.runtime.stage.launcher.ApplicationLauncher
-
Sets the context class loader and returns the current one.
- SwitchDefaultLabel - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents default
labels in switch statements.
- SwitchDefaultLabelImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SwitchDefaultLabelImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SwitchDefaultLabelImpl
-
- switchLabel(EmitDirection) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Emits a begin or end of a switch
label block.
- switchLabel(EmitDirection) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- SwitchLabel - Interface in com.asakusafw.utils.java.model.syntax
-
An abstract super interface of labels in switch statement.
- switchObject(int) - Method in interface com.asakusafw.runtime.io.util.Union
-
Switches position and get its object.
- switchObject(int) - Method in class com.asakusafw.runtime.io.util.WritableRawComparableUnion
-
- switchObject(int) - Method in class com.asakusafw.runtime.io.util.WritableUnion
-
- SwitchStatement - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents switch statement.
- SwitchStatementImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SwitchStatementImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SwitchStatementImpl
-
- Symbol<D extends Declaration> - Interface in com.asakusafw.dmdl.semantics
-
Super interface of the all reference symbols.
- symbol(String) - Method in interface com.asakusafw.utils.java.internal.model.util.EmitContext
-
Emits a symbol.
- symbol(String) - Method in class com.asakusafw.utils.java.internal.model.util.PrintEmitContext
-
- symbol - Variable in enum com.asakusafw.windgate.cli.ExecutionKind
-
The symbol of this kind.
- Symbolic - Interface in com.asakusafw.yaess.core
-
An abstract super interface of symbolic elements.
- sync() - Method in class com.asakusafw.runtime.io.util.BufferedFileInput
-
Resets internal buffer.
- sync() - Method in class com.asakusafw.runtime.io.util.BufferedFileOutput
-
Resets internal buffer.
- Synchronized() - Method in class com.asakusafw.utils.java.model.util.AttributeBuilder
-
Appends synchronized
modifier to this builder.
- SynchronizedStatement - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents synchronized statement.
- SynchronizedStatementImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- SynchronizedStatementImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.SynchronizedStatementImpl
-
- system() - Static method in class com.asakusafw.operation.tools.directio.bootstrap.Environment
-
Returns a new system environment variables.
- system() - Static method in class com.asakusafw.utils.gradle.CommandPath
-
Creates a new instance from environment variables.
- system() - Static method in class com.asakusafw.utils.gradle.EnvironmentConfigurator
-
- system() - Static method in class com.asakusafw.utils.gradle.PropertyConfigurator
-
- system() - Static method in class com.asakusafw.windgate.bootstrap.Environment
-
Returns a new system environment variables.
- system(ClassLoader) - Static method in class com.asakusafw.windgate.core.ProfileContext
-
Creates a new context with system variables as context parameters.
- system() - Static method in class com.asakusafw.workflow.hadoop.bootstrap.Environment
-
Returns a new system environment variables.
- system(ClassLoader) - Static method in class com.asakusafw.yaess.core.ProfileContext
-
Creates a new context with system variables as context parameters.
- system() - Static method in class com.asakusafw.yaess.core.VariableResolver
-
Creates a new instance from environment variables and system properties.
- validate(CompileEnvironment, ExecutableElement, OperatorDescription) - Static method in class com.asakusafw.operator.util.ElementHelper
-
- validate(Class<?>, String, DataModelSourceFactory) - Method in class com.asakusafw.testdriver.core.TestModerator
-
- validate(Class<?>, String, VerifierFactory) - Method in class com.asakusafw.testdriver.core.TestModerator
-
- validate() - Method in interface com.asakusafw.testdriver.core.Verifier.Validatable
-
Validates this object.
- validate() - Method in class com.asakusafw.testdriver.core.VerifyRuleVerifier
-
- validateCompileEnvironment() - Method in class com.asakusafw.testdriver.TestDriverContext
-
- validateEnvironment() - Method in class com.asakusafw.testdriver.JobExecutor
-
Deprecated.
Validates the target job execution environment.
- validateExecutionEnvironment() - Method in class com.asakusafw.testdriver.TestDriverContext
-
Validates current test execution environment.
- validatePlan(TestExecutionPlan) - Method in class com.asakusafw.testdriver.JobExecutor
-
Deprecated.
Validates the target test execution plan for this executor.
- validateSyntax(DmdlSemantics, AstModelDefinition<?>) - Method in interface com.asakusafw.dmdl.analyzer.DmdlAnalyzerEnhancer
-
Validates the syntax of definitions.
- validateSyntax(DmdlSemantics, AstModelDefinition<?>) - Method in class com.asakusafw.dmdl.java.analyzer.JavaDataModelAnalyzerEnhancer
-
- Value<T> - Class in com.asakusafw.dmdl.directio.util
-
Represents a value.
- value - Variable in class com.asakusafw.dmdl.model.AstAttributeElement
-
The holding value of this element.
- value - Variable in class com.asakusafw.dmdl.model.AstAttributeValueMap.Entry
-
The entry value.
- value() - Method in enum com.asakusafw.windgate.core.vocabulary.JdbcProcess.OperationKind
-
Returns the value representation of this kind.
- VALUE_FALSE - Static variable in class com.asakusafw.dmdl.directio.util.AttributeAnalyzer
-
The value name of false
.
- VALUE_NULL - Static variable in class com.asakusafw.dmdl.directio.util.AttributeAnalyzer
-
The value name of null
.
- VALUE_TRUE - Static variable in class com.asakusafw.dmdl.directio.util.AttributeAnalyzer
-
The value name of true
.
- ValueConditionKind - Enum in com.asakusafw.testdriver.excel
-
Kind of value predicate represented in each cell.
- ValueConverter - Class in com.asakusafw.directio.hive.parquet.v1
-
- ValueConverter() - Constructor for class com.asakusafw.directio.hive.parquet.v1.ValueConverter
-
- ValueConverter - Class in com.asakusafw.directio.hive.parquet.v2
-
- ValueConverter() - Constructor for class com.asakusafw.directio.hive.parquet.v2.ValueConverter
-
- ValueDescription - Interface in com.asakusafw.operator.description
-
Represents a value.
- ValueDescription.ValueKind - Enum in com.asakusafw.operator.description
-
- ValueDriver - Interface in com.asakusafw.directio.hive.serde
-
- ValueInfo - Interface in com.asakusafw.info.value
-
Represents a value.
- ValueInfo.Kind - Enum in com.asakusafw.info.value
-
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v1.BasicValueWriter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v1.ParquetValueDrivers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v1.StringValueDrivers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v1.TimestampValueDrivers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v2.BasicValueWriter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v2.ParquetValueDrivers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v2.StringValueDrivers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.parquet.v2.TimestampValueDrivers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.serde.DataModelMapping.ExceptionHandlingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.serde.DataModelMapping.FieldMappingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.serde.StringValueSerdeFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.serde.TimestampValueSerdeFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.Diagnostic.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait.QuoteStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait.TypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.json.driver.JsonFormatConstants.DecimalStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.json.driver.JsonFormatConstants.JsonFormatKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.line.driver.LineFieldTrait.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.text.TextFieldTrait.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.directio.tsv.driver.TsvFieldTrait.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.model.AstCollectionType.CollectionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.model.AstPropertyDefinition.PropertyKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.model.BasicTypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.model.LiteralKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.model.ModelDefinitionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.semantics.PropertyMappingKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.semantics.type.CollectionType.CollectionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait.QuoteStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.cli.generate.ddl.HiveTableParameter.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.hive.FieldType.Category
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.hive.FieldType.TypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.hive.RowFormatInfo.FormatKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.hive.StorageFormatInfo.Category
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.hive.StorageFormatInfo.FormatKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.operator.CoreOperatorSpec.CoreOperatorKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.operator.InputGranularity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.operator.InputGroup.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.operator.OperatorSpec.OperatorKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.plan.DataExchange
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.task.TaskInfo.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.info.value.ValueInfo.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operation.tools.directio.common.TaskExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.CompileEnvironment.Support
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.description.BasicTypeDescription.BasicTypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(Object) - Static method in class com.asakusafw.operator.description.Descriptions
-
- valueOf(String) - Static method in enum com.asakusafw.operator.description.TypeDescription.TypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.description.ValueDescription.ValueKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.model.DataModelMirror.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.model.KeyMirror.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.model.OperatorDescription.Document.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.model.OperatorDescription.Node.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.model.OperatorDescription.Reference.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.operator.WarningAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.core.context.RuntimeContext.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.core.Report.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.directio.FilePattern.PatternElementKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.csv.CsvFormatException.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.json.ErrorAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.json.JsonFormat.InputOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.json.JsonFormat.OutputOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.json.LineSeparator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.json.value.ValueOptionPropertyAdapter.NullStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.csv.QuoteStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.ErrorAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.HeaderType.Input
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.HeaderType.Output
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.HeaderType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.InputOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.OutputOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.driver.StandardFieldOutputOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.LineSeparator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.UnmappableOutput.ErrorCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.io.text.value.DecimalOptionFieldAdapter.OutputStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.stage.directio.StringTemplate.Format
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.stage.resource.StageResourceDriver.AccessMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.util.hadoop.InstallationUtil.FrameworkVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.util.VariableTable.RedefineStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.runtime.value.Date.Format
-
Returns the enum constant of this type with the specified name.
- valueOf(StringOption, Date.Format) - Static method in class com.asakusafw.runtime.value.Date
-
Parses the target string and returns the corresponding date as the elapsed days from
0001/01/01 (YYYY/MM/DD)
.
- valueOf(String, Date.Format) - Static method in class com.asakusafw.runtime.value.Date
-
Parses the target string and returns the corresponding date object.
- valueOf(String) - Static method in enum com.asakusafw.runtime.value.DateTime.Format
-
Returns the enum constant of this type with the specified name.
- valueOf(StringOption, DateTime.Format) - Static method in class com.asakusafw.runtime.value.DateTime
-
Parses the target string using the specified format, and returns the corresponding date and time as the elapsed
seconds from 0001/01/01 (YYYY/MM/DD) 00:00:00
.
- valueOf(String, DateTime.Format) - Static method in class com.asakusafw.runtime.value.DateTime
-
Parses the target string using the specified format, and returns the corresponding date and time object.
- valueOf(String) - Static method in enum com.asakusafw.testdata.generator.excel.SheetFormat.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdata.generator.excel.WorkbookFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.compiler.CompilerConfiguration.DebugLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.compiler.CompilerConfiguration.OptimizeLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.compiler.util.DeploymentUtil.DeleteOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.compiler.util.DeploymentUtil.DeployOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.core.PropertyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.ColumnMatchingCondition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem.ItemType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.NullValueCondition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.legacy.RowMatchingCondition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.NullityConditionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.RuleSheetFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.TotalConditionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.excel.ValueConditionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.rule.CompareOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.rule.DataModelCondition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.TestDriverContext.TestExecutionPhase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.testdriver.TestExecutionPlan.TaskKind
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.trace.model.Tracepoint.PortKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.trace.model.TraceSetting.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.internal.model.util.EmitDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.internal.model.util.ExpressionPriority
-
Returns the enum constant of this type with the specified name.
- valueOf(InfixOperator) - Static method in enum com.asakusafw.utils.java.internal.model.util.ExpressionPriority
-
Returns the priority about the target infix operator.
- valueOf(Expression) - Static method in enum com.asakusafw.utils.java.internal.model.util.ExpressionPriority
-
Returns the priority about the target expression.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.internal.model.util.LiteralTokenKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.IrBasicTypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.JavadocTokenKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.BasicTypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(Class<?>) - Static method in enum com.asakusafw.utils.java.model.syntax.BasicTypeKind
-
Returns the type kind about the target Java type.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ExecutableKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.FieldKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind.Range
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind.Target
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind
-
Returns the enum constant of this type with the specified name.
- valueOf(ImportKind.Target, ImportKind.Range) - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind
-
Returns the import kind from its target and scope kinds.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.InfixOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.LiteralKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ModelKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ModifierKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.ObjectTypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.PostfixOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.PropertyKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.UnaryOperator.Category
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.UnaryOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.syntax.WildcardBoundKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.utils.java.model.util.ImportBuilder.Strategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.attribute.BufferType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.attribute.ViewInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.attribute.ViewInfo.ViewKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.external.ImporterDescription.DataSize
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.builder.Data.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.builder.PortInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.Connectivity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.FlowBoundary
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.FlowElementKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.Inline
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.ObservationCount
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.PortDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.graph.ShuffleKey.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.processor.InputBuffer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.flow.processor.PartialAggregation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.model.Property.Aggregator
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.model.Summarized.Aggregator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.operator.KeyInfo.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.operator.Logging.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.windgate.JdbcExporterDescription.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.vocabulary.windgate.JdbcImporterDescription.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.cli.ExecutionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.core.DriverScript.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.core.session.SessionException.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.core.vocabulary.FileProcess
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.core.vocabulary.JdbcProcess.OperationKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.core.vocabulary.JdbcProcess
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.windgate.core.vocabulary.StreamProcess
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.workflow.executor.basic.BasicCommandLauncher.Output
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.workflow.executor.basic.BasicCommandLauncher.OutputChannel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.workflow.model.CommandToken.TokenKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.workflow.model.DeleteTaskInfo.PathKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.workflow.model.TaskInfo.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.yaess.core.ExecutionLock.Scope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.yaess.core.ExecutionPhase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.yaess.core.ExecutionScript.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.yaess.core.PhaseMonitor.JobStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.asakusafw.yaess.jobqueue.client.JobStatus.Kind
-
Returns the enum constant of this type with the specified name.
- ValueOption<V extends ValueOption<V>> - Class in com.asakusafw.runtime.value
-
Represents nullable and modifiable value.
- ValueOption() - Constructor for class com.asakusafw.runtime.value.ValueOption
-
- ValueOptionFieldAdapter<T extends ValueOption<T>> - Class in com.asakusafw.runtime.io.text.value
-
- ValueOptionFieldAdapter() - Constructor for class com.asakusafw.runtime.io.text.value.ValueOptionFieldAdapter
-
Creates a new instance.
- ValueOptionFieldAdapter(String) - Constructor for class com.asakusafw.runtime.io.text.value.ValueOptionFieldAdapter
-
Creates a new instance.
- ValueOptionFieldAdapter.BuilderBase<S extends ValueOptionFieldAdapter.BuilderBase<S,T>,T extends FieldAdapter<?>> - Class in com.asakusafw.runtime.io.text.value
-
- ValueOptionList<E extends ValueOption<E>> - Class in com.asakusafw.runtime.value
-
An abstract implementation of list of references to other properties.
- ValueOptionList() - Constructor for class com.asakusafw.runtime.value.ValueOptionList
-
- ValueOptionMap<K,V extends ValueOption<V>> - Class in com.asakusafw.runtime.value
-
An abstract implementation of map of references to other properties.
- ValueOptionMap() - Constructor for class com.asakusafw.runtime.value.ValueOptionMap
-
- ValueOptionPropertyAdapter<T extends ValueOption<T>> - Class in com.asakusafw.runtime.io.json.value
-
- ValueOptionPropertyAdapter(ValueOptionPropertyAdapter.BuilderBase<?, ?>) - Constructor for class com.asakusafw.runtime.io.json.value.ValueOptionPropertyAdapter
-
Creates a new instance.
- ValueOptionPropertyAdapter.BuilderBase<S extends ValueOptionPropertyAdapter.BuilderBase<S,T>,T extends PropertyAdapter<?>> - Class in com.asakusafw.runtime.io.json.value
-
- ValueOptionPropertyAdapter.NullStyle - Enum in com.asakusafw.runtime.io.json.value
-
A kind of output style of null
properties.
- ValuePredicate<T> - Interface in com.asakusafw.testdriver.rule
-
2-arity predicate object.
- ValueReader - Interface in com.asakusafw.runtime.io.json
-
Provides values from data sources.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v1.BasicValueWriter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v1.ParquetValueDrivers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v1.StringValueDrivers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v1.TimestampValueDrivers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v2.BasicValueWriter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v2.ParquetValueDrivers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v2.StringValueDrivers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.parquet.v2.TimestampValueDrivers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.serde.DataModelMapping.ExceptionHandlingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.serde.DataModelMapping.FieldMappingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.serde.StringValueSerdeFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.serde.TimestampValueSerdeFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.directio.hive.serde.ValueSerdeFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.Diagnostic.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.csv.driver.CsvFieldTrait.QuoteStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.hive.common.HiveFieldTrait.TypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.json.driver.JsonFormatConstants.DecimalStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.json.driver.JsonFormatConstants.JsonFormatKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.json.driver.JsonPropertyTrait.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.line.driver.LineFieldTrait.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.text.TextFieldTrait.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.directio.tsv.driver.TsvFieldTrait.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.model.AstCollectionType.CollectionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.model.AstPropertyDefinition.PropertyKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.model.BasicTypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.model.LiteralKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.model.ModelDefinitionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.semantics.PropertyMappingKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.semantics.PropertyReferenceDeclaration.ReferenceKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.semantics.type.CollectionType.CollectionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.dmdl.windgate.csv.driver.CsvFieldTrait.QuoteStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.cli.generate.ddl.HiveTableParameter.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.hive.FieldType.Category
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.hive.FieldType.TypeName
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.hive.RowFormatInfo.FormatKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.hive.StorageFormatInfo.Category
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.hive.StorageFormatInfo.FormatKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.operator.CoreOperatorSpec.CoreOperatorKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.operator.InputGranularity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.operator.InputGroup.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.operator.OperatorSpec.OperatorKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.plan.DataExchange
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.task.TaskInfo.Phase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.info.value.ValueInfo.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operation.tools.directio.common.TaskExecutor
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.CompileEnvironment.Support
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.description.BasicTypeDescription.BasicTypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.description.TypeDescription.TypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.description.ValueDescription.ValueKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.model.DataModelMirror.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.model.KeyMirror.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.model.OperatorDescription.Document.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.model.OperatorDescription.Node.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.model.OperatorDescription.Reference.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.operator.WarningAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.core.context.RuntimeContext.ExecutionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.core.Report.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.directio.FilePattern.PatternElementKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.csv.CsvFormatException.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.json.ErrorAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.json.JsonFormat.InputOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.json.JsonFormat.OutputOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.json.LineSeparator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.json.value.ValueOptionPropertyAdapter.NullStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.csv.QuoteStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.ErrorAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.HeaderType.Input
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.HeaderType.Output
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.HeaderType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.InputOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.OutputOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.driver.StandardFieldOutputOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.LineSeparator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.UnmappableOutput.ErrorCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.io.text.value.DecimalOptionFieldAdapter.OutputStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.stage.directio.StringTemplate.Format
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.stage.resource.StageResourceDriver.AccessMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.util.hadoop.InstallationUtil.FrameworkVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.util.VariableTable.RedefineStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.value.Date.Format
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.runtime.value.DateTime.Format
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdata.generator.excel.SheetFormat.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdata.generator.excel.WorkbookFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.compiler.CompilerConfiguration.DebugLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.compiler.CompilerConfiguration.OptimizeLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.compiler.util.DeploymentUtil.DeleteOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.compiler.util.DeploymentUtil.DeployOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.core.PropertyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.legacy.ColumnMatchingCondition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem.ItemType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.legacy.ConditionSheetItem
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.legacy.NullValueCondition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.legacy.RowMatchingCondition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.NullityConditionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.RuleSheetFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.TotalConditionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.excel.ValueConditionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.rule.CompareOperator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.rule.DataModelCondition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.TestDriverContext.TestExecutionPhase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.testdriver.TestExecutionPlan.TaskKind
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.trace.model.Tracepoint.PortKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.trace.model.TraceSetting.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.internal.model.util.EmitDirection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.internal.model.util.ExpressionPriority
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.internal.model.util.LiteralTokenKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.IrBasicTypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.internal.parser.javadoc.ir.JavadocTokenKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.BasicTypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ExecutableKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.FieldKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind.Range
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind.Target
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ImportKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.InfixOperator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.LiteralKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ModelKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ModifierKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.ObjectTypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.PostfixOperator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.PropertyKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.UnaryOperator.Category
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.UnaryOperator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.syntax.WildcardBoundKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.utils.java.model.util.ImportBuilder.Strategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.attribute.BufferType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.attribute.ViewInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.attribute.ViewInfo.ViewKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.external.ImporterDescription.DataSize
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.builder.Data.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.builder.PortInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.Connectivity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.FlowBoundary
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.FlowElementKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.Inline
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.ObservationCount
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.PortDirection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.graph.ShuffleKey.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.processor.InputBuffer
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.flow.processor.PartialAggregation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.model.Property.Aggregator
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.model.Summarized.Aggregator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.operator.KeyInfo.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.operator.Logging.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.windgate.JdbcExporterDescription.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.vocabulary.windgate.JdbcImporterDescription.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.cli.ExecutionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.core.DriverScript.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.core.session.SessionException.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.core.vocabulary.FileProcess
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.core.vocabulary.JdbcProcess.OperationKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.core.vocabulary.JdbcProcess
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.windgate.core.vocabulary.StreamProcess
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.workflow.executor.basic.BasicCommandLauncher.Output
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.workflow.executor.basic.BasicCommandLauncher.OutputChannel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.workflow.model.CommandToken.TokenKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.workflow.model.DeleteTaskInfo.PathKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.workflow.model.TaskInfo.Phase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.yaess.core.ExecutionLock.Scope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.yaess.core.ExecutionPhase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.yaess.core.ExecutionScript.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.yaess.core.PhaseMonitor.JobStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.asakusafw.yaess.jobqueue.client.JobStatus.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueSerde - Interface in com.asakusafw.directio.hive.serde
-
- ValueSerdeFactory - Enum in com.asakusafw.directio.hive.serde
-
- ValueWriter - Interface in com.asakusafw.directio.hive.parquet.v1
-
Write values into RecordConsumer
.
- ValueWriter - Interface in com.asakusafw.directio.hive.parquet.v2
-
Write values into RecordConsumer
.
- ValueWriter - Interface in com.asakusafw.runtime.io.json
-
Writes values into data sources.
- VAR_BATCH_ID - Static variable in class com.asakusafw.runtime.stage.StageConstants
-
The variable name of the batch ID.
- VAR_BATCH_ID - Static variable in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
Variable name of batch ID.
- VAR_DEFINITION_ID - Static variable in class com.asakusafw.runtime.stage.StageConstants
-
The variable name of the definition ID.
- VAR_EXECUTION_ID - Static variable in class com.asakusafw.runtime.stage.StageConstants
-
The variable name of the execution ID.
- VAR_EXECUTION_ID - Static variable in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
Variable name of execution ID.
- VAR_FLOW_ID - Static variable in class com.asakusafw.runtime.stage.StageConstants
-
The variable name of the flow ID.
- VAR_FLOW_ID - Static variable in class com.asakusafw.yaess.basic.ProcessHadoopScriptHandler
-
Variable name of flow ID.
- VAR_STAGE_ID - Static variable in class com.asakusafw.runtime.stage.StageConstants
-
The variable name of the stage ID.
- VAR_USER - Static variable in class com.asakusafw.runtime.stage.StageConstants
-
The variable name of the user name.
- VarcharStringOptionDriver - Class in com.asakusafw.directio.hive.serde
-
- VarcharStringOptionDriver(HiveVarcharObjectInspector) - Constructor for class com.asakusafw.directio.hive.serde.VarcharStringOptionDriver
-
Creates a new instance.
- VarcharStringOptionInspector - Class in com.asakusafw.directio.hive.serde
-
- VarcharStringOptionInspector() - Constructor for class com.asakusafw.directio.hive.serde.VarcharStringOptionInspector
-
Creates a new instance.
- VarcharStringOptionInspector(int) - Constructor for class com.asakusafw.directio.hive.serde.VarcharStringOptionInspector
-
Creates a new instance.
- VariableDeclarator - Interface in com.asakusafw.utils.java.model.syntax
-
An interface which represents variable declarators.
- VariableDeclaratorImpl - Class in com.asakusafw.utils.java.internal.model.syntax
-
- VariableDeclaratorImpl() - Constructor for class com.asakusafw.utils.java.internal.model.syntax.VariableDeclaratorImpl
-
- VariableResolver - Class in com.asakusafw.yaess.core
-
Resolves variables in form of ${variable_name}
.
- VariableResolver(Map<String, String>) - Constructor for class com.asakusafw.yaess.core.VariableResolver
-
Creates a new instance.
- VariableTable - Class in com.asakusafw.runtime.util
-
Parses strings which may contain variables.
- VariableTable() - Constructor for class com.asakusafw.runtime.util.VariableTable
-
Creates a new empty instance.
- VariableTable(VariableTable.RedefineStrategy) - Constructor for class com.asakusafw.runtime.util.VariableTable
-
Creates a new empty instance.
- VariableTable.RedefineStrategy - Enum in com.asakusafw.runtime.util
-
Represents strategies for redefining variables.
- VerboseParameter - Class in com.asakusafw.utils.jcommander.common
-
Provides verbose flag.
- VerboseParameter() - Constructor for class com.asakusafw.utils.jcommander.common.VerboseParameter
-
- Verifier - Interface in com.asakusafw.testdriver.core
-
Result verifier.
- Verifier.Validatable - Interface in com.asakusafw.testdriver.core
-
- VerifierFactory - Class in com.asakusafw.testdriver.core
-
- VerifierFactory() - Constructor for class com.asakusafw.testdriver.core.VerifierFactory
-
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.hive.orc.OrcFileDriver
-
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.hive.parquet.ParquetFileDriver
-
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFileNameDriver
-
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatDriver
-
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonFormatSettings
-
Verifies this settings.
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonLineNumberDriver
-
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertyDriver
-
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonPropertySettings
-
Verifies this settings.
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonRecordNumberDriver
-
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.json.driver.JsonStreamSettings
-
Verifies this settings.
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.line.driver.LineFormatDriver
-
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.csv.CsvTextDriver
-
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.EscapeSettings
-
Verifies this settings.
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.QuoteSettings
-
Verifies this settings.
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.tabular.TabularTextDriver
-
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.TextFieldDriver
-
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.TextFieldSettings
-
Verifies this settings.
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.TextFileNameDriver
-
- verify(DmdlSemantics, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.TextFormatSettings
-
Verifies this settings.
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.TextLineNumberDriver
-
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.directio.text.TextRecordNumberDriver
-
- verify(AttributeDriver.Context, Declaration, AstAttribute) - Method in interface com.asakusafw.dmdl.spi.AttributeDriver
-
Verifies the attributed declaration.
- verify(AttributeDriver.Context, Declaration, AstAttribute) - Method in class com.asakusafw.dmdl.spi.ModelAttributeDriver
-
- verify(DmdlSemantics, ModelDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.spi.ModelAttributeDriver
-
Verifies the attributed declaration.
- verify(AttributeDriver.Context, Declaration, AstAttribute) - Method in class com.asakusafw.dmdl.spi.PropertyAttributeDriver
-
- verify(DmdlSemantics, PropertyDeclaration, AstAttribute) - Method in class com.asakusafw.dmdl.spi.PropertyAttributeDriver
-
Verifies the attributed declaration.
- verify(DataModelReflection, DataModelReflection) - Method in class com.asakusafw.testdriver.core.CompositeVerifyRule
-
- verify(T, T) - Method in interface com.asakusafw.testdriver.core.ModelTester
-
Tests each model object and returns error report.
- verify(T, T) - Method in interface com.asakusafw.testdriver.core.ModelVerifier
-
Verifies each model object and returns error report.
- verify(DataModelReflection, DataModelReflection) - Method in class com.asakusafw.testdriver.core.ModelVerifierDriver
-
- verify(DataModelReflection, DataModelReflection) - Method in class com.asakusafw.testdriver.core.TesterDriver
-
- verify(DataModelReflection, DataModelReflection) - Method in interface com.asakusafw.testdriver.core.TestRule
-
Verifies each model object.
- verify(DataModelSource) - Method in interface com.asakusafw.testdriver.core.Verifier
-
Verifies the result data.
- verify(DataModelSource) - Method in class com.asakusafw.testdriver.core.VerifyRuleVerifier
-
- verify(VerifierFactory) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Sets how verify the execution results for this output.
- verify(DataModelSourceFactory, String) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(String, String) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Iterable<? extends T>, String) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Provider<? extends Source<? extends T>>, String) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Class<? extends DataFormat<? super T>>, String, String) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Class<? extends DataFormat<? super T>>, File, String) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(DataModelSourceFactory, String, ModelTester<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(String, String, ModelTester<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Iterable<? extends T>, String, ModelTester<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Provider<? extends Source<? extends T>>, String, ModelTester<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Class<? extends DataFormat<? super T>>, String, String, ModelTester<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Class<? extends DataFormat<? super T>>, File, String, ModelTester<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(DataModelSourceFactory, ModelVerifier<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(String, ModelVerifier<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Iterable<? extends T>, ModelVerifier<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Provider<? extends Source<? extends T>>, ModelVerifier<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Class<? extends DataFormat<? super T>>, String, ModelVerifier<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(Class<? extends DataFormat<? super T>>, File, ModelVerifier<? super T>) - Method in class com.asakusafw.testdriver.FlowDriverOutput
-
Enables to verify the results of this output.
- verify(DataModelReflection, DataModelReflection) - Method in class com.asakusafw.testdriver.rule.VerifyRuleInterpretor
-
- verify(ExporterDescription, String, String, ModelTester<?>...) - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
Verifies jobflow output.
- verify(ExporterDescription, String, String, ModelTransformer<?>, ModelTester<?>...) - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
Verifies jobflow output.
- verify(ExporterDescription, VerifierFactory) - Method in class com.asakusafw.testdriver.tools.runner.BatchTestTool
-
Verifies jobflow output.
- verifyApplication(ClassLoader) - Method in class com.asakusafw.runtime.core.context.RuntimeContext
-
Verifies application by using current context.
- VerifyContext - Class in com.asakusafw.testdriver.core
-
Verification context.
- VerifyContext(TestContext) - Constructor for class com.asakusafw.testdriver.core.VerifyContext
-
Creates a new instance.
- VerifyContext(TestContext, Date) - Constructor for class com.asakusafw.testdriver.core.VerifyContext
-
Creates a new instance.
- VerifyEngine - Class in com.asakusafw.testdriver.core
-
Verifies model objects using
VerifyRule
and expected data set.
- VerifyEngine(VerifyRule) - Constructor for class com.asakusafw.testdriver.core.VerifyEngine
-
Creates a new instance.
- verifyFrameworkVersion() - Static method in class com.asakusafw.runtime.util.hadoop.InstallationUtil
-
Verifies the running core framework version.
- VerifyRule - Interface in com.asakusafw.testdriver.core
-
Strategy of test result verification.
- VerifyRuleBuilder - Class in com.asakusafw.testdriver.rule
-
- VerifyRuleBuilder(DataModelDefinition<?>) - Constructor for class com.asakusafw.testdriver.rule.VerifyRuleBuilder
-
Creates a new instance.
- VerifyRuleBuilder.Property - Class in com.asakusafw.testdriver.rule
-
Builds verify conditions for individual properties.
- VerifyRuleFactory - Class in com.asakusafw.testdriver.core
-
- VerifyRuleFactory() - Constructor for class com.asakusafw.testdriver.core.VerifyRuleFactory
-
- VerifyRuleInterpretor - Class in com.asakusafw.testdriver.rule
-
- VerifyRuleInterpretor(List<PropertyName>, Set<DataModelCondition>, List<? extends PropertyCondition<?>>) - Constructor for class com.asakusafw.testdriver.rule.VerifyRuleInterpretor
-
Creates a new instance.
- VerifyRuleProvider - Interface in com.asakusafw.testdriver.core
-
- VerifyRuleVerifier - Class in com.asakusafw.testdriver.core
-
- VerifyRuleVerifier(DataModelSource, VerifyRule) - Constructor for class com.asakusafw.testdriver.core.VerifyRuleVerifier
-
Creates a new instance.
- VERSION - Static variable in class com.asakusafw.info.BatchInfo
-
The schema version.
- VERSION - Static variable in class com.asakusafw.yaess.core.BatchScript
-
Current version.
- VERSION_MAJOR - Static variable in class com.asakusafw.runtime.core.BatchRuntime
-
Major version.
- VERSION_MINOR - Static variable in class com.asakusafw.runtime.core.BatchRuntime
-
Minor version.
- VersionCommand - Class in com.asakusafw.operation.tools.portal
-
A command for printing list of batch.
- VersionCommand() - Constructor for class com.asakusafw.operation.tools.portal.VersionCommand
-
- VertexSelectorParameter - Class in com.asakusafw.info.cli.common
-
Selects vertex.
- VertexSelectorParameter() - Constructor for class com.asakusafw.info.cli.common.VertexSelectorParameter
-
- View<T> - Interface in com.asakusafw.runtime.core
-
Represents a data-flow view.
- ViewInfo - Class in com.asakusafw.vocabulary.attribute
-
Represents information of data-flow views.
- ViewInfo.Direction - Enum in com.asakusafw.vocabulary.attribute
-
Represents a kind of ordering direction.
- ViewInfo.Ordering - Class in com.asakusafw.vocabulary.attribute
-
Represents an ordering atom.
- ViewInfo.ViewKind - Enum in com.asakusafw.vocabulary.attribute
-
Represents a kind of view.
- visitAlternateConstructorInvocation(AlternateConstructorInvocation, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitAlternateConstructorInvocation(AlternateConstructorInvocation, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitAlternateConstructorInvocation(AlternateConstructorInvocation, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitAlternateConstructorInvocation(AlternateConstructorInvocation, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitAnnotationDeclaration(AnnotationDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitAnnotationDeclaration(AnnotationDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitAnnotationDeclaration(AnnotationDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitAnnotationDeclaration(AnnotationDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitAnnotationElement(AnnotationElement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitAnnotationElement(AnnotationElement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitAnnotationElement(AnnotationElement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitAnnotationElement(AnnotationElement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitAnnotationElementDeclaration(AnnotationElementDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitAnnotationElementDeclaration(AnnotationElementDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitAnnotationElementDeclaration(AnnotationElementDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitAnnotationElementDeclaration(AnnotationElementDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitArrayAccessExpression(ArrayAccessExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitArrayAccessExpression(ArrayAccessExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitArrayAccessExpression(ArrayAccessExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitArrayAccessExpression(ArrayAccessExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitArrayCreationExpression(ArrayCreationExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitArrayCreationExpression(ArrayCreationExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitArrayCreationExpression(ArrayCreationExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitArrayCreationExpression(ArrayCreationExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitArrayInitializer(ArrayInitializer, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitArrayInitializer(ArrayInitializer, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitArrayInitializer(ArrayInitializer, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitArrayInitializer(ArrayInitializer, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitArrayType(ArrayType, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitArrayType(ArrayType, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitArrayType(IrDocArrayType, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitArrayType(ArrayType, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitArrayType(ArrayType, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitAssertStatement(AssertStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitAssertStatement(AssertStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitAssertStatement(AssertStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitAssertStatement(AssertStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitAssignmentExpression(AssignmentExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitAssignmentExpression(AssignmentExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitAssignmentExpression(AssignmentExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitAssignmentExpression(AssignmentExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitAttribute(C, AstAttribute) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitAttribute(C, AstAttribute) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitAttributeElement(C, AstAttributeElement) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitAttributeElement(C, AstAttributeElement) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitAttributeValueArray(C, AstAttributeValueArray) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitAttributeValueArray(C, AstAttributeValueArray) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitAttributeValueMap(C, AstAttributeValueMap) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitAttributeValueMap(C, AstAttributeValueMap) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitBasicType(C, AstBasicType) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitBasicType(C, AstBasicType) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitBasicType(BasicType, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitBasicType(BasicType, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitBasicType(IrDocBasicType, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitBasicType(BasicType, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitBasicType(BasicType, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitBlock(Block, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitBlock(Block, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitBlock(IrDocBlock, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitBlock(Block, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitBlock(Block, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
Processes
Block
using this visitor.
- visitBlockComment(BlockComment, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitBlockComment(BlockComment, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitBlockComment(BlockComment, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitBlockComment(BlockComment, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitBreakStatement(BreakStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitBreakStatement(BreakStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitBreakStatement(BreakStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitBreakStatement(BreakStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitCastExpression(CastExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitCastExpression(CastExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitCastExpression(CastExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitCastExpression(CastExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitCatchClause(CatchClause, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitCatchClause(CatchClause, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitCatchClause(CatchClause, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitCatchClause(CatchClause, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitClass(Class<?>, ModelFactory) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeMapper
-
- visitClass(Class<?>, C) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeVisitor
-
Processes
Class
using this visitor.
- visitClassBody(ClassBody, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitClassBody(ClassBody, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitClassBody(ClassBody, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitClassBody(ClassBody, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitClassDeclaration(ClassDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitClassDeclaration(ClassDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitClassDeclaration(ClassDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitClassDeclaration(ClassDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitClassInstanceCreationExpression(ClassInstanceCreationExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitClassInstanceCreationExpression(ClassInstanceCreationExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitClassInstanceCreationExpression(ClassInstanceCreationExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitClassInstanceCreationExpression(ClassInstanceCreationExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitClassLiteral(ClassLiteral, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitClassLiteral(ClassLiteral, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitClassLiteral(ClassLiteral, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitClassLiteral(ClassLiteral, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitCollectionType(C, AstCollectionType) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitCollectionType(C, AstCollectionType) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitComment(IrDocComment, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitCompilationUnit(CompilationUnit, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitCompilationUnit(CompilationUnit, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitCompilationUnit(CompilationUnit, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitCompilationUnit(CompilationUnit, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitConditionalExpression(ConditionalExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitConditionalExpression(ConditionalExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitConditionalExpression(ConditionalExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitConditionalExpression(ConditionalExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitConstructorDeclaration(ConstructorDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitConstructorDeclaration(ConstructorDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitConstructorDeclaration(ConstructorDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitConstructorDeclaration(ConstructorDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitConstructorReferenceExpression(ConstructorReferenceExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitConstructorReferenceExpression(ConstructorReferenceExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitConstructorReferenceExpression(ConstructorReferenceExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitConstructorReferenceExpression(ConstructorReferenceExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitContinueStatement(ContinueStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitContinueStatement(ContinueStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitContinueStatement(ContinueStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitContinueStatement(ContinueStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitDescription(C, AstDescription) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitDescription(C, AstDescription) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitDocBlock(DocBlock, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitDocBlock(DocBlock, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitDocBlock(DocBlock, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitDocBlock(DocBlock, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitDocField(DocField, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitDocField(DocField, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitDocField(DocField, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitDocField(DocField, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitDocMethod(DocMethod, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitDocMethod(DocMethod, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitDocMethod(DocMethod, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitDocMethod(DocMethod, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitDocMethodParameter(DocMethodParameter, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitDocMethodParameter(DocMethodParameter, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitDocMethodParameter(DocMethodParameter, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitDocMethodParameter(DocMethodParameter, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitDocText(DocText, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitDocText(DocText, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitDocText(DocText, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitDocText(DocText, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
Processes
DocText
using this visitor.
- visitDoStatement(DoStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitDoStatement(DoStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitDoStatement(DoStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitDoStatement(DoStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitEmptyStatement(EmptyStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitEmptyStatement(EmptyStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitEmptyStatement(EmptyStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitEmptyStatement(EmptyStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitEnhancedForStatement(EnhancedForStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitEnhancedForStatement(EnhancedForStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitEnhancedForStatement(EnhancedForStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitEnhancedForStatement(EnhancedForStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitEnumConstantDeclaration(EnumConstantDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitEnumConstantDeclaration(EnumConstantDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitEnumConstantDeclaration(EnumConstantDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitEnumConstantDeclaration(EnumConstantDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitEnumDeclaration(EnumDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitEnumDeclaration(EnumDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitEnumDeclaration(EnumDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitEnumDeclaration(EnumDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitExpressionStatement(ExpressionStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitExpressionStatement(ExpressionStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitExpressionStatement(ExpressionStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitExpressionStatement(ExpressionStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitField(IrDocField, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitFieldAccessExpression(FieldAccessExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitFieldAccessExpression(FieldAccessExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitFieldAccessExpression(FieldAccessExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitFieldAccessExpression(FieldAccessExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitFieldDeclaration(FieldDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitFieldDeclaration(FieldDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitFieldDeclaration(FieldDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitFieldDeclaration(FieldDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitFormalParameterDeclaration(FormalParameterDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitFormalParameterDeclaration(FormalParameterDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitFormalParameterDeclaration(FormalParameterDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitFormalParameterDeclaration(FormalParameterDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitForStatement(ForStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitForStatement(ForStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitForStatement(ForStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitForStatement(ForStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitGenericArrayType(GenericArrayType, ModelFactory) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeMapper
-
- visitGenericArrayType(GenericArrayType, C) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeVisitor
-
- visitGrouping(C, AstGrouping) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitGrouping(C, AstGrouping) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitIfStatement(IfStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitIfStatement(IfStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitIfStatement(IfStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitIfStatement(IfStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitImportDeclaration(ImportDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitImportDeclaration(ImportDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitImportDeclaration(ImportDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitImportDeclaration(ImportDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitInfixExpression(InfixExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitInfixExpression(InfixExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitInfixExpression(InfixExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitInfixExpression(InfixExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitInitializerDeclaration(InitializerDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitInitializerDeclaration(InitializerDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitInitializerDeclaration(InitializerDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitInitializerDeclaration(InitializerDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitInstanceofExpression(InstanceofExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitInstanceofExpression(InstanceofExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitInstanceofExpression(InstanceofExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitInstanceofExpression(InstanceofExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitInterfaceDeclaration(InterfaceDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitInterfaceDeclaration(InterfaceDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitInterfaceDeclaration(InterfaceDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitInterfaceDeclaration(InterfaceDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitJavadoc(Javadoc, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitJavadoc(Javadoc, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitJavadoc(Javadoc, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitJavadoc(Javadoc, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
Processes
Javadoc
using this visitor.
- visitJoin(C, AstJoin) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitJoin(C, AstJoin) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitLabeledStatement(LabeledStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitLabeledStatement(LabeledStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitLabeledStatement(LabeledStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitLabeledStatement(LabeledStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitLambdaExpression(LambdaExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitLambdaExpression(LambdaExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitLambdaExpression(LambdaExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitLambdaExpression(LambdaExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitLineComment(LineComment, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitLineComment(LineComment, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitLineComment(LineComment, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitLineComment(LineComment, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitLiteral(C, AstLiteral) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitLiteral(C, AstLiteral) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitLiteral(Literal, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitLiteral(Literal, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitLiteral(Literal, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitLiteral(Literal, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
Processes
Literal
using this visitor.
- visitLocalClassDeclaration(LocalClassDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitLocalClassDeclaration(LocalClassDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitLocalClassDeclaration(LocalClassDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitLocalClassDeclaration(LocalClassDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitLocalVariableDeclaration(LocalVariableDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitLocalVariableDeclaration(LocalVariableDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitLocalVariableDeclaration(LocalVariableDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitLocalVariableDeclaration(LocalVariableDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitMarkerAnnotation(MarkerAnnotation, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitMarkerAnnotation(MarkerAnnotation, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitMarkerAnnotation(MarkerAnnotation, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitMarkerAnnotation(MarkerAnnotation, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitMethod(IrDocMethod, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitMethodDeclaration(MethodDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitMethodDeclaration(MethodDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitMethodDeclaration(MethodDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitMethodDeclaration(MethodDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitMethodInvocationExpression(MethodInvocationExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitMethodInvocationExpression(MethodInvocationExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitMethodInvocationExpression(MethodInvocationExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitMethodInvocationExpression(MethodInvocationExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitMethodParameter(IrDocMethodParameter, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitMethodReferenceExpression(MethodReferenceExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitMethodReferenceExpression(MethodReferenceExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitMethodReferenceExpression(MethodReferenceExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitMethodReferenceExpression(MethodReferenceExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitModelDefinition(C, AstModelDefinition<T>) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitModelDefinition(C, AstModelDefinition<T>) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitModelFolding(C, AstModelFolding) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitModelFolding(C, AstModelFolding) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitModelMapping(C, AstModelMapping) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitModelMapping(C, AstModelMapping) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitModelReference(C, AstModelReference) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitModelReference(C, AstModelReference) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitModifier(Modifier, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitModifier(Modifier, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitModifier(Modifier, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitModifier(Modifier, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitNamedType(NamedType, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitNamedType(NamedType, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitNamedType(IrDocNamedType, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitNamedType(NamedType, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitNamedType(NamedType, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitNormalAnnotation(NormalAnnotation, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitNormalAnnotation(NormalAnnotation, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitNormalAnnotation(NormalAnnotation, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitNormalAnnotation(NormalAnnotation, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- Visitor<R,C,E extends Throwable> - Class in com.asakusafw.utils.java.model.syntax
-
- Visitor() - Constructor for class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitPackageDeclaration(PackageDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitPackageDeclaration(PackageDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitPackageDeclaration(PackageDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitPackageDeclaration(PackageDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitParameterizedType(ParameterizedType, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitParameterizedType(ParameterizedType, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitParameterizedType(ParameterizedType, ModelFactory) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeMapper
-
- visitParameterizedType(ParameterizedType, C) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeVisitor
-
- visitParameterizedType(ParameterizedType, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitParameterizedType(ParameterizedType, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitParenthesizedExpression(ParenthesizedExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitParenthesizedExpression(ParenthesizedExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitParenthesizedExpression(ParenthesizedExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitParenthesizedExpression(ParenthesizedExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitPostfixExpression(PostfixExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitPostfixExpression(PostfixExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitPostfixExpression(PostfixExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitPostfixExpression(PostfixExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitPropertyDefinition(C, AstPropertyDefinition) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitPropertyDefinition(C, AstPropertyDefinition) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitPropertyFolding(C, AstPropertyFolding) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitPropertyFolding(C, AstPropertyFolding) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitPropertyMapping(C, AstPropertyMapping) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitPropertyMapping(C, AstPropertyMapping) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitQualifiedName(C, AstQualifiedName) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitQualifiedName(C, AstQualifiedName) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitQualifiedName(QualifiedName, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitQualifiedName(QualifiedName, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitQualifiedName(IrDocQualifiedName, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitQualifiedName(QualifiedName, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitQualifiedName(QualifiedName, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitQualifiedType(QualifiedType, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitQualifiedType(QualifiedType, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitQualifiedType(QualifiedType, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitQualifiedType(QualifiedType, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitRecordDefinition(C, AstRecordDefinition) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitRecordDefinition(C, AstRecordDefinition) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitReferenceType(C, AstReferenceType) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitReferenceType(C, AstReferenceType) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitReturnStatement(ReturnStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitReturnStatement(ReturnStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitReturnStatement(ReturnStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitReturnStatement(ReturnStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitScript(C, AstScript) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitScript(C, AstScript) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitSequenceType(C, AstSequenceType) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitSequenceType(C, AstSequenceType) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitSimpleName(C, AstSimpleName) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitSimpleName(C, AstSimpleName) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitSimpleName(SimpleName, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSimpleName(SimpleName, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSimpleName(IrDocSimpleName, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitSimpleName(SimpleName, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSimpleName(SimpleName, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitSingleElementAnnotation(SingleElementAnnotation, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSingleElementAnnotation(SingleElementAnnotation, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSingleElementAnnotation(SingleElementAnnotation, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSingleElementAnnotation(SingleElementAnnotation, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitStatementExpressionList(StatementExpressionList, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitStatementExpressionList(StatementExpressionList, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitStatementExpressionList(StatementExpressionList, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitStatementExpressionList(StatementExpressionList, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitSummarize(C, AstSummarize) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitSummarize(C, AstSummarize) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitSuper(Super, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSuper(Super, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSuper(Super, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSuper(Super, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
Processes
Super
using this visitor.
- visitSuperConstructorInvocation(SuperConstructorInvocation, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSuperConstructorInvocation(SuperConstructorInvocation, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSuperConstructorInvocation(SuperConstructorInvocation, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSuperConstructorInvocation(SuperConstructorInvocation, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitSwitchCaseLabel(SwitchCaseLabel, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSwitchCaseLabel(SwitchCaseLabel, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSwitchCaseLabel(SwitchCaseLabel, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSwitchCaseLabel(SwitchCaseLabel, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitSwitchDefaultLabel(SwitchDefaultLabel, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSwitchDefaultLabel(SwitchDefaultLabel, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSwitchDefaultLabel(SwitchDefaultLabel, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSwitchDefaultLabel(SwitchDefaultLabel, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitSwitchStatement(SwitchStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSwitchStatement(SwitchStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSwitchStatement(SwitchStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSwitchStatement(SwitchStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitSynchronizedStatement(SynchronizedStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitSynchronizedStatement(SynchronizedStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitSynchronizedStatement(SynchronizedStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitSynchronizedStatement(SynchronizedStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitText(IrDocText, P) - Method in class com.asakusafw.utils.java.internal.parser.javadoc.ir.IrDocElementVisitor
-
- visitThis(This, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitThis(This, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitThis(This, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitThis(This, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
Processes
This
using this visitor.
- visitThrowStatement(ThrowStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitThrowStatement(ThrowStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitThrowStatement(ThrowStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitThrowStatement(ThrowStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitTryResource(TryResource, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitTryResource(TryResource, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitTryResource(TryResource, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitTryResource(TryResource, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitTryStatement(TryStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitTryStatement(TryStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitTryStatement(TryStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitTryStatement(TryStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitTypeParameterDeclaration(TypeParameterDeclaration, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitTypeParameterDeclaration(TypeParameterDeclaration, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitTypeParameterDeclaration(TypeParameterDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitTypeParameterDeclaration(TypeParameterDeclaration, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitTypeVariable(TypeVariable<?>, ModelFactory) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeMapper
-
- visitTypeVariable(TypeVariable<?>, C) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeVisitor
-
- visitUnaryExpression(UnaryExpression, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitUnaryExpression(UnaryExpression, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitUnaryExpression(UnaryExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitUnaryExpression(UnaryExpression, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitUnionExpression(C, AstUnionExpression<T>) - Method in class com.asakusafw.dmdl.model.AstNode.AbstractVisitor
-
- visitUnionExpression(C, AstUnionExpression<T>) - Method in interface com.asakusafw.dmdl.model.AstNode.Visitor
-
- visitUnionType(UnionType, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitUnionType(UnionType, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitUnionType(UnionType, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitUnionType(UnionType, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitVariableDeclarator(VariableDeclarator, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitVariableDeclarator(VariableDeclarator, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitVariableDeclarator(VariableDeclarator, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitVariableDeclarator(VariableDeclarator, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitWhileStatement(WhileStatement, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitWhileStatement(WhileStatement, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitWhileStatement(WhileStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitWhileStatement(WhileStatement, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitWildcard(Wildcard, DigestContext) - Method in class com.asakusafw.utils.java.internal.model.util.ModelDigester
-
- visitWildcard(Wildcard, Model) - Method in class com.asakusafw.utils.java.internal.model.util.ModelMatcher
-
- visitWildcard(Wildcard, C) - Method in class com.asakusafw.utils.java.model.syntax.StrictVisitor
-
- visitWildcard(Wildcard, C) - Method in class com.asakusafw.utils.java.model.syntax.Visitor
-
- visitWildcardType(WildcardType, ModelFactory) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeMapper
-
- visitWildcardType(WildcardType, C) - Method in class com.asakusafw.utils.java.internal.model.util.ReflectionTypeVisitor
-
- VOID_RESOURCE_NAME - Static variable in class com.asakusafw.vocabulary.windgate.Constants
-
The abstract resource name of void inputs/outputs.
- voidCleanUp(ExecutionContext) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
- VoidDeleteTaskExecutor - Class in com.asakusafw.testdriver.executor
-
- VoidDeleteTaskExecutor() - Constructor for class com.asakusafw.testdriver.executor.VoidDeleteTaskExecutor
-
- VoidDrainDriver<T> - Class in com.asakusafw.windgate.core.util
-
A void implementation of
DrainDriver
which drops any inputs.
- VoidDrainDriver() - Constructor for class com.asakusafw.windgate.core.util.VoidDrainDriver
-
- VoidInputStream - Class in com.asakusafw.runtime.io.util
-
- VoidInputStream() - Constructor for class com.asakusafw.runtime.io.util.VoidInputStream
-
- VoidModelInput<T> - Class in com.asakusafw.runtime.io.util
-
- VoidModelInput() - Constructor for class com.asakusafw.runtime.io.util.VoidModelInput
-
- VoidModelOutput<T> - Class in com.asakusafw.runtime.io.util
-
- VoidModelOutput() - Constructor for class com.asakusafw.runtime.io.util.VoidModelOutput
-
- VoidOutputStream - Class in com.asakusafw.runtime.io.util
-
- VoidOutputStream() - Constructor for class com.asakusafw.runtime.io.util.VoidOutputStream
-
- VoidResourceProvider - Class in com.asakusafw.windgate.core.util
-
Provides void resources.
- VoidResourceProvider() - Constructor for class com.asakusafw.windgate.core.util.VoidResourceProvider
-
- VoidResult<T> - Class in com.asakusafw.runtime.flow
-
An implementation of
Result
that discards all results.
- VoidResult() - Constructor for class com.asakusafw.runtime.flow.VoidResult
-
- voidSetUp(ExecutionContext) - Method in class com.asakusafw.yaess.core.ExecutionScriptHandlerBase
-
- VoidSourceDriver<T> - Class in com.asakusafw.windgate.core.util
-
The void implementation of
SourceDriver
which provides nothing.
- VoidSourceDriver() - Constructor for class com.asakusafw.windgate.core.util.VoidSourceDriver
-
- Volatile() - Method in class com.asakusafw.utils.java.model.util.AttributeBuilder
-
Appends volatile
modifier to this builder.
- Volatile - Annotation Type in com.asakusafw.vocabulary.operator
-
多重化に関する最適化を抑止すべきメソッドに付与する注釈。
- VolatileClassFile - Class in com.asakusafw.utils.java.jsr199.testing
-
Represents a Java class file which is stored on the heap.
- VolatileClassFile(String) - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileClassFile
-
Creates a new instance with empty contents.
- VolatileClassFile(String, byte[]) - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileClassFile
-
Creates a new instance with the specified contents.
- VolatileClassOutputManager - Class in com.asakusafw.utils.java.jsr199.testing
-
An implementation of
JavaFileManager
which stores generated contents onto the heap.
- VolatileClassOutputManager(JavaFileManager) - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileClassOutputManager
-
Creates a new instance.
- VolatileCompiler - Class in com.asakusafw.utils.java.jsr199.testing
-
Compiles Java source programs and generates source/resource/class files onto the heap.
- VolatileCompiler() - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileCompiler
-
Creates a new instance.
- VolatileJavaFile - Class in com.asakusafw.utils.java.jsr199.testing
-
Represents a Java source file which is stored on the heap.
- VolatileJavaFile(String) - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileJavaFile
-
Creates a new instance with empty contents.
- VolatileJavaFile(String, String) - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileJavaFile
-
Creates a new instance with the specified contents.
- VolatileLookUpTable<T> - Class in com.asakusafw.runtime.flow.join
-
An implementation of
LookUpTable
that holds objects on the memory.
- VolatileLookUpTable.Builder<T> - Class in com.asakusafw.runtime.flow.join
-
- VolatileResourceFile - Class in com.asakusafw.utils.java.jsr199.testing
-
A
FileObject
implementation which is stored on the heap.
- VolatileResourceFile(String) - Constructor for class com.asakusafw.utils.java.jsr199.testing.VolatileResourceFile
-
Creates a new instance.