- AboutHandler - Class in water.api
-
- AboutHandler() - Constructor for class water.api.AboutHandler
-
- AboutHandler.AboutEntryV3 - Class in water.api
-
- AboutHandler.AboutEntryV3() - Constructor for class water.api.AboutHandler.AboutEntryV3
-
- AboutHandler.AboutEntryV3(String, String) - Constructor for class water.api.AboutHandler.AboutEntryV3
-
- AboutHandler.AboutV3 - Class in water.api
-
- AboutHandler.AboutV3() - Constructor for class water.api.AboutHandler.AboutV3
-
- AbstractBuildVersion - Class in water.init
-
- AbstractBuildVersion() - Constructor for class water.init.AbstractBuildVersion
-
- AbstractEmbeddedH2OConfig - Class in water.init
-
This class is a small shim between a main java program (such as a
Hadoop mapper) and an embedded full-capability H2O.
- AbstractEmbeddedH2OConfig() - Constructor for class water.init.AbstractEmbeddedH2OConfig
-
- ABV - Static variable in class water.H2O
-
- acceptsFrame(Frame) - Method in class water.api.Schema
-
Deprecated.
- accuracy - Variable in class hex.AUCData
-
- accuracy(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- accuracy() - Method in class hex.AUCData
-
- accuracy() - Method in class hex.ConfusionMatrix
-
The percentage of predictions that are correct.
- accuracy - Variable in class water.api.AUCBase
-
- accuracy_for_criteria - Variable in class water.api.AUCBase
-
- ACK_ACK_PRIORITY - Static variable in class water.H2O
-
- ACK_PRIORITY - Static variable in class water.H2O
-
- actual - Variable in class hex.AUC
-
- actual - Variable in class hex.HitRatio
-
- actual_domain - Variable in class water.api.AUCBase
-
- actual_value - Variable in class water.api.ModelParameterSchemaV2
-
- adapt(Runnable) - Static method in class jsr166y.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
run
method of the given
Runnable
as its action, and returns
a null result upon
ForkJoinTask.join()
.
- adapt(Runnable, T) - Static method in class jsr166y.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
run
method of the given
Runnable
as its action, and returns
the given result upon
ForkJoinTask.join()
.
- adapt(Callable<? extends T>) - Static method in class jsr166y.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
call
method of the given
Callable
as its action, and returns
its result upon
ForkJoinTask.join()
, translating any checked exceptions
encountered into
RuntimeException
.
- adaptTestForTrain(Frame, boolean) - Method in class hex.Model
-
Adapt a Test/Validation Frame to be compatible for a Training Frame.
- adaptTestForTrain(String[], String[][], Frame, double, boolean) - Static method in class hex.Model
-
- adaptTo(String[]) - Method in class water.fvec.Vec
-
Make a Vec adapting this Enum vector to the 'to' Enum Vec.
- add(int, int) - Method in class hex.ConfusionMatrix
-
- add(ConfusionMatrix) - Method in class hex.ConfusionMatrix
-
- add(E) - Method in class jsr166y.ConcurrentLinkedDeque
-
Inserts the specified element at the tail of this deque.
- add(E) - Method in class jsr166y.LinkedTransferQueue
-
Inserts the specified element at the tail of this queue.
- add(Future) - Method in class water.Futures
-
Some Future task which needs to complete before this Futures completes
- add(Futures) - Method in class water.Futures
-
Merge pending-task lists (often as part of doing a 'reduce' step)
- add(String[], Vec[]) - Method in class water.fvec.Frame
-
- add(String, Vec) - Method in class water.fvec.Frame
-
Append a named Vec to the Frame.
- add(Frame) - Method in class water.fvec.Frame
-
Append a Frame onto this Frame.
- add(NewChunk) - Method in class water.fvec.NewChunk
-
- add(Chunk) - Method in class water.Quantiles
-
- add(double) - Method in class water.Quantiles
-
- add(Quantiles) - Method in class water.Quantiles
-
- add(byte[], byte[]) - Static method in class water.util.ArrayUtils
-
- add(int[], int[]) - Static method in class water.util.ArrayUtils
-
- add(int[][], int[][]) - Static method in class water.util.ArrayUtils
-
- add(long[], long[]) - Static method in class water.util.ArrayUtils
-
- add(long[][], long[][]) - Static method in class water.util.ArrayUtils
-
- add(long[][][], long[][][]) - Static method in class water.util.ArrayUtils
-
- add(float[], float[]) - Static method in class water.util.ArrayUtils
-
- add(float[][], float[][]) - Static method in class water.util.ArrayUtils
-
- add(double[], double[]) - Static method in class water.util.ArrayUtils
-
- add(double[], double[], double[]) - Static method in class water.util.ArrayUtils
-
- add(double[][], double[][]) - Static method in class water.util.ArrayUtils
-
- add(double[][][], double[][][]) - Static method in class water.util.ArrayUtils
-
- add(long[], long) - Static method in class water.util.ArrayUtils
-
- add(double[], int, double) - Static method in class water.util.AtomicUtils.DoubleArray
-
- add(float[], int, float) - Static method in class water.util.AtomicUtils.FloatArray
-
- add(int[], int, int) - Static method in class water.util.AtomicUtils.IntArray
-
- add2Chunk(NewChunk) - Method in class water.fvec.NewChunk.Value
-
- addAll(Collection<? extends E>) - Method in class jsr166y.ConcurrentLinkedDeque
-
Appends all of the elements in the specified collection to the end of
this deque, in the order that they are returned by the specified
collection's iterator.
- addAndCloseChunk(Chunk, Futures) - Method in class water.fvec.UploadFileVec
-
- addCompleter(H2O.H2OCountedCompleter) - Method in class water.RPC
-
- addEnum(int) - Method in class water.fvec.NewChunk
-
- addFirst(E) - Method in class jsr166y.ConcurrentLinkedDeque
-
Inserts the specified element at the front of this deque.
- addFolder(Path, ArrayList<String>, ArrayList<String>) - Static method in class water.persist.PersistHdfs
-
- addHeader(String, String) - Method in class water.NanoHTTPD.Response
-
Adds given line to the header.
- addInvalidCol(int) - Method in class water.parser.Parser.InspectDataOut
-
- addLast(E) - Method in class jsr166y.ConcurrentLinkedDeque
-
Inserts the specified element at the end of this deque.
- addModelMetrics(ModelMetrics) - Method in class hex.Model.Output
-
- addNA() - Method in class water.fvec.NewChunk
-
- addNum(long, int) - Method in class water.fvec.NewChunk
-
- addNum(double) - Method in class water.fvec.NewChunk
-
- addNumCol(int, long, int) - Method in class water.parser.Parser.InspectDataOut
-
- addNumCol(int, double) - Method in class water.parser.Parser.InspectDataOut
-
- addr(NewChunk) - Method in class water.fvec.NewChunk
-
- addRef(Frame) - Method in class water.rapids.Env
-
- addrPack() - Method in class water.init.TimelineSnapshot.Event
-
- addrString() - Method in class water.init.TimelineSnapshot.Event
-
- addStr(ValueString) - Method in class water.fvec.NewChunk
-
- addStrCol(int, ValueString) - Method in class water.parser.Parser.InspectDataOut
-
- addToNavbar(Route, String, String, String) - Static method in class water.api.RequestServer
-
- addToPendingCount(int) - Method in class jsr166y.CountedCompleter
-
Adds (atomically) the given value to the pending count.
- addUUID(long, long) - Method in class water.fvec.NewChunk
-
- addUUID(Chunk, long) - Method in class water.fvec.NewChunk
-
- addUUID(Chunk, int) - Method in class water.fvec.NewChunk
-
- addVec() - Method in class water.fvec.Vec.VectorGroup
-
Shortcut for addVecs(1)
.
- addVecs(int) - Method in class water.fvec.Vec.VectorGroup
-
Gets the next n keys of this group.
- addWarning(String) - Method in class hex.Model
-
- addZeros(int) - Method in class water.fvec.NewChunk
-
- algo - Variable in class water.api.ModelSchema
-
- align(Vec) - Method in class water.fvec.Vec
-
Always makes a copy of the given vector which shares the same group as
this Vec.
- allNames() - Method in class hex.Model.Output
-
The names of all the columns, including the response column (which comes last).
- anyURIToKey(URI) - Static method in class water.persist.Persist
-
- anyVec() - Method in class water.fvec.Frame
-
Returns the first readable vector.
- API - Annotation Type in water.api
-
API Annotation
API annotations are used to document field behaviors for the external REST API.
- API.Direction - Enum in water.api
-
Is a given field an input, an output, or both?
- API.Level - Enum in water.api
-
How important is it to specify a given field to get a useful result?
- API_PORT - Static variable in class water.H2O
-
- APIException - Exception in water.api
-
The exception to report various errors during
handling API requests.
- APIException(String, Throwable) - Constructor for exception water.api.APIException
-
- append(double[][], double[][]) - Static method in class water.util.ArrayUtils
-
- append(double[], double[]) - Static method in class water.util.ArrayUtils
-
- append(String[], String[]) - Static method in class water.util.ArrayUtils
-
- append(T[], T...) - Static method in class water.util.ArrayUtils
-
- append(StringBuffer) - Method in class water.util.MarkdownBuilder
-
- append(String) - Method in class water.util.MarkdownBuilder
-
- append_field_arrays(String[], String[]) - Static method in class water.api.ModelParametersSchema
-
- AppendableVec - Class in water.fvec
-
A NEW single distributed vector column.
- AppendableVec(Key) - Constructor for class water.fvec.AppendableVec
-
- AppendableVec(Key, long[], int) - Constructor for class water.fvec.AppendableVec
-
- approxExp(double) - Static method in class water.util.MathUtils
-
Fast approximate exp
- approxInvSqrt(double) - Static method in class water.util.MathUtils
-
Fast approximate 1./sqrt
- approxInvSqrt(float) - Static method in class water.util.MathUtils
-
Fast approximate 1./sqrt
- approxLog(double) - Static method in class water.util.MathUtils
-
Fast approximate log for values greater than 1, otherwise exact
- approxSqrt(double) - Static method in class water.util.MathUtils
-
Fast approximate sqrt
- approxSqrt(float) - Static method in class water.util.MathUtils
-
Fast approximate sqrt
- approxSumSquares(float[], int, int) - Static method in class water.util.MathUtils
-
Approximate sumSquares
- ARGS - Static variable in class water.H2O
-
Singleton ARGS instance that contains the processed arguments.
- array(String[]) - Method in class water.util.DocGen.HTML
-
- array(int[]) - Method in class water.util.DocGen.HTML
-
- array(double[]) - Method in class water.util.DocGen.HTML
-
- array(float[]) - Method in class water.util.DocGen.HTML
-
- array(Enum[]) - Method in class water.util.DocGen.HTML
-
- array(String[][]) - Method in class water.util.DocGen.HTML
-
- array(double[][]) - Method in class water.util.DocGen.HTML
-
- array(float[][]) - Method in class water.util.DocGen.HTML
-
- array(int[][]) - Method in class water.util.DocGen.HTML
-
- array(long[][]) - Method in class water.util.DocGen.HTML
-
- array(long[][][]) - Method in class water.util.DocGen.HTML
-
- arrayCopyOf(byte[], int) - Static method in class water.MemoryManager
-
- arrayCopyOf(int[], int) - Static method in class water.MemoryManager
-
- arrayCopyOf(long[], int) - Static method in class water.MemoryManager
-
- arrayCopyOf(double[], int) - Static method in class water.MemoryManager
-
- arrayCopyOfRange(byte[], int, int) - Static method in class water.MemoryManager
-
- arrayCopyOfRange(int[], int, int) - Static method in class water.MemoryManager
-
- arrayCopyOfRange(long[], int, int) - Static method in class water.MemoryManager
-
- arrayCopyOfRange(double[], int, int) - Static method in class water.MemoryManager
-
- arrayHead() - Method in class water.util.DocGen.HTML
-
- arrayHead(String[]) - Method in class water.util.DocGen.HTML
-
- arrayRow(String[]) - Method in class water.util.DocGen.HTML
-
- arrayTail() - Method in class water.util.DocGen.HTML
-
- ArrayUtils - Class in water.util
-
- ArrayUtils() - Constructor for class water.util.ArrayUtils
-
- arrive() - Method in class jsr166y.Phaser
-
Arrives at this phaser, without waiting for others to arrive.
- arriveAndAwaitAdvance() - Method in class jsr166y.Phaser
-
Arrives at this phaser and awaits others.
- arriveAndDeregister() - Method in class jsr166y.Phaser
-
Arrives at this phaser and deregisters from it without waiting
for others to arrive.
- AST - Class in water.rapids
-
Each node in the syntax tree knows how to parse a piece of text from the passed tree.
- AST() - Constructor for class water.rapids.AST
-
- ASTApply - Class in water.rapids
-
R's `apply`
- ASTApply() - Constructor for class water.rapids.ASTApply
-
- ASTddply - Class in water.rapids
-
plyr's ddply: GroupBy by any other name.
- ASTddply() - Constructor for class water.rapids.ASTddply
-
- ASTddply.ddplyPass1 - Class in water.rapids
-
- ASTddply.Group - Class in water.rapids
-
- ASTddply.Group(int) - Constructor for class water.rapids.ASTddply.Group
-
- ASTFunc - Class in water.rapids
-
Functions will always have all of their arguments fully specified (even if that means they are filled with null).
- ASTFunc() - Constructor for class water.rapids.ASTFunc
-
- ASTFunc(String, String[], Env.SymbolTable, ASTStatement) - Constructor for class water.rapids.ASTFunc
-
- ASTOp - Class in water.rapids
-
Parse a generic R string and build an AST, in the context of an H2O Cloud
- asyncExec(Vec...) - Method in class water.MRTask
-
- asyncExec(Frame) - Method in class water.MRTask
-
- asyncExec(int, Frame, boolean) - Method in class water.MRTask
-
Fork the task in strictly non-blocking fashion.
- at(long) - Method in class water.fvec.Vec
-
Fetch element the slow way, as a double, or Double.NaN is missing.
- at16h(int) - Method in class water.fvec.Chunk
-
High half of a 128-bit UUID, or throws if the value is missing.
- at16h(long) - Method in class water.fvec.Vec
-
Fetch element the slow way, as the high half of a UUID.
- at16h_impl(int) - Method in class water.fvec.NewChunk
-
- at16l(int) - Method in class water.fvec.Chunk
-
Low half of a 128-bit UUID, or throws if the value is missing.
- at16l(long) - Method in class water.fvec.Vec
-
Fetch element the slow way, as the low half of a UUID.
- at16l_impl(int) - Method in class water.fvec.NewChunk
-
- at8(int) - Method in class water.fvec.Chunk
-
Load a long
value using chunk-relative row numbers.
- at8(long) - Method in class water.fvec.Vec
-
Fetch element the slow way, as a long.
- at8_impl(int) - Method in class water.fvec.NewChunk
-
- atd(int) - Method in class water.fvec.Chunk
-
Load a double
value using chunk-relative row numbers.
- atd_impl(int) - Method in class water.fvec.NewChunk
-
- Atomic<T extends Atomic> - Class in water
-
Atomic update of a Key
- Atomic() - Constructor for class water.Atomic
-
- Atomic(H2O.H2OCountedCompleter) - Constructor for class water.Atomic
-
- atomic(Value) - Method in class water.Atomic
-
- atomic(Job.Progress) - Method in class water.Job.ProgressUpdate
-
Update progress with new work
- atomic(T) - Method in class water.TAtomic
-
Atomically update an old value to a new one.
- atomic(Value) - Method in class water.TAtomic
-
- ATOMIC_PRIORITY - Static variable in class water.H2O
-
- AtomicUtils - Class in water.util
-
- AtomicUtils() - Constructor for class water.util.AtomicUtils
-
- AtomicUtils.DoubleArray - Class in water.util
-
- AtomicUtils.DoubleArray() - Constructor for class water.util.AtomicUtils.DoubleArray
-
- AtomicUtils.FloatArray - Class in water.util
-
- AtomicUtils.FloatArray() - Constructor for class water.util.AtomicUtils.FloatArray
-
- AtomicUtils.IntArray - Class in water.util
-
- AtomicUtils.IntArray() - Constructor for class water.util.AtomicUtils.IntArray
-
- AtomicUtils.LongArray - Class in water.util
-
- AtomicUtils.LongArray() - Constructor for class water.util.AtomicUtils.LongArray
-
- atStr(ValueString, int) - Method in class water.fvec.Chunk
-
String value using chunk-relative row numbers, or null if missing.
- atStr(ValueString, long) - Method in class water.fvec.Vec
-
Fetch element the slow way, as a
ValueString
or null if missing.
- atStr_impl(ValueString, int) - Method in class water.fvec.NewChunk
-
- attemptTimeParse(ValueString) - Static method in class water.parser.ParseTime
-
- attemptUUIDParse0(ValueString) - Static method in class water.parser.ParseTime
-
- attemptUUIDParse1(ValueString) - Static method in class water.parser.ParseTime
-
- AUC - Class in hex
-
- AUC(ConfusionMatrix[], float[], String[]) - Constructor for class hex.AUC
-
Constructor for algos that make their own CMs
- AUC - Variable in class hex.AUCData
-
- AUC() - Method in class hex.AUCData
-
- AUC - Variable in class water.api.AUCBase
-
- auc - Variable in class water.api.ModelMetricsBase
-
- AUC.ThresholdCriterion - Enum in hex
-
- AUCBase<I extends AUCData,S extends AUCBase<I,S>> - Class in water.api
-
- AUCBase() - Constructor for class water.api.AUCBase
-
- AUCData - Class in hex
-
- AUCData() - Constructor for class hex.AUCData
-
- AUCV3 - Class in water.api
-
- AUCV3() - Constructor for class water.api.AUCV3
-
- AutoBuffer - Class in water
-
A ByteBuffer backed mixed Input/OutputStream class.
- AutoBuffer(FileChannel, boolean, byte) - Constructor for class water.AutoBuffer
-
- AutoBuffer(byte[]) - Constructor for class water.AutoBuffer
-
Read from a fixed byte[]; should not be closed.
- AutoBuffer() - Constructor for class water.AutoBuffer
-
Write to an ever-expanding byte[].
- AutoBuffer(int) - Constructor for class water.AutoBuffer
-
Write to a known sized byte[].
- avg(double[]) - Static method in class water.util.ArrayUtils
-
- avg(long[]) - Static method in class water.util.ArrayUtils
-
- awaitAdvance(int) - Method in class jsr166y.Phaser
-
Awaits the phase of this phaser to advance from the given phase
value, returning immediately if the current phase is not equal
to the given phase value or this phaser is terminated.
- awaitAdvanceInterruptibly(int) - Method in class jsr166y.Phaser
-
Awaits the phase of this phaser to advance from the given phase
value, throwing InterruptedException
if interrupted
while waiting, or returning immediately if the current phase is
not equal to the given phase value or this phaser is
terminated.
- awaitAdvanceInterruptibly(int, long, TimeUnit) - Method in class jsr166y.Phaser
-
Awaits the phase of this phaser to advance from the given phase
value or the given timeout to elapse, throwing InterruptedException
if interrupted while waiting, or
returning immediately if the current phase is not equal to the
given phase value or this phaser is terminated.
- awaitTermination(long, TimeUnit) - Method in class jsr166y.ForkJoinPool
-
Blocks until all tasks have completed execution after a shutdown
request, or the timeout occurs, or the current thread is
interrupted, whichever happens first.
- aws_credentials - Variable in class water.H2O.OptArgs
-
-aws_credentials=aws_credentials; properties file for aws credentials
- C1NCHUNK - Static variable in class water.TypeMap
-
- cache() - Static method in class water.KeySnapshot
-
- calcOptimalChunkSize(long, int) - Static method in class water.fvec.FileVec
-
Calculates safe and hopefully optimal chunk sizes.
- call(H2ONode, DT) - Static method in class water.RPC
-
- call() - Method in class water.RPC
-
- callback(T) - Method in class water.H2O.H2OCallback
-
- can_build() - Method in class hex.ModelBuilder
-
List containing the categories of models that this builder can
build.
- can_build - Variable in class hex.schemas.ModelBuilderSchema
-
- cancel(boolean) - Method in class jsr166y.ForkJoinTask
-
Attempts to cancel execution of this task.
- cancel() - Method in class water.Job
-
Signal cancellation of this job.
- cancel(String) - Method in class water.Job
-
Signal exceptional cancellation of this job.
- cancel(boolean) - Method in class water.RPC
-
- cancel2(Throwable) - Method in class water.Job
-
Signal exceptional cancellation of this job.
- cancel_sparse() - Method in class water.fvec.NewChunk
-
- cardinality() - Method in class water.fvec.Vec
-
Returns cardinality for enum domain or -1 for other types.
- cardinality() - Method in class water.util.IcedBitSet
-
- Categorical - Class in water.parser
-
Class for tracking categorical (enum) columns.
- categorical_fraction - Variable in class hex.CreateFrame
-
- cell(Enum) - Method in class water.util.DocGen.HTML
-
- cell(String) - Method in class water.util.DocGen.HTML
-
- cell(long) - Method in class water.util.DocGen.HTML
-
- cell(double) - Method in class water.util.DocGen.HTML
-
- cell(String[]) - Method in class water.util.DocGen.HTML
-
- cell(double[]) - Method in class water.util.DocGen.HTML
-
- cellValues - Variable in class water.api.TwoDimTableV1
-
- CHAR_DECIMAL_SEP - Variable in class water.parser.Parser
-
- CHAR_SEPARATOR - Variable in class water.parser.Parser
-
- check(File) - Static method in class water.util.FileIntegrityChecker
-
- checkCompatible(Frame) - Method in class water.fvec.Frame
-
Quick compatibility check between Frames.
- checkHeader - Variable in class water.parser.ParseSetupV2
-
- checksum - Variable in class water.api.FrameV2
-
- checksum - Variable in class water.api.ModelSchema
-
- checksum() - Method in class water.Keyed
-
- checksum_impl() - Method in class hex.Model
-
- checksum_impl() - Method in class hex.Model.Parameters
-
Compute a checksum based on all non-transient non-static ice-able assignable fields (incl.
- checksum_impl() - Method in class hex.ModelMetrics
-
- checksum_impl() - Method in class water.fvec.Frame
-
64-bit checksum of the checksums of the vecs.
- checksum_impl() - Method in class water.fvec.Vec
-
A high-quality 64-bit checksum of the Vec's content, useful for
establishing dataset identity.
- checksum_impl() - Method in class water.Job
-
Default checksum; not really used by Jobs.
- checksum_impl() - Method in class water.Keyed
-
High-quality 64-bit checksum of the content of the
object.
- CHK - Static variable in class water.Key
-
- chk2() - Method in class water.fvec.Chunk
-
Exposed for internal testing only.
- Chunk - Class in water.fvec
-
A compression scheme, over a chunk of data - a single array of bytes.
- Chunk() - Constructor for class water.fvec.Chunk
-
- chunk2StartElem(int) - Method in class water.fvec.AppendableVec
-
- chunkCnts - Variable in class hex.DMatrix.MatrixMulStats
-
- chunkForChunkIdx(int) - Method in class water.fvec.AppendableVec
-
- chunkForChunkIdx(int) - Method in class water.fvec.ByteVec
-
- chunkForChunkIdx(int) - Method in class water.fvec.EnumWrappedVec
-
- chunkForChunkIdx(int) - Method in class water.fvec.StrWrappedVec
-
- chunkForChunkIdx(int) - Method in class water.fvec.SubsetVec
-
- chunkForChunkIdx(int) - Method in class water.fvec.Vec
-
The Chunk for a chunk#.
- chunkForRow(long) - Method in class water.fvec.Vec
-
The Chunk for a row#.
- chunkIdx(int) - Method in class water.fvec.AppendableVec
-
- chunkIdx(int) - Method in class water.fvec.FileVec
-
- chunkIdx(int) - Method in class water.fvec.UploadFileVec
-
- chunkKey(int) - Method in class water.fvec.Vec
-
Get a Chunk Key from a chunk-index.
- chunkKey(Key, int) - Static method in class water.fvec.Vec
-
Get a Chunk Key from a chunk-index and a Vec Key, without needing the
actual Vec object.
- chunkOffset(Key) - Static method in class water.fvec.FileVec
-
Convert a chunk-key to a file offset.
- chunksDone - Variable in class hex.DMatrix.MatrixMulStats
-
- ChunkSplitter - Class in water
-
Helper to provide access to package
hidden methods and attributes.
- ChunkSplitter() - Constructor for class water.ChunkSplitter
-
- chunksTotal - Variable in class hex.DMatrix.MatrixMulStats
-
- ChunkSummary - Class in water.util
-
Simple summary of how many chunks of each type are in a Frame
- ChunkSummary() - Constructor for class water.util.ChunkSummary
-
- chunkSummary(Frame) - Static method in class water.util.FrameUtils
-
Compute a chunk summary (how many chunks of each type, relative size, total size)
- chunkTypes - Variable in class hex.DMatrix.MatrixMulStats
-
- ci(SB) - Method in class water.util.SB
-
- cidx() - Method in class water.fvec.Chunk
-
- class_sampling_factors - Variable in class water.api.SupervisedModelParametersSchema
-
Desired over/under-sampling ratios per class (lexicographic order).
- classErr() - Method in class hex.ConfusionMatrix
-
- classErr(int) - Method in class hex.ConfusionMatrix
-
- classErrCount(int) - Method in class hex.ConfusionMatrix
-
- classname - Variable in class water.api.DocsBase
-
- className() - Method in class water.Icer
-
- className() - Method in class water.Value
-
Class name of the embedded POJO, without needing an actual POJO.
- classNames() - Method in class hex.Model.Output
-
The names of the levels for an enum (categorical) response column.
- clean() - Method in class water.rapids.Env
-
- clear() - Method in class jsr166y.ConcurrentLinkedDeque
-
Removes all of the elements from this deque.
- clear(int) - Method in class water.util.IcedBitSet
-
- clear() - Method in class water.util.IcedHashMap
-
- clearBinsField() - Method in class water.api.FrameV2
-
- clearBinsField() - Method in class water.api.FrameV2.ColV2
-
- clearInitState() - Method in class hex.ModelBuilder
-
Clear whatever was done by init() so it can be run again.
- client - Variable in class water.H2O.OptArgs
-
-client, -client=true; Client-only; no work; no homing of Keys (but can cache)
- CLIENT_TIMEOUT - Static variable in class water.HeartBeatThread
-
- clone() - Method in interface water.Freezable
-
Make clone public, but without the annoying exception.
- clone() - Method in class water.H2O.H2OCountedCompleter
-
- clone() - Method in class water.Iced
-
Clone, without the annoying exception
- clone() - Method in class water.init.TimelineSnapshot.Event
-
- close() - Method in class water.AutoBuffer
-
- close(Futures) - Method in class water.fvec.AppendableVec
-
- close(int, Futures) - Method in class water.fvec.Chunk
-
After writing we must call close() to register the bulk changes.
- close(Futures) - Method in class water.fvec.NewChunk
-
- close(C1NChunk, int, Futures) - Method in class water.fvec.UploadFileVec
-
- close(Futures) - Method in class water.fvec.Vec.Writer
-
- close() - Method in class water.fvec.Vec.Writer
-
- close(Closeable...) - Static method in class water.util.FileUtils
-
Silently close given files.
- closeAll(AppendableVec[]) - Static method in class water.fvec.AppendableVec
-
- closeAll(AppendableVec[], Futures) - Static method in class water.fvec.AppendableVec
-
- closeLocal() - Method in class water.MRTask
-
Override to do any remote cleaning on the last remote instance of
this object, for disposing of node-local shared data structures.
- closeLocal() - Method in class water.rapids.ASTddply.ddplyPass1
-
- CLOUD - Static variable in class water.H2O
-
- CLOUD_DGRAM - Static variable in class water.init.NetworkInit
-
- cloud_healthy - Variable in class water.api.CloudV1
-
- CLOUD_MULTICAST_GROUP - Static variable in class water.H2O
-
- CLOUD_MULTICAST_IF - Static variable in class water.H2O
-
- CLOUD_MULTICAST_PORT - Static variable in class water.H2O
-
- CLOUD_MULTICAST_SOCKET - Static variable in class water.H2O
-
- cloud_name - Variable in class water.api.CloudV1
-
- cloud_size - Variable in class water.api.CloudV1
-
- cloud_uptime_millis - Variable in class water.api.CloudV1
-
- CloudV1 - Class in water.api
-
- CloudV1() - Constructor for class water.api.CloudV1
-
- CloudV1.NodeV1 - Class in water.api
-
- CloudV1.NodeV1() - Constructor for class water.api.CloudV1.NodeV1
-
- cm(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- cm() - Method in class hex.AUCData
-
- CM() - Method in class hex.AUCData
-
- cm - Variable in class water.api.ModelMetricsBase
-
- colFormats - Variable in class water.api.TwoDimTableV1
-
- colHeaders - Variable in class water.api.TwoDimTableV1
-
- collective - Variable in class water.init.NetworkTest
-
- colname - Variable in class water.Quantiles
-
- cols - Variable in class hex.CreateFrame
-
- colTypes - Variable in class water.api.TwoDimTableV1
-
- column - Variable in class water.api.QuantilesV1
-
- column_name - Variable in class water.api.FrameV2.ColSpecifierV2
-
- columnDataTypes - Variable in class water.parser.ParseSetupV2
-
- columnNames - Variable in class water.parser.ParseSetupV2
-
- columns - Variable in class water.api.FrameV2
-
- comment(String...) - Method in class water.util.MarkdownBuilder
-
- compareAndSetForkJoinTaskTag(short, short) - Method in class jsr166y.ForkJoinTask
-
Atomically conditionally sets the tag value for this task.
- compareAndSetPendingCount(int, int) - Method in class jsr166y.CountedCompleter
-
Sets (atomically) the pending count to the given count only if
it currently holds the given expected value.
- compareTo(Object) - Method in class water.H2ONode
-
- compareTo(TimelineSnapshot.Event) - Method in class water.init.TimelineSnapshot.Event
-
Used to determine ordering of events not bound by any dependency.
- compareTo(Object) - Method in class water.Key
-
Lexically ordered Key comparison, so Keys can be sorted.
- compareTo(KeySnapshot.KeyInfo) - Method in class water.KeySnapshot.KeyInfo
-
- compareTo(ValueString) - Method in class water.parser.ValueString
-
- compareTo(Delayed) - Method in class water.RPC
-
- compatible_models - Variable in class water.api.FrameV2
-
- compiledBy() - Method in class water.init.AbstractBuildVersion
-
- compiledBy() - Method in class water.init.BuildVersion
-
- compiledOn() - Method in class water.init.AbstractBuildVersion
-
- compiledOn() - Method in class water.init.BuildVersion
-
- complete(Void) - Method in class jsr166y.CountedCompleter
-
- complete(V) - Method in class jsr166y.ForkJoinTask
-
Completes this task, and if not already aborted or cancelled,
returning the given value as the result of subsequent
invocations of join
and related operations.
- completeExceptionally(Throwable) - Method in class jsr166y.ForkJoinTask
-
Completes this task abnormally, and if not already aborted or
cancelled, causes it to throw the given exception upon
join
and related operations.
- compress() - Method in class water.fvec.NewChunk
-
- compute(ConfusionMatrix[], float[], String[], AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- compute() - Method in class jsr166y.CountedCompleter
-
The main computation performed by this task.
- compute() - Method in class jsr166y.RecursiveAction
-
The main computation performed by this task.
- compute() - Method in class jsr166y.RecursiveTask
-
The main computation performed by this task.
- compute() - Method in class water.H2O.H2OCountedCompleter
-
Used by the F/J framework internally to do work.
- compute2() - Method in class hex.DMatrix.MatrixMulTsk
-
- compute2() - Method in class hex.FrameSplitter
-
- compute2() - Method in class water.api.Handler
-
- compute2() - Method in class water.Atomic
-
- compute2() - Method in class water.DTask.DKeyTask
-
- compute2() - Method in class water.fvec.FrameCreator
-
- compute2() - Method in class water.fvec.RebalanceDataSet
-
- compute2() - Method in class water.H2O.H2OCallback
-
- compute2() - Method in class water.H2O.H2OCountedCompleter
-
Override to specify actual work to do
- compute2() - Method in class water.init.NetworkTest.NetworkTester
-
- compute2() - Method in class water.MRTask
-
Called from FJ threads to do local work.
- compute2() - Method in class water.parser.ParseDataset.ParserFJTask
-
- compute2() - Method in class water.TaskGetKey
-
- compute2() - Method in class water.TaskPutKey
-
- compute2() - Method in class water.util.MRUtils.ParallelTasks
-
- ConcurrentLinkedDeque<E> - Class in jsr166y
-
An unbounded concurrent deque based on linked nodes.
- ConcurrentLinkedDeque() - Constructor for class jsr166y.ConcurrentLinkedDeque
-
Constructs an empty deque.
- ConcurrentLinkedDeque(Collection<? extends E>) - Constructor for class jsr166y.ConcurrentLinkedDeque
-
Constructs a deque initially containing the elements of
the given collection, added in traversal order of the
collection's iterator.
- COND_QUOTE - Static variable in class water.parser.Parser
-
- COND_QUOTED_NUMBER_END - Static variable in class water.parser.Parser
-
- COND_QUOTED_TOKEN - Static variable in class water.parser.Parser
-
- CONF - Static variable in class water.persist.PersistHdfs
-
Globally shared HDFS configuration.
- confusion_matrices - Variable in class hex.AUCData
-
- confusion_matrices - Variable in class water.api.AUCBase
-
- confusion_matrix - Variable in class water.api.ConfusionMatrixBase
-
- confusion_matrix_for_criteria - Variable in class water.api.AUCBase
-
- ConfusionMatrix - Class in hex
-
- ConfusionMatrix(long[][], String[]) - Constructor for class hex.ConfusionMatrix
-
Constructor for Confusion Matrix
- ConfusionMatrixBase<I extends ConfusionMatrix,S extends ConfusionMatrixBase> - Class in water.api
-
- ConfusionMatrixBase() - Constructor for class water.api.ConfusionMatrixBase
-
- ConfusionMatrixV3 - Class in water.api
-
- ConfusionMatrixV3() - Constructor for class water.api.ConfusionMatrixV3
-
- consensus - Variable in class water.api.CloudV1
-
- consType(Schema, Class, String) - Static method in class water.api.SchemaMetadata.FieldMetadata
-
For a given Class generate a client-friendly type name (e.g., int[][] or Frame).
- consValue(Object) - Static method in class water.api.SchemaMetadata.FieldMetadata
-
- contains(Object) - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns true
if this deque contains at least one
element e
such that o.equals(e)
.
- contains(Object) - Method in class jsr166y.LinkedTransferQueue
-
Returns true
if this queue contains the specified element.
- contains(String[], String) - Static method in class water.util.ArrayUtils
-
- contains(int[], int) - Static method in class water.util.ArrayUtils
-
- contains(int) - Method in class water.util.IcedBitSet
-
- containsKey(Key) - Static method in class water.H2O
-
- containsKey(Object) - Method in class water.util.IcedHashMap
-
- containsValue(Object) - Method in class water.util.IcedHashMap
-
- convertEnum2Str(ValueString[]) - Method in class water.fvec.NewChunk
-
- copyOver(T) - Method in class water.DTask
-
- copyOver(Vec.CollectDomain) - Method in class water.fvec.Vec.CollectDomain
-
- copyOver(T, T) - Method in class water.Icer
-
- copyProperties(Object, Object, PojoUtils.FieldNaming) - Static method in class water.util.PojoUtils
-
Copy properties "of the same name" from one POJO to the other.
- copyProperties(Object, Object, PojoUtils.FieldNaming, String[]) - Static method in class water.util.PojoUtils
-
Copy properties "of the same name" from one POJO to the other.
- copyRawBits(int) - Method in class water.AutoBuffer
-
Copy raw bits from the (direct) buffer out.
- copyStream(InputStream, OutputStream) - Static method in class water.init.NodePersistentStorage
-
- correctProbabilities(float[], float[], float[]) - Static method in class water.util.ModelUtils
-
Correct a given list of class probabilities produced as a prediction by a model back to prior class distribution
- count - Variable in class water.api.ProfilerNodeV2.ProfilerNodeEntryV2
-
- CountedCompleter - Class in jsr166y
-
A resultless
ForkJoinTask
with a completion action
performed when triggered and there are no remaining pending
actions.
- CountedCompleter(CountedCompleter, int) - Constructor for class jsr166y.CountedCompleter
-
Creates a new CountedCompleter with the given completer
and initial pending count.
- CountedCompleter(CountedCompleter) - Constructor for class jsr166y.CountedCompleter
-
Creates a new CountedCompleter with the given completer
and an initial pending count of zero.
- CountedCompleter() - Constructor for class jsr166y.CountedCompleter
-
Creates a new CountedCompleter with no completer
and an initial pending count of zero.
- counts - Variable in class water.util.ProfileCollectorTask.NodeProfile
-
- cpu_ticks - Variable in class water.api.WaterMeterCpuTicksV1
-
- cpu_ticks - Variable in class water.util.WaterMeterCpuTicks
-
- cpus_allowed - Variable in class water.api.CloudV1.NodeV1
-
- createAndFillImpl() - Method in class water.api.Schema
-
Convenience helper which creates and fill an impl.
- CreateFrame - Class in hex
-
Create a Frame from scratch
If randomize = true, then the frame is filled with Random values.
- CreateFrame(Key<CreateFrame>, String) - Constructor for class hex.CreateFrame
-
- CreateFrame() - Constructor for class hex.CreateFrame
-
- CreateFrameHandler - Class in water.api
-
- CreateFrameHandler() - Constructor for class water.api.CreateFrameHandler
-
- createIfApiAnnotation(Schema, Field) - Static method in class water.api.SchemaMetadata.FieldMetadata
-
Factory method to create a new FieldMetadata instance if the Field has an @API annotation.
- createImpl() - Method in class hex.schemas.ModelBuilderSchema
-
Create the corresponding impl object, as well as its parameters object.
- createImpl() - Method in class water.api.ConfusionMatrixBase
-
- createImpl() - Method in class water.api.JobV2
-
- createImpl() - Method in class water.api.ModelMetricsBase
-
- createImpl() - Method in class water.api.ModelParameterSchemaV2
-
- createImpl() - Method in class water.api.ModelParametersSchema.ValidationMessageBase
-
- createImpl() - Method in class water.api.Schema
-
Create an implementation object and any child objects but DO NOT fill them.
- createImpl() - Method in class water.api.SchemaMetadataBase
-
- createImpl() - Method in class water.api.WaterMeterCpuTicksV1
-
- createModelBuilder(String) - Static method in class hex.ModelBuilder
-
Factory method to create a ModelBuilder instance of the correct class given the algo name.
- createOutputSchema() - Method in class water.api.ModelSchema
-
Factory method to create the model-specific output schema.
- createParametersSchema() - Method in class hex.schemas.ModelBuilderSchema
-
Factory method to create the model-specific parameters schema.
- createParametersSchema() - Method in class water.api.ModelSchema
-
Factory method to create the model-specific parameters schema.
- createSchemaMetadata(String) - Static method in class water.api.SchemaMetadata
-
- crushBytes() - Method in class water.fvec.Chunk
-
Used by a ParseExceptionTest to break the Chunk invariants and trigger an
NPE.
- current() - Static method in class jsr166y.ThreadLocalRandom
-
Returns the current thread's ThreadLocalRandom
.
- data() - Method in class hex.AUC
-
- data - Variable in class water.api.FrameV2.ColV2
-
- data - Variable in class water.NanoHTTPD.Response
-
Data of the response, may be null.
- data - Variable in class water.parser.ParseSetupV2
-
- dataHi() - Method in class water.init.TimelineSnapshot.Event
-
- dataLo() - Method in class water.init.TimelineSnapshot.Event
-
- debug(Object...) - Static method in class water.util.Log
-
- decodeFile(File) - Static method in class water.persist.PersistNFS
-
Key from file
- deepClone(double[][]) - Static method in class water.util.ArrayUtils
-
- deepSlice(Object, Object) - Method in class water.fvec.Frame
-
In support of R, a generic Deep Copy and Slice.
- DEFAULT_ICE_ROOT() - Static method in class water.H2O
-
- default_pctiles - Variable in class water.api.FrameV2
-
- DEFAULT_THRESHOLDS - Static variable in class water.util.ModelUtils
-
List of default thresholds
- default_value - Variable in class water.api.ModelParameterSchemaV2
-
- defaultColName(int) - Static method in class water.fvec.Frame
-
Default column name maker
- defaultDropConsCols() - Method in class hex.Model.Parameters
-
- defaultDropNA20Cols() - Method in class hex.Model.Parameters
-
- defaultForkJoinWorkerThreadFactory - Static variable in class jsr166y.ForkJoinPool
-
Creates a new ForkJoinWorkerThread.
- delete(int, NodePersistentStorageV1) - Method in class water.api.NodePersistentStorageHandler
-
- delete(String, String) - Method in class water.init.NodePersistentStorage
-
- delete(Key) - Static method in class water.Lockable
-
Write-lock key and delete; blocking.
- delete() - Method in class water.Lockable
-
Write-lock 'this' and delete; blocking.
- delete(Key, Futures) - Method in class water.Lockable
-
Write-lock 'this' and delete.
- delete(Value) - Method in class water.persist.Persist
-
Reclaim space from a previously stored Value
- delete(Value) - Method in class water.persist.PersistHdfs
-
- delete(Value) - Method in class water.persist.PersistNFS
-
- delete(Value) - Method in class water.persist.PersistS3
-
- delete() - Method in class water.rapids.Raft
-
- delete_and_lock(Key) - Method in class water.Lockable
-
Write-lock this._key
by job_key
, and delete any prior mapping.
- depth - Variable in class water.api.ProfilerV2
-
- depth - Variable in class water.util.JProfile
-
- descendingIterator() - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns an iterator over the elements in this deque in reverse
sequential order.
- describe() - Method in class water.init.AbstractBuildVersion
-
- describe() - Method in class water.init.BuildVersion
-
- description - Variable in class water.api.JobV2
-
- DESERIAL_PRIORITY - Static variable in class water.H2O
-
- dest - Variable in class water.api.JobV2
-
- dest() - Method in class water.Job
-
Since _dest is public final, not sure why we have a getter but some
people like 'em.
- destination_key - Variable in class water.api.ModelParametersSchema
-
- dev_message - Variable in exception water.exceptions.H2OAbstractRuntimeException
-
- dev_msg - Variable in class water.api.H2OErrorV1
-
- DException - Class in water
-
A Distributed Exception - an exception originally thrown on one node
and passed to another.
- DException.DistributedException - Exception in water
-
Simple named exception class, inflated from a deserialized
DException
.
- DFLT_CHUNK_SIZE - Static variable in class water.fvec.FileVec
-
Default Chunk size in bytes, useful when breaking up large arrays into
"bite-sized" chunks.
- DFLT_LOG2_CHUNK_SIZE - Static variable in class water.fvec.FileVec
-
Log-2 of Chunk size.
- dfork(Vec...) - Method in class water.MRTask
-
Invokes the map/reduce computation over the given Frame.
- dfork(Frame) - Method in class water.MRTask
-
- dfork(int, Vec...) - Method in class water.MRTask
-
- dfork(int, Frame, boolean) - Method in class water.MRTask
-
- di(int) - Method in class water.util.SB
-
- die(String) - Static method in class water.H2O
-
- difference(int[], int[]) - Static method in class water.util.ArrayUtils
-
- difference(String[], String[]) - Static method in class water.util.ArrayUtils
-
- dinvoke(H2ONode) - Method in class water.DTask
-
Top-level remote execution hook.
- dinvoke(H2ONode) - Method in class water.MRTask
-
Called once on remote at top level, probably with a subset of the cloud.
- dinvoke(H2ONode) - Method in class water.TaskGetKey
-
- dinvoke(H2ONode) - Method in class water.TaskPutKey
-
- dist() - Method in class water.util.MRUtils.ClassDist
-
- div(float[], int) - Static method in class water.util.ArrayUtils
-
- div(float[], float) - Static method in class water.util.ArrayUtils
-
- div(double[], double) - Static method in class water.util.ArrayUtils
-
- div(double[][], long[]) - Static method in class water.util.ArrayUtils
-
- DKV - Class in water
-
A Distributed Key/Value Store.
- DKV() - Constructor for class water.DKV
-
- DMatrix - Class in hex
-
Created by tomasnykodym on 11/13/14.
- DMatrix() - Constructor for class hex.DMatrix
-
- DMatrix.MatrixMulStats - Class in hex
-
Info about matrix multiplication currently in progress.
- DMatrix.MatrixMulStats(long, Key) - Constructor for class hex.DMatrix.MatrixMulStats
-
- DMatrix.MatrixMulTsk - Class in hex
-
- DMatrix.MatrixMulTsk(H2O.H2OCountedCompleter, Key, Frame, Frame) - Constructor for class hex.DMatrix.MatrixMulTsk
-
- DMatrix.TransposeTsk - Class in hex
-
(MR)Task performing the matrix transpose.
- DMatrix.TransposeTsk(Frame) - Constructor for class hex.DMatrix.TransposeTsk
-
- do_classification - Variable in class water.api.SupervisedModelParametersSchema
-
- do_train(int, S) - Method in class water.api.ModelBuilderHandler
-
Create a model by launching a ModelBuilder algo.
- do_validate_parameters(int, S) - Method in class water.api.ModelBuilderHandler
-
- doAll(Vec...) - Method in class water.MRTask
-
Invokes the map/reduce computation over the given Vecs.
- doAll(int, Vec...) - Method in class water.MRTask
-
- doAll(Frame, boolean) - Method in class water.MRTask
-
Invokes the map/reduce computation over the given Frame.
- doAll(Frame) - Method in class water.MRTask
-
- doAll(int, Frame) - Method in class water.MRTask
-
- doAll(int, Frame, boolean) - Method in class water.MRTask
-
- doAll(Key...) - Method in class water.MRTask
-
- doAllNodes() - Method in class water.MRTask
-
- doc_method - Variable in class water.api.RouteBase
-
- DocGen<T extends DocGen> - Class in water.util
-
Auto-gen doc support, for JSON and REST API docs
- DocGen() - Constructor for class water.util.DocGen
-
- DocGen.HTML - Class in water.util
-
- DocGen.HTML() - Constructor for class water.util.DocGen.HTML
-
- DocsBase<I extends Iced,S extends DocsBase<I,S>> - Class in water.api
-
- DocsBase() - Constructor for class water.api.DocsBase
-
- DocsHandler - Class in water.api
-
- DocsHandler() - Constructor for class water.api.DocsHandler
-
- DocsV1 - Class in water.api
-
- DocsV1() - Constructor for class water.api.DocsV1
-
- doIt() - Method in class water.util.GetLogsFromNode
-
Do the work.
- doIt() - Method in class water.util.WaterMeterCpuTicks
-
- domain - Variable in class water.api.FrameV2.ColV2
-
- domain() - Method in class water.fvec.Vec.CollectDomain
-
Returns exact numeric domain of given vector computed by this task.
- domain() - Method in class water.fvec.Vec
-
Returns the enum toString mapping array, or null if not an Categorical column.
- domains - Variable in class water.api.ModelOutputSchema
-
- domains() - Method in class water.fvec.Frame
-
All the domains for enum columns; null for non-enum columns.
- domainUnion(String[], String[]) - Static method in class water.util.ArrayUtils
-
Clever union of String arrays.
- done() - Method in class water.Job
-
Marks job as finished and records job end time.
- doubles() - Method in class water.fvec.NewChunk
-
- DownloadDataHandler - Class in water.api
-
- DownloadDataHandler() - Constructor for class water.api.DownloadDataHandler
-
- DownloadDataV1 - Class in water.api
-
- DownloadDataV1() - Constructor for class water.api.DownloadDataV1
-
- DputIfMatch(Key, Value, Value, Futures) - Static method in class water.DKV
-
- DputIfMatch(Key, Value, Value, Futures, boolean) - Static method in class water.DKV
-
Update the mapping for Key key, from Value old to Value
val.
- drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class jsr166y.ForkJoinPool
-
Removes all available unexecuted submitted and forked tasks
from scheduling queues and adds them to the given collection,
without altering their execution status.
- drainTo(Collection<? super E>) - Method in class jsr166y.LinkedTransferQueue
-
- drainTo(Collection<? super E>, int) - Method in class jsr166y.LinkedTransferQueue
-
- dropped() - Method in class water.init.TimelineSnapshot.Event
-
- dropped(long[], int) - Static method in class water.TimeLine
-
- DTask<T extends DTask> - Class in water
-
- DTask() - Constructor for class water.DTask
-
- DTask(H2O.H2OCountedCompleter) - Constructor for class water.DTask
-
- DTask.DKeyTask<T extends DTask.DKeyTask,V extends Keyed> - Class in water
-
Task to be executed at the home node of the given key.
- DTask.DKeyTask(Key) - Constructor for class water.DTask.DKeyTask
-
- DTask.DKeyTask(H2O.H2OCountedCompleter, Key) - Constructor for class water.DTask.DKeyTask
-
- DTask.RemoveCall - Class in water
-
Task to cleanly remove value from the K/V (call it's remove()
destructor) without the need to fetch it locally first.
- DTask.RemoveCall(H2O.H2OCountedCompleter, Key) - Constructor for class water.DTask.RemoveCall
-
- duration_in_ms - Variable in class water.api.ModelMetricsBase
-
- echo(int, LogAndEchoV1) - Method in class water.api.LogAndEchoHandler
-
- element() - Method in class jsr166y.ConcurrentLinkedDeque
-
- embeddedH2OConfig - Static variable in class water.H2O
-
- emptyDouble - Static variable in class water.util.TwoDimTable
-
- enter() - Static method in class water.Scope
-
Enter a new Scope
- entries - Variable in class water.api.AboutHandler.AboutV3
-
- entries - Variable in class water.api.ProfilerNodeV2
-
- entrySet() - Method in class water.util.IcedHashMap
-
- ENUM - Static variable in class water.fvec.AppendableVec
-
- enumCnt() - Method in class water.fvec.NewChunk
-
- EnumUtils - Class in water.util
-
Utilities to deal with Java enums.
- EnumUtils() - Constructor for class water.util.EnumUtils
-
- EnumWrappedVec - Class in water.fvec
-
A vector transforming values of given vector according to given domain
mapping - currently only used to transform Enum columns but in theory would
work for any dense-packed Int column.
- EnumWrappedVec(Key, long[], String[], Key) - Constructor for class water.fvec.EnumWrappedVec
-
Main constructor: convert from one enum to another
- Env - Class in water.rapids
-
Execute a set of instructions in the context of an H2O cloud.
- EOL - Static variable in class water.parser.Parser
-
- equals(Object) - Method in class water.fvec.Vec
-
True if two Vecs are equal.
- equals(Object) - Method in class water.fvec.Vec.VectorGroup
-
True if two VectorGroups are equal
- equals(Object) - Method in class water.H2ONode
-
- equals(Object) - Method in class water.init.TimelineSnapshot.Event
-
- equals(Object) - Method in class water.Key
-
- equals(Object) - Method in class water.parser.ValueString
-
- equals(Object) - Method in class water.rapids.ASTddply.Group
-
- equals(Object) - Method in class water.util.IcedHashMap
-
- equals(Object) - Method in class water.util.IcedInt
-
- equalsWithinOneSmallUlp(float, float) - Static method in class water.util.MathUtils
-
Compare two numbers to see if they are within one ulp of the smaller decade.
- equalsWithinOneSmallUlp(double, double) - Static method in class water.util.MathUtils
-
- err(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- err() - Method in class hex.AUCData
-
- err() - Method in class hex.ConfusionMatrix
-
- err(Object...) - Static method in class water.util.Log
-
- errCount() - Method in class hex.ConfusionMatrix
-
- error(String, String) - Method in class hex.ModelBuilder
-
- error_count() - Method in class hex.ModelBuilder
-
- error_for_criteria - Variable in class water.api.AUCBase
-
- errorr - Variable in class hex.AUCData
-
- errorr - Variable in class water.api.AUCBase
-
- escape(String) - Method in class water.util.DocGen
-
- escape(String) - Method in class water.util.DocGen.HTML
-
- escapeJava(String) - Static method in class water.util.SB
-
Escape all " and \ characters to provide a proper Java-like string
Does not escape unicode characters.
- event() - Method in class water.api.TimelineV2.EventV2
-
- event() - Method in class water.api.TimelineV2.NetworkEvent
-
- events - Variable in class water.api.TimelineV2
-
- exception - Variable in class water.api.JobV2
-
- exception_msg - Variable in class water.api.H2OErrorV1
-
- exception_type - Variable in class water.api.H2OErrorV1
-
- exec() - Method in class jsr166y.CountedCompleter
-
Implements execution conventions for CountedCompleters
- exec() - Method in class jsr166y.ForkJoinTask
-
Immediately performs the base action of this task and returns
true if, upon return from this method, this task is guaranteed
to have completed normally.
- exec() - Method in class jsr166y.RecursiveAction
-
Implements execution conventions for RecursiveActions.
- exec() - Method in class jsr166y.RecursiveTask
-
Implements execution conventions for RecursiveTask.
- Exec - Class in water.rapids
-
Exec is an interpreter of abstract syntax trees.
- Exec(String, Env) - Constructor for class water.rapids.Exec
-
- exec(String) - Static method in class water.rapids.Exec
-
- execImpl() - Method in class hex.CreateFrame
-
- execImpl() - Method in class water.init.NetworkTest
-
- execImpl(boolean) - Method in class water.util.JProfile
-
- execImpl() - Method in class water.util.JStack
-
- execute(ForkJoinTask<?>) - Method in class jsr166y.ForkJoinPool
-
Arranges for (asynchronous) execution of the given task.
- execute(Runnable) - Method in class jsr166y.ForkJoinPool
-
- exit(int) - Static method in class water.H2O
-
Notify embedding software instance H2O wants to exit.
- exit(int) - Method in class water.init.AbstractEmbeddedH2OConfig
-
Tell the embedding software that H2O wants the process to exit.
- exit(Key...) - Static method in class water.Scope
-
Exit the inner-most Scope, remove all Keys created since the matching
enter call except for the listed Keys.
- EXPECT_COND_LF - Static variable in class water.parser.Parser
-
- exponent() - Method in class water.fvec.NewChunk
-
- extractChunkPart(Chunk, Chunk, int, int, Futures) - Static method in class water.ChunkSplitter
-
Extract portion of given chunk into given output chunk.
- extractFrame(int, int) - Method in class water.fvec.Frame
-
Split this Frame; return a subframe created from the given column interval, and
remove those columns from this Frame.
- extractVersion(String) - Static method in class water.api.Schema
-
Extract the version number from the schema class name.
- F0point5 - Variable in class hex.AUCData
-
- F0point5(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- F0point5() - Method in class hex.AUCData
-
- F0point5() - Method in class hex.ConfusionMatrix
-
Returns the F-measure which combines precision and recall and weights precision higher than recall.
- F0point5 - Variable in class water.api.AUCBase
-
- F0point5_for_criteria - Variable in class water.api.AUCBase
-
- F1 - Variable in class hex.AUCData
-
- F1(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- F1() - Method in class hex.AUCData
-
- F1() - Method in class hex.ConfusionMatrix
-
Returns the F-measure which combines precision and recall.
- F1 - Variable in class water.api.AUCBase
-
- F1_for_criteria - Variable in class water.api.AUCBase
-
- F2 - Variable in class hex.AUCData
-
- F2(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- F2() - Method in class hex.AUCData
-
- F2() - Method in class hex.ConfusionMatrix
-
Returns the F-measure which combines precision and recall and weights recall higher than precision.
- F2 - Variable in class water.api.AUCBase
-
- F2_for_criteria - Variable in class water.api.AUCBase
-
- factor(long) - Method in class water.fvec.Vec
-
Returns the i
th factor for this enum column.
- factors - Variable in class hex.CreateFrame
-
- fail() - Static method in class water.H2O
-
- fail(String) - Static method in class water.H2O
-
- fail(String, Throwable) - Static method in class water.H2O
-
- fatal(Object...) - Static method in class water.util.Log
-
- fetch(int, DownloadDataV1) - Method in class water.api.DownloadDataHandler
-
- fetch(int, JobsV2) - Method in class water.api.JobsHandler
-
- fetch(int, JStackV2) - Method in class water.api.JStackHandler
-
- fetch(int, LogsV3) - Method in class water.api.LogsHandler
-
- fetch(int, ProfilerV2) - Method in class water.api.ProfilerHandler
-
- fetch(int, TimelineV2) - Method in class water.api.TimelineHandler
-
- fetch(int, WaterMeterCpuTicksV1) - Method in class water.api.WaterMeterCpuTicksHandler
-
- FETCH_ACK_PRIORITY - Static variable in class water.H2O
-
- fetchAll(Class<T>) - Method in class water.KeySnapshot
-
- fetchAll(Class<T>, boolean) - Method in class water.KeySnapshot
-
- fetchAll(Class<T>, boolean, int, int) - Method in class water.KeySnapshot
-
- fetchFlatfile() - Method in class water.init.AbstractEmbeddedH2OConfig
-
If configProvidesFlatfile, get it.
- fetchRoute(int, DocsV1) - Method in class water.api.DocsHandler
-
- fetchSchemaMetadata(int, DocsV1) - Method in class water.api.DocsHandler
-
- fetchSchemaMetadataByClass(int, DocsV1) - Method in class water.api.DocsHandler
-
Deprecated.
- field_name - Variable in class water.api.ModelParametersSchema.ValidationMessageBase
-
- FieldMetadataV1 - Class in water.api
-
- FieldMetadataV1() - Constructor for class water.api.FieldMetadataV1
-
- fields() - Method in class water.api.ModelParametersSchema
-
- fields - Variable in class water.api.SchemaMetadata
-
- fields - Variable in class water.api.SchemaMetadataBase
-
- FILE - Static variable in class water.persist.Persist.Schemes
-
- FileIntegrityChecker - Class in water.util
-
- FileIntegrityChecker(File) - Constructor for class water.util.FileIntegrityChecker
-
- filename - Variable in class water.api.LogsV3
-
- FileUtils - Class in water.util
-
File utilities.
- FileUtils() - Constructor for class water.util.FileUtils
-
- FileVec - Class in water.fvec
-
- FileVec(Key, long, byte) - Constructor for class water.fvec.FileVec
-
- FileVec(Key, long, byte, int) - Constructor for class water.fvec.FileVec
-
- fill(int, Chunk[], long[]) - Method in class water.rapids.ASTddply.Group
-
- fill(byte[], int, int, int) - Method in class water.util.IcedBitSet
-
- fillFromImpl(B) - Method in class hex.schemas.ModelBuilderSchema
-
- fillFromImpl(I) - Method in class water.api.ConfusionMatrixBase
-
- fillFromImpl(Frame) - Method in class water.api.FrameV2
-
- fillFromImpl(Job) - Method in class water.api.JobV2
-
- fillFromImpl(Key) - Method in class water.api.KeySchema
-
- fillFromImpl(ModelMetrics) - Method in class water.api.ModelMetricsBase
-
- fillFromImpl(O) - Method in class water.api.ModelOutputSchema
-
- fillFromImpl(Iced) - Method in class water.api.ModelParameterSchemaV2
-
- fillFromImpl(P) - Method in class water.api.ModelParametersSchema
-
- fillFromImpl(ModelBuilder.ValidationMessage) - Method in class water.api.ModelParametersSchema.ValidationMessageBase
-
- fillFromImpl(M) - Method in class water.api.ModelSchema
-
- fillFromImpl(Quantiles) - Method in class water.api.QuantilesV1
-
- fillFromImpl(Route) - Method in class water.api.RouteBase
-
- fillFromImpl(I) - Method in class water.api.Schema
-
Version and Schema-specific filling from the implementation object.
- fillFromImpl(SchemaMetadata) - Method in class water.api.SchemaMetadataBase
-
- fillFromImpl(P) - Method in class water.api.SupervisedModelParametersSchema
-
- fillFromImpl(TimelineHandler.Timeline) - Method in class water.api.TimelineV2
-
- fillFromImpl(WaterMeterCpuTicks) - Method in class water.api.WaterMeterCpuTicksV1
-
- fillFromParms(Properties) - Method in class hex.schemas.ModelBuilderSchema
-
- fillFromParms(Properties) - Method in class water.api.Schema
-
- fillImpl(B) - Method in class hex.schemas.ModelBuilderSchema
-
- fillImpl(ModelMetrics) - Method in class water.api.ModelMetricsBase
-
- fillImpl(P) - Method in class water.api.ModelParametersSchema
-
- fillImpl(Quantiles) - Method in class water.api.QuantilesV1
-
- fillImpl(I) - Method in class water.api.Schema
-
Fill an impl object and any children from this schema and its children.
- fillImpl(I) - Method in class water.api.SchemaMetadataBase
-
- fillImpl(P) - Method in class water.api.SupervisedModelParametersSchema
-
- filter(KeySnapshot.KVFilter) - Method in class water.KeySnapshot
-
Filter the snapshot providing custom filter.
- filter(KeySnapshot.KeyInfo) - Method in class water.KeySnapshot.KVFilter
-
- finalizeRegistration() - Static method in class water.H2O
-
Start the web service; disallow future URL registration.
- find(String) - Method in class water.fvec.Frame
-
Finds the column index with a matching name, or -1 if missing
- find(Vec) - Method in class water.fvec.Frame
-
Finds the matching column index, or -1 if missing
- find(String[]) - Method in class water.fvec.Frame
-
- find(T[], T) - Static method in class water.util.ArrayUtils
-
- findActualClassParameter(Class, int) - Static method in class water.util.ReflectionUtils
-
Reflection helper which returns the actual class for a type parameter, even if itself is parameterized.
- findInetAddressForSelf() - Static method in class water.init.NetworkInit
-
- findMethodOutputClass(Method) - Static method in class water.util.ReflectionUtils
-
Reflection helper which returns the actual class for a method's parameter.
- findMethodParameterClass(Method, int) - Static method in class water.util.ReflectionUtils
-
Reflection helper which returns the actual class for a method's parameter.
- finishUp(Vec, double[], int, boolean) - Method in class water.Quantiles
-
- fitsIntoInt(double) - Static method in class water.util.PrettyPrint
-
- fixedLength(String, int) - Static method in class water.util.Log
-
- fjqueue - Variable in class water.api.CloudV1.NodeV1
-
- fjthrds - Variable in class water.api.CloudV1.NodeV1
-
- flatfile - Variable in class water.H2O.OptArgs
-
-flatfile=flatfile; Specify a list of cluster IP addresses
- flipForReading() - Method in class water.AutoBuffer
-
- forceTermination() - Method in class jsr166y.Phaser
-
Forces this phaser to enter termination state.
- fork() - Method in class jsr166y.ForkJoinTask
-
Arranges to asynchronously execute this task.
- fork(Key) - Method in class water.Atomic
-
- ForkJoinPool - Class in jsr166y
-
- ForkJoinPool() - Constructor for class jsr166y.ForkJoinPool
-
Creates a
ForkJoinPool
with parallelism equal to
Runtime.availableProcessors()
, using the
default thread factory,
no UncaughtExceptionHandler, and non-async LIFO processing mode.
- ForkJoinPool(int) - Constructor for class jsr166y.ForkJoinPool
-
Creates a
ForkJoinPool
with the indicated parallelism
level, the
default thread factory,
no UncaughtExceptionHandler, and non-async LIFO processing mode.
- ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class jsr166y.ForkJoinPool
-
Creates a ForkJoinPool
with the given parameters.
- ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in jsr166y
-
- ForkJoinPool.ManagedBlocker - Interface in jsr166y
-
Interface for extending managed parallelism for tasks running
in
ForkJoinPool
s.
- ForkJoinTask<V> - Class in jsr166y
-
Abstract base class for tasks that run within a
ForkJoinPool
.
- ForkJoinTask() - Constructor for class jsr166y.ForkJoinTask
-
- ForkJoinWorkerThread - Class in jsr166y
-
- ForkJoinWorkerThread(ForkJoinPool) - Constructor for class jsr166y.ForkJoinWorkerThread
-
Creates a ForkJoinWorkerThread operating in the given pool.
- forkParseDataset(Key, Key[], ParseSetup, boolean) - Static method in class water.parser.ParseDataset
-
- formatPct(double) - Static method in class water.util.PrettyPrint
-
- forStrptimePattern(String) - Static method in class water.parser.ParseTime
-
Factory to create a formatter from a strptime pattern string.
- frame() - Method in class hex.ModelMetrics
-
- frame - Variable in class water.api.ModelMetricsBase
-
- Frame - Class in water.fvec
-
A collection of named
Vec
s, essentially an R-like Distributed Data Frame.
- Frame(Vec...) - Constructor for class water.fvec.Frame
-
Creates an internal frame composed of the given Vecs and default names.
- Frame(String[], Vec[]) - Constructor for class water.fvec.Frame
-
Creates an internal frame composed of the given Vecs and names.
- Frame(Key) - Constructor for class water.fvec.Frame
-
Creates an empty frame with given key.
- Frame(Key, Vec[], boolean) - Constructor for class water.fvec.Frame
-
Special constructor for data with unnamed columns (e.g.
- Frame(Key, String[], Vec[]) - Constructor for class water.fvec.Frame
-
Creates a frame with given key, names and vectors.
- Frame(Frame) - Constructor for class water.fvec.Frame
-
Deep copy of Vecs and Keys and Names (but not data!) to a new random Key.
- FRAME - Static variable in class water.TypeMap
-
- Frame.VecSpecifier - Class in water.fvec
-
Pair of (column name, Frame key).
- Frame.VecSpecifier() - Constructor for class water.fvec.Frame.VecSpecifier
-
- frame_checksum - Variable in class water.api.ModelMetricsBase
-
- FrameCreator - Class in water.fvec
-
Helper to make up a Frame from scratch, with random content
- FrameCreator(CreateFrame, Key) - Constructor for class water.fvec.FrameCreator
-
- FrameCreator.MissingInserter - Class in water.fvec
-
- FrameCreator.MissingInserter(long, double) - Constructor for class water.fvec.FrameCreator.MissingInserter
-
- FrameCreator.MissingInserter(H2O.H2OCountedCompleter, long, double) - Constructor for class water.fvec.FrameCreator.MissingInserter
-
- FrameSplitter - Class in hex
-
Frame splitter function to divide given frame into
multiple partitions based on given ratios.
- FrameSplitter(Frame, float[]) - Constructor for class hex.FrameSplitter
-
- FrameSplitter(Frame, float[], Key[], Key) - Constructor for class hex.FrameSplitter
-
- FrameUtils - Class in water.util
-
- FrameUtils() - Constructor for class water.util.FrameUtils
-
- FrameUtils.MissingInserter - Class in water.util
-
Helper to insert missing values into a Frame
- FrameUtils.MissingInserter(long, double) - Constructor for class water.util.FrameUtils.MissingInserter
-
- FrameV2 - Class in water.api
-
- FrameV2() - Constructor for class water.api.FrameV2
-
- FrameV2.ColSpecifierV2 - Class in water.api
-
- FrameV2.ColSpecifierV2() - Constructor for class water.api.FrameV2.ColSpecifierV2
-
- FrameV2.ColSpecifierV2(String) - Constructor for class water.api.FrameV2.ColSpecifierV2
-
- FrameV2.ColV2 - Class in water.api
-
- FrameV2.ColV2() - Constructor for class water.api.FrameV2.ColV2
-
- free_disk - Variable in class water.api.CloudV1.NodeV1
-
- free_mem - Variable in class water.api.CloudV1.NodeV1
-
- freeMem() - Method in class water.Value
-
Invalidate byte[] cache.
- freePOJO() - Method in class water.Value
-
Invalidate POJO cache.
- Freezable<T extends Freezable> - Interface in water
-
Auto-serializer interface using a delegator pattern (the faster option is
to byte-code gen directly in all Iced classes, but this requires all Iced
classes go through a ClassLoader).
- from - Variable in class water.api.TimelineV2.NetworkEvent
-
- frozenType() - Method in interface water.Freezable
-
Returns a small dense integer, which is cluster-wide unique per-class.
- frozenType() - Method in class water.H2O.H2OCountedCompleter
-
- frozenType() - Method in class water.Iced
-
Returns a small dense integer, which is cluster-wide unique per-class.
- frozenType() - Method in class water.Icer
-
- frozenType() - Method in class water.util.IcedArrayList
-
- Futures - Class in water
-
A collection of Futures that can be extended, or blocked on the whole
collection.
- Futures() - Constructor for class water.Futures
-
- genDelegate(int, Class<T>) - Static method in class water.Weaver
-
- generateNumKeys(Key, int) - Static method in class water.util.FrameUtils
-
Generate given numbers of keys by suffixing key by given numbered suffix.
- generateNumKeys(Key, int, String) - Static method in class water.util.FrameUtils
-
- get() - Method in class jsr166y.ForkJoinTask
-
Waits if necessary for the computation to complete, and then
retrieves its result.
- get(long, TimeUnit) - Method in class jsr166y.ForkJoinTask
-
Waits if necessary for at most the given time for the computation
to complete, and then retrieves its result, if available.
- get(int, AboutHandler.AboutV3) - Method in class water.api.AboutHandler
-
- get() - Method in class water.AutoBuffer
-
- get(Class<T>) - Method in class water.AutoBuffer
-
- get(Key) - Static method in class water.DKV
-
Return the
Value
mapped to Key
key, or null if no
mapping.
- get(String) - Static method in class water.DKV
-
Return the
Value
mapped to Key formed by
key_name, or
null if no mapping.
- get(Key) - Static method in class water.H2O
-
- get() - Method in class water.Job
-
Blocks and get result of this job.
- get() - Method in class water.Key
-
Convenience function to fetch key contents from the DKV.
- get(String) - Static method in class water.rapids.ASTOp
-
- get() - Method in class water.RPC
-
- get(long, TimeUnit) - Method in class water.RPC
-
- get(int) - Method in class water.util.IcedBitSet
-
- get(Object) - Method in class water.util.IcedHashMap
-
- get(int, int) - Method in class water.util.TwoDimTable
-
Accessor for table cells
- get() - Method in class water.Value
-
The FAST path get-POJO as an
Iced
subclass - final method for
speed.
- get(Class<T>) - Method in class water.Value
-
The FAST path get-POJO as a
Freezable
- final method for speed.
- get1() - Method in class water.AutoBuffer
-
- get1U() - Method in class water.AutoBuffer
-
- get2() - Method in class water.AutoBuffer
-
- get2(byte[], int) - Static method in class water.util.UnsafeUtils
-
- get3() - Method in class water.AutoBuffer
-
- get4() - Method in class water.AutoBuffer
-
- get4(byte[], int) - Static method in class water.util.UnsafeUtils
-
- get4f() - Method in class water.AutoBuffer
-
- get4f(byte[], int) - Static method in class water.util.UnsafeUtils
-
- get8() - Method in class water.AutoBuffer
-
- get8(byte[], int) - Static method in class water.util.UnsafeUtils
-
- get8d() - Method in class water.AutoBuffer
-
- get8d(byte[], int) - Static method in class water.util.UnsafeUtils
-
- get_as_string(int, NodePersistentStorageV1) - Method in class water.api.NodePersistentStorageHandler
-
- get_as_string(String, String) - Method in class water.init.NodePersistentStorage
-
- get_ast() - Method in class water.rapids.Raft
-
- get_buf() - Method in class water.parser.ValueString
-
- get_espc() - Method in class water.fvec.Vec
-
Get the _espc long[].
- get_free_disk() - Method in class water.HeartBeat
-
- get_free_mem() - Method in class water.HeartBeat
-
- get_key() - Method in class water.rapids.Raft
-
- GET_KEY_PRIORITY - Static variable in class water.H2O
-
- get_length() - Method in class water.parser.ValueString
-
- get_max_disk() - Method in class water.HeartBeat
-
- get_max_mem() - Method in class water.HeartBeat
-
- get_mvalsz() - Method in class water.HeartBeat
-
- get_off() - Method in class water.parser.ValueString
-
- get_tot_mem() - Method in class water.HeartBeat
-
- get_tvalsz() - Method in class water.HeartBeat
-
- get_type() - Method in class water.fvec.Vec
-
Get the column type.
- getA(Class<T>) - Method in class water.AutoBuffer
-
- getA1() - Method in class water.AutoBuffer
-
- getA1(int) - Method in class water.AutoBuffer
-
- getA2() - Method in class water.AutoBuffer
-
- getA4() - Method in class water.AutoBuffer
-
- getA4f() - Method in class water.AutoBuffer
-
- getA8() - Method in class water.AutoBuffer
-
- getA8d() - Method in class water.AutoBuffer
-
- getAA(Class<T>) - Method in class water.AutoBuffer
-
- getAA1() - Method in class water.AutoBuffer
-
- getAA2() - Method in class water.AutoBuffer
-
- getAA4() - Method in class water.AutoBuffer
-
- getAA4f() - Method in class water.AutoBuffer
-
- getAA8() - Method in class water.AutoBuffer
-
- getAA8d() - Method in class water.AutoBuffer
-
- getAAA4() - Method in class water.AutoBuffer
-
- getAAA8() - Method in class water.AutoBuffer
-
- getAAASer(Class<T>) - Method in class water.AutoBuffer
-
- getAASer(Class<T>) - Method in class water.AutoBuffer
-
- getAAStr() - Method in class water.AutoBuffer
-
- getActiveThreadCount() - Method in class jsr166y.ForkJoinPool
-
Returns an estimate of the number of threads that are currently
stealing or executing tasks.
- getAEnum(Enum[]) - Method in class water.AutoBuffer
-
- getAlgo(Model) - Static method in class hex.ModelBuilder
-
Get the algo name for the given Model.
- getArrivedParties() - Method in class jsr166y.Phaser
-
Returns the number of registered parties that have arrived at
the current phase of this phaser.
- getASer(Class<T>) - Method in class water.AutoBuffer
-
- getAStr() - Method in class water.AutoBuffer
-
- getAsyncMode() - Method in class jsr166y.ForkJoinPool
-
Returns true
if this pool uses local first-in-first-out
scheduling mode for forked tasks that are never joined.
- getBytes() - Method in class water.fvec.Chunk
-
Short-cut to the embedded big-data memory.
- getBytes() - Method in class water.util.DocGen.HTML
-
- getClient() - Static method in class water.persist.PersistS3
-
Initialize the AWS S3 client
- getCLOUD() - Static method in class water.TimeLine
-
- getCloudSize() - Static method in class water.H2O
-
- getColDim() - Method in class water.util.TwoDimTable
-
Get row dimension
- getCompleter() - Method in class jsr166y.CountedCompleter
-
Returns the completer established in this task's constructor,
or null
if none.
- getCpuTicks() - Method in class water.util.LinuxProcFileReader
-
Array of ticks.
- getDelay(TimeUnit) - Method in class water.RPC
-
- getDependency(TimelineSnapshot.Event) - Method in class water.init.TimelineSnapshot
-
- getDeterRNG(long) - Static method in class water.util.RandomUtils
-
- getDException() - Method in class water.DTask
-
The _ex field as a RuntimeException or null.
- getEmbeddedH2OConfig() - Static method in class water.H2O
-
- getEnum(Enum[]) - Method in class water.AutoBuffer
-
- getException() - Method in class jsr166y.ForkJoinTask
-
Returns the exception thrown by the base computation, or a
CancellationException
if cancelled, or null
if
none or if the method has not yet completed.
- getFactory() - Method in class jsr166y.ForkJoinPool
-
Returns the factory used for constructing new workers.
- getFirst() - Method in class jsr166y.ConcurrentLinkedDeque
-
- getFirstBytes() - Method in class water.fvec.ByteVec
-
Get an unspecified amount of initial bytes; typically a whole C1NChunk of
length Vec.DFLT_CHUNK_SIZE but no guarantees.
- getForkJoinTaskTag() - Method in class jsr166y.ForkJoinTask
-
Returns the tag for this task.
- getFreezable() - Method in class water.Value
-
The FAST path get-POJO as a
Freezable
- final method for speed.
- getFromDKV(Model, Frame) - Static method in class hex.ModelMetrics
-
- getGet(String) - Static method in class water.DKV
-
- getGet(Key) - Static method in class water.DKV
-
- getHandlerMethodInputSchema(Method) - Static method in class water.api.Handler
-
- getHandlerMethodOutputSchema(Method) - Static method in class water.api.Handler
-
- getHighestSupportedVersion() - Static method in class water.api.Schema
-
- getIce() - Static method in class water.persist.Persist
-
Get the current Persist flavor for user-mode swapping.
- getImplClass(Class<? extends Schema>) - Static method in class water.api.Schema
-
- getImplClass() - Method in class water.api.Schema
-
- getIpPortString() - Static method in class water.H2O
-
- getIpPortString() - Method in class water.H2ONode
-
- getKeyedClass(Class<? extends KeySchema>) - Static method in class water.api.KeySchema
-
- getKeyedClass() - Method in class water.api.KeySchema
-
- getKeyedClassType(Class<? extends KeySchema>) - Static method in class water.api.KeySchema
-
- getKeyedClassType() - Method in class water.api.KeySchema
-
- getLast() - Method in class jsr166y.ConcurrentLinkedDeque
-
- getLatestVersion() - Static method in class water.api.Schema
-
- getLogDir() - Static method in class water.util.Log
-
- getLogFileName() - Static method in class water.util.Log
-
- getLogPathFileNameStem() - Static method in class water.util.Log
-
- GetLogsFromNode - Class in water.util
-
Get zipped log directory data from a node.
- GetLogsFromNode() - Constructor for class water.util.GetLogsFromNode
-
- getModelBuilder(String) - Static method in class hex.ModelBuilder
-
Get the ModelBuilder class for the given algo name.
- getModelBuilderName(Class<? extends ModelBuilder>) - Static method in class hex.ModelBuilder
-
- getModelBuilders() - Static method in class hex.ModelBuilder
-
Get a Map of all algo names to their ModelBuilder classes.
- getModelCategory() - Method in class hex.Model.Output
-
- getModelCategory() - Method in class hex.SupervisedModel.SupervisedOutput
-
- getModelClass(String) - Static method in class hex.ModelBuilder
-
Get the Model class for the given algo name.
- getNames(Class<? extends Enum<?>>) - Static method in class water.util.EnumUtils
-
Return an array of Strings of all the enum levels.
- getNPS() - Static method in class water.H2O
-
- getParallelism() - Method in class jsr166y.ForkJoinPool
-
Returns the targeted parallelism level of this pool.
- getParent() - Method in class jsr166y.Phaser
-
Returns the parent of this phaser, or null
if none.
- getPendingCount() - Method in class jsr166y.CountedCompleter
-
Returns the current pending count.
- getPhase() - Method in class jsr166y.Phaser
-
Returns the current phase number.
- getPool() - Static method in class jsr166y.ForkJoinTask
-
Returns the pool hosting the current task execution, or null
if this task is executing outside of any ForkJoinPool.
- getPool() - Method in class jsr166y.ForkJoinWorkerThread
-
Returns the pool hosting this thread.
- getPoolIndex() - Method in class jsr166y.ForkJoinWorkerThread
-
Returns the index number of this thread in its pool.
- getPoolSize() - Method in class jsr166y.ForkJoinPool
-
Returns the number of worker threads that have started but not
yet terminated.
- getPrediction(float[], int) - Static method in class water.util.ModelUtils
-
- getPrediction(float[], double[]) - Static method in class water.util.ModelUtils
-
Utility function to get a best prediction from an array of class
prediction distribution.
- getPredictions(int, float[], double[]) - Static method in class water.util.ModelUtils
-
Create labels from per-class probabilities with pseudo-random tie-breaking, if needed.
- getProcessCpusAllowed() - Method in class water.util.LinuxProcFileReader
-
- getProcessID() - Method in class water.util.LinuxProcFileReader
-
- getProcessNumOpenFds() - Method in class water.util.LinuxProcFileReader
-
- getProcessRss() - Method in class water.util.LinuxProcFileReader
-
- getProcessTotalTicks() - Method in class water.util.LinuxProcFileReader
-
- getQueuedSubmissionCount() - Method in class jsr166y.ForkJoinPool
-
Returns an estimate of the number of tasks submitted to this
pool that have not yet begun executing.
- getQueuedTaskCount() - Method in class jsr166y.ForkJoinPool
-
Returns an estimate of the total number of tasks currently held
in queues by worker threads (but not including tasks submitted
to the pool that have not begun executing).
- getQueuedTaskCount() - Static method in class jsr166y.ForkJoinTask
-
Returns an estimate of the number of tasks that have been
forked by the current worker thread but not yet executed.
- getRawResult() - Method in class jsr166y.CountedCompleter
-
Always returns null
.
- getRawResult() - Method in class jsr166y.ForkJoinTask
-
Returns the result that would be returned by
ForkJoinTask.join()
, even
if this task completed abnormally, or
null
if this task
is not known to have been completed.
- getRawResult() - Method in class jsr166y.RecursiveAction
-
Always returns null
.
- getRawResult() - Method in class jsr166y.RecursiveTask
-
- getRegisteredParties() - Method in class jsr166y.Phaser
-
Returns the number of parties registered at this phaser.
- getResource2(String) - Static method in class water.init.JarHash
-
- getResult() - Method in class hex.FrameSplitter
-
Blocking call to obtain a result of computation.
- getResult() - Method in class water.fvec.RebalanceDataSet
-
- getResult() - Method in class water.H2O.H2OFuture
-
- getResult() - Method in class water.MRTask
-
Block for & get any final results from a dfork'd MRTask.
- getRNG(long...) - Static method in class water.util.RandomUtils
-
- getRoot() - Method in class jsr166y.Phaser
-
Returns the root ancestor of this phaser, which is the same as
this phaser if it has no parent.
- getRowDim() - Method in class water.util.TwoDimTable
-
Get row dimension
- getRunningThreadCount() - Method in class jsr166y.ForkJoinPool
-
Returns an estimate of the number of worker threads that are
not blocked waiting to join tasks or for other managed
synchronization.
- getSchemaVersion() - Method in class water.api.Schema
-
- getSer() - Method in class water.AutoBuffer
-
- getSer(Class<T>) - Method in class water.AutoBuffer
-
- getShutdownRequested() - Static method in class water.H2O
-
- getStealCount() - Method in class jsr166y.ForkJoinPool
-
Returns an estimate of the total number of tasks stolen from
one thread's work queue by another.
- getStr(int, int) - Method in class water.AutoBuffer
-
- getStr() - Method in class water.AutoBuffer
-
- getSurplusQueuedTaskCount() - Static method in class jsr166y.ForkJoinTask
-
Returns an estimate of how many more locally queued tasks are
held by the current worker thread than there are other worker
threads that might steal them.
- getSystemIdleTicks() - Method in class water.util.LinuxProcFileReader
-
- getSystemTotalTicks() - Method in class water.util.LinuxProcFileReader
-
- getTimezone() - Static method in class water.parser.ParseTime
-
- getTotalSpace() - Method in class water.persist.Persist
-
Total storage space, or -1 for unknown
- getUdp(int) - Static method in class water.UDP
-
- getUnarrivedParties() - Method in class jsr166y.Phaser
-
Returns the number of registered parties that have not yet
arrived at the current phase of this phaser.
- getUncaughtExceptionHandler() - Method in class jsr166y.ForkJoinPool
-
Returns the handler for internal worker threads that terminate
due to unrecoverable errors encountered while executing tasks.
- getUsableSpace() - Method in class water.persist.Persist
-
Usable storage space, or -1 for unknown
- getUsedRNGKind() - Static method in class water.util.RandomUtils
-
- getUsedRNGType() - Static method in class water.util.RandomUtils
-
- getVariables() - Method in class hex.VarImp
-
- getVecKey(Key) - Static method in class water.fvec.Vec
-
Get a Vec Key from Chunk Key, without loading the Chunk.
- getVecKey() - Method in class water.Key
-
- getWaitingConsumerCount() - Method in class jsr166y.LinkedTransferQueue
-
- getWaitingConsumerCount() - Method in interface jsr166y.TransferQueue
-
Returns an estimate of the number of consumers waiting to
receive elements via BlockingQueue.take()
or timed
poll
.
- getWovenFields(Class) - Static method in class water.Weaver
-
Get all woven fields in this class, including subclasses, up to the
normal
Iced
serialization classes, skipping static and transient
fields, and the required _ice_id field.
- getZ() - Method in class water.AutoBuffer
-
- gflops - Variable in class water.api.CloudV1.NodeV1
-
- Gini - Variable in class hex.AUCData
-
- Gini() - Method in class hex.AUCData
-
- Gini - Variable in class water.api.AUCBase
-
- globalKeysOfClass(Class) - Static method in class water.KeySnapshot
-
Return all the keys of the given class.
- globalKeysOfType(short) - Static method in class water.KeySnapshot
-
Return all the keys of the given hardcoded type.
- globalSnapshot() - Static method in class water.KeySnapshot
-
- globalSnapshot(long) - Static method in class water.KeySnapshot
-
Cache-enabled call to get global key snapshot.
- group() - Method in class water.fvec.Vec
-
Get the group this vector belongs to.
- GRP - Static variable in class water.Key
-
- guessSetup(byte[], boolean, int) - Static method in class water.parser.ParseSetup
-
- guessSetup(byte[], ParseSetup) - Static method in class water.parser.ParseSetup
-
- guessSetup(Key[], ParseSetup) - Static method in class water.parser.ParseSetup
-
- guessSetup(byte[], ParserType, byte, int, boolean, int, String[], String[][]) - Static method in class water.parser.ParseSetup
-
- guessSetup(int, ParseSetupV2) - Method in class water.parser.ParseSetupHandler
-
- GUI_PRIORITY - Static variable in class water.H2O
-
- h2o - Variable in class water.api.CloudV1.NodeV1
-
- H2O - Class in water
-
Start point for creating or joining an H2O
Cloud.
- H2O.FJWThr - Class in water
-
- H2O.H2OCallback<T extends H2O.H2OCountedCompleter> - Class in water
-
- H2O.H2OCallback() - Constructor for class water.H2O.H2OCallback
-
- H2O.H2OCallback(H2O.H2OCountedCompleter) - Constructor for class water.H2O.H2OCallback
-
- H2O.H2OCountedCompleter<T extends H2O.H2OCountedCompleter> - Class in water
-
- H2O.H2OCountedCompleter() - Constructor for class water.H2O.H2OCountedCompleter
-
- H2O.H2OCountedCompleter(H2O.H2OCountedCompleter) - Constructor for class water.H2O.H2OCountedCompleter
-
- H2O.H2OFuture<T> - Class in water
-
- H2O.H2OFuture() - Constructor for class water.H2O.H2OFuture
-
- H2O.OptArgs - Class in water
-
A class containing all of the arguments for H2O.
- H2O.OptArgs() - Constructor for class water.H2O.OptArgs
-
- H2O_PORT - Static variable in class water.H2O
-
- H2OAbstractRuntimeException - Exception in water.exceptions
-
RuntimeException which results in an http 400 error, and serves as a base class for other error types.
- H2OAbstractRuntimeException(String, String, IcedHashMap) - Constructor for exception water.exceptions.H2OAbstractRuntimeException
-
- H2OAbstractRuntimeException(String, String) - Constructor for exception water.exceptions.H2OAbstractRuntimeException
-
- H2OCC - Static variable in class water.TypeMap
-
- H2OClient - Class in water
-
A simple wrapper around H2O starter to launch H2O in client mode.
- H2OClient() - Constructor for class water.H2OClient
-
- H2OColumnNotFoundArgumentException - Exception in water.exceptions
-
Exception signalling that a Vec was not found.
- H2OColumnNotFoundArgumentException(String, Frame, String) - Constructor for exception water.exceptions.H2OColumnNotFoundArgumentException
-
- H2OColumnNotFoundArgumentException(String, String, String) - Constructor for exception water.exceptions.H2OColumnNotFoundArgumentException
-
- H2OColumnNotFoundArgumentException(Frame, String) - Constructor for exception water.exceptions.H2OColumnNotFoundArgumentException
-
- H2OColumnNotFoundArgumentException(String, String) - Constructor for exception water.exceptions.H2OColumnNotFoundArgumentException
-
- H2OEnumLevelNotFoundArgumentException - Exception in water.exceptions
-
Exception signalling that an enum (categorical) level was not found.
- H2OEnumLevelNotFoundArgumentException(String, String, String, String) - Constructor for exception water.exceptions.H2OEnumLevelNotFoundArgumentException
-
- H2OError - Class in water
-
Class which represents a back-end error which will be returned to the client.
- H2OError(String, String, String, int, IcedHashMap<String, Object>, Exception) - Constructor for class water.H2OError
-
- H2OError(long, String, String, String, int, IcedHashMap<String, Object>, Exception) - Constructor for class water.H2OError
-
- H2OError(Exception, String) - Constructor for class water.H2OError
-
- H2OErrorV1 - Class in water.api
-
Schema which represents a back-end error which will be returned to the client.
- H2OErrorV1() - Constructor for class water.api.H2OErrorV1
-
- H2OIllegalArgumentException - Exception in water.exceptions
-
- H2OIllegalArgumentException(String, String, Object) - Constructor for exception water.exceptions.H2OIllegalArgumentException
-
- H2OIllegalArgumentException(String, String, IcedHashMap) - Constructor for exception water.exceptions.H2OIllegalArgumentException
-
Raw-message constructor for use by subclasses.
- H2OIllegalArgumentException(String, String) - Constructor for exception water.exceptions.H2OIllegalArgumentException
-
Raw-message constructor for use by subclasses.
- H2OIllegalValueException - Exception in water.exceptions
-
Exception indicating that we found an illegal value which was not passed in as an argument.
- H2OIllegalValueException(String, String, Object) - Constructor for exception water.exceptions.H2OIllegalValueException
-
- H2OIllegalValueException(String, Object) - Constructor for exception water.exceptions.H2OIllegalValueException
-
- H2OKeyNotFoundArgumentException - Exception in water.exceptions
-
Exception signalling that a Key was not found.
- H2OKeyNotFoundArgumentException(String, String) - Constructor for exception water.exceptions.H2OKeyNotFoundArgumentException
-
- H2OKeyNotFoundArgumentException(String, Key) - Constructor for exception water.exceptions.H2OKeyNotFoundArgumentException
-
- H2OKeyNotFoundArgumentException(String) - Constructor for exception water.exceptions.H2OKeyNotFoundArgumentException
-
- H2OKeyNotFoundArgumentException(Key) - Constructor for exception water.exceptions.H2OKeyNotFoundArgumentException
-
- H2OKeysNotFoundArgumentException - Exception in water.exceptions
-
- H2OKeysNotFoundArgumentException(String, String[]) - Constructor for exception water.exceptions.H2OKeysNotFoundArgumentException
-
- H2OKeyWrongTypeArgumentException - Exception in water.exceptions
-
- H2OKeyWrongTypeArgumentException(String, Object, Class<? extends Keyed>, Class) - Constructor for exception water.exceptions.H2OKeyWrongTypeArgumentException
-
- H2ONode - Class in water
-
A Node
in an H2O
Cloud.
- H2ONotFoundArgumentException - Exception in water.exceptions
-
- H2ONotFoundArgumentException(String, String) - Constructor for exception water.exceptions.H2ONotFoundArgumentException
-
- Handler - Class in water.api
-
- Handler() - Constructor for class water.api.Handler
-
- Handler(Handler) - Constructor for class water.api.Handler
-
- handler_class - Variable in class water.api.RouteBase
-
- handler_method - Variable in class water.api.RouteBase
-
- has(double[]) - Method in class water.rapids.ASTddply.Group
-
- has_response - Variable in class hex.CreateFrame
-
- hasException() - Method in class water.DTask
-
- hasFloat() - Method in class water.fvec.Chunk
-
- hashCode() - Method in class water.fvec.Vec
-
Vec's hashcode, which is just the Vec Key hashcode.
- hashCode() - Method in class water.fvec.Vec.VectorGroup
-
VectorGroups's hashcode
- hashCode() - Method in class water.H2ONode
-
- hashCode() - Method in class water.init.TimelineSnapshot.Event
-
- hashCode() - Method in class water.Key
-
- hashCode() - Method in class water.parser.ValueString
-
- hashCode() - Method in class water.rapids.ASTddply.Group
-
- hashCode() - Method in class water.util.IcedHashMap
-
- hashCode() - Method in class water.util.IcedInt
-
- hasNaNsOrInfs(double[]) - Static method in class water.util.ArrayUtils
-
- hasNaNsOrInfs(float[]) - Static method in class water.util.ArrayUtils
-
- hasNext() - Method in class water.init.TimelineSnapshot
-
Just check if there is any non null non-issued event.
- hasQueuedSubmissions() - Method in class jsr166y.ForkJoinPool
-
Returns true
if there are any tasks submitted to this
pool that have not yet begun executing.
- hasWaitingConsumer() - Method in class jsr166y.LinkedTransferQueue
-
- hasWaitingConsumer() - Method in interface jsr166y.TransferQueue
-
Returns true
if there is at least one consumer waiting
to receive an element via BlockingQueue.take()
or
timed poll
.
- hcnt2 - Variable in class water.Quantiles
-
- hcnt2_high - Variable in class water.Quantiles
-
- hcnt2_high_min - Variable in class water.Quantiles
-
- hcnt2_low - Variable in class water.Quantiles
-
- hcnt2_max - Variable in class water.Quantiles
-
- hcnt2_min - Variable in class water.Quantiles
-
- hdfs - Variable in class water.H2O.OptArgs
-
-hdfs=hdfs; HDFS backend
- HDFS - Static variable in class water.persist.Persist.Schemes
-
- HDFS - Static variable in class water.Value
-
- hdfs_config - Variable in class water.H2O.OptArgs
-
-hdfs_config=hdfs_config; configuration file of the HDFS
- hdfs_skip - Variable in class water.H2O.OptArgs
-
-hdfs_skip=hdfs_skip; used by hadoop driver to not unpack and load any hdfs jar file at runtime.
- hdfs_version - Variable in class water.H2O.OptArgs
-
-hdfs_version=hdfs_version; version of the filesystem
- HDFSFileVec - Class in water.fvec
-
Vec representation of file stored on HDFS.
- header - Variable in class water.NanoHTTPD.Response
-
Headers for the HTTP response.
- heading1(String...) - Method in class water.util.MarkdownBuilder
-
- heading2(String...) - Method in class water.util.MarkdownBuilder
-
- healthy - Variable in class water.api.CloudV1.NodeV1
-
- HeartBeat - Class in water
-
Struct holding H2ONode health info.
- HeartBeat() - Constructor for class water.HeartBeat
-
- HeartBeatThread - Class in water
-
Starts a thread publishing multicast HeartBeats to the local subnet: the
Leader of this Cloud.
- HeartBeatThread() - Constructor for class water.HeartBeatThread
-
- help - Variable in class water.api.ModelOutputSchema
-
- help - Variable in class water.api.ModelParameterSchemaV2
-
- help - Variable in class water.H2O.OptArgs
-
-help, -help=true; print help and exit
- helpQuiesce() - Static method in class jsr166y.ForkJoinTask
-
Possibly executes tasks until the pool hosting the current task
is quiescent
.
- hex - package hex
-
- hex(String) - Static method in class water.parser.ParseSetup
-
- hex.schemas - package hex.schemas
-
- hexName - Variable in class water.parser.ParseSetupV2
-
- HIDDEN_USER_KEY - Static variable in class water.Key
-
- hide(String, String) - Method in class hex.ModelBuilder
-
- HitRatio - Class in hex
-
- HitRatio(Vec, Frame, int) - Constructor for class hex.HitRatio
-
- hline() - Method in class water.util.MarkdownBuilder
-
- home() - Method in class water.Key
-
- home_node() - Method in class water.Key
-
The home node for this Key.
- href(String, String, String) - Method in class water.util.DocGen.HTML
-
- HTTP_BADREQUEST - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_FORBIDDEN - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_INTERNALERROR - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- http_method - Variable in class water.api.DocsBase
-
- http_method - Variable in class water.api.RouteBase
-
- HTTP_NOTFOUND - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_NOTIMPLEMENTED - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_NOTMODIFIED - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_OK - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_PARTIALCONTENT - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_RANGE_NOT_SATISFIABLE - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_REDIRECT - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_RESPONSE_CODE() - Method in exception water.exceptions.H2OAbstractRuntimeException
-
- HTTP_RESPONSE_CODE() - Method in exception water.exceptions.H2OIllegalArgumentException
-
- HTTP_RESPONSE_CODE() - Method in exception water.exceptions.H2OKeyWrongTypeArgumentException
-
- HTTP_RESPONSE_CODE() - Method in exception water.exceptions.H2ONotFoundArgumentException
-
- http_status - Variable in class water.api.H2OErrorV1
-
- HTTP_TOOLONGREQUEST - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- HTTP_UNAUTHORIZED - Static variable in class water.NanoHTTPD
-
Some HTTP response status codes
- httpd(String) - Static method in class water.util.Log
-
- httpStatus() - Method in class hex.schemas.ModelBuilderSchema
-
- httpStatus() - Method in class water.api.H2OErrorV1
-
- httpStatus() - Method in interface water.api.SpecifiesHttpResponseCode
-
- httpStatusHeader(int) - Static method in class water.H2OError
-
- I - Static variable in class water.persist.Persist
-
All available back-ends, C.f.
- i(int) - Method in class water.util.SB
-
- i() - Method in class water.util.SB
-
- ICE - Static variable in class water.Value
-
- ICE_ROOT - Static variable in class water.H2O
-
- ice_root - Variable in class water.H2O.OptArgs
-
-ice_root=ice_root; ice root directory; where temp files go
- Iced<D extends Iced> - Class in water
-
H2O uses Iced classes as the primary means of moving Java Objects around
the cluster.
- Iced() - Constructor for class water.Iced
-
- ICED - Static variable in class water.TypeMap
-
- IcedArrayList<T extends Iced> - Class in water.util
-
Simple wrapper around ArrayList with support for H2O serialization
- IcedArrayList() - Constructor for class water.util.IcedArrayList
-
- IcedBitSet - Class in water.util
-
BitSet - Iced, meaning cheaply serialized over the wire.
- IcedBitSet(int) - Constructor for class water.util.IcedBitSet
-
- IcedBitSet(int, int) - Constructor for class water.util.IcedBitSet
-
- IcedHashMap<K,V> - Class in water.util
-
Iced / Freezable NonBlockingHashMap.
- IcedHashMap() - Constructor for class water.util.IcedHashMap
-
- IcedInt - Class in water.util
-
- IcedInt(int) - Constructor for class water.util.IcedInt
-
- IcedWrapper - Class in water
-
Iced wrapper object for primitive types and arrays, to allow fields in other Iced
classes to have a generic type equivalent to Object, which can contain primitives,
arrays, and Iced objects.
- IcedWrapper(Object) - Constructor for class water.IcedWrapper
-
- icer() - Method in class water.H2O.H2OCountedCompleter
-
Find the serializatoin delegate for a subclass of this class
- Icer<T extends Freezable> - Class in water
-
Base Class for the
Iced
implementation hierarchy; subclasses are
all auto-gen'd and no user code should call or extend this class.
- Icer(T) - Constructor for class water.Icer
-
- ignore(Throwable) - Static method in class water.util.Log
-
- ignore(Throwable, String) - Static method in class water.util.Log
-
- ignore(Throwable, String, boolean) - Static method in class water.util.Log
-
- ignored_columns - Variable in class water.api.ModelParametersSchema
-
- ii(int) - Method in class water.util.SB
-
- ILLEGAL_CHARACTERS - Static variable in class water.util.SB
-
Java-string illegal characters which need to be escaped
- importFiles(int, ImportFilesV2) - Method in class water.api.ImportFilesHandler
-
- ImportFilesHandler - Class in water.api
-
The handler provides import capabilities.
- ImportFilesHandler() - Constructor for class water.api.ImportFilesHandler
-
- incr(int[], int) - Static method in class water.util.AtomicUtils.IntArray
-
- incr(long[], int) - Static method in class water.util.AtomicUtils.LongArray
-
- indent(StringBuilder, int) - Method in class water.rapids.AST
-
- index() - Method in class water.H2ONode
-
- indices() - Method in class water.fvec.NewChunk
-
- inet(long[], int) - Static method in class water.TimeLine
-
- inflate() - Method in class water.fvec.Chunk
-
- inflate_impl(NewChunk) - Method in class water.fvec.Chunk
-
Chunk-specific bulk inflater back to NewChunk.
- inflate_impl(NewChunk) - Method in class water.fvec.NewChunk
-
- info(String, String) - Method in class hex.ModelBuilder
-
- info(Object...) - Static method in class water.util.Log
-
- info(String, boolean) - Static method in class water.util.Log
-
- inForkJoinPool() - Static method in class jsr166y.ForkJoinTask
-
Returns
true
if the current thread is a
ForkJoinWorkerThread
executing as a ForkJoinPool computation.
- init(boolean) - Method in class hex.ModelBuilder
-
Initialize the ModelBuilder, validating all arguments and preparing the
training frame.
- init(boolean) - Method in class hex.SupervisedModelBuilder
-
Initialize the ModelBuilder, validating all arguments and preparing the
training frame.
- init(Value, long, int) - Method in class water.api.InspectHandler.InspectPojo
-
- init(Quantiles) - Method in class water.api.QuantilesHandler
-
- init(String) - Static method in class water.util.Log
-
- initializeNetworkSockets() - Static method in class water.init.NetworkInit
-
- InitIDHandler - Class in water.api
-
- InitIDHandler() - Constructor for class water.api.InitIDHandler
-
- InitIDV1 - Class in water.api
-
- InitIDV1() - Constructor for class water.api.InitIDV1
-
- innerProduct(double[], double[]) - Static method in class water.util.ArrayUtils
-
- innerProduct(double[], double[]) - Static method in class water.util.MathUtils
-
- input_schema - Variable in class water.api.RouteBase
-
- inspect(int, InspectV1) - Method in class water.api.InspectHandler
-
- InspectHandler - Class in water.api
-
- InspectHandler() - Constructor for class water.api.InspectHandler
-
- InspectHandler.InspectPojo - Class in water.api
-
- InspectHandler.InspectPojo() - Constructor for class water.api.InspectHandler.InspectPojo
-
- InspectHandler.InspectPojo(Value, long, int) - Constructor for class water.api.InspectHandler.InspectPojo
-
- integer_fraction - Variable in class hex.CreateFrame
-
- integer_range - Variable in class hex.CreateFrame
-
- intern(InetAddress, int) - Static method in class water.H2ONode
-
- intern(byte[], int) - Static method in class water.H2ONode
-
- interpolation_type - Variable in class water.api.QuantilesV1
-
- INVALIDATE_PRIORITY - Static variable in class water.H2O
-
- invalidLine(String) - Method in class water.parser.Parser.InspectDataOut
-
- invoke(ForkJoinTask<T>) - Method in class jsr166y.ForkJoinPool
-
Performs the given task, returning its result upon completion.
- invoke() - Method in class jsr166y.ForkJoinTask
-
Commences performing this task, awaits its completion if
necessary, and returns its result, or throws an (unchecked)
RuntimeException
or Error
if the underlying
computation did so.
- invoke(Key) - Method in class water.Atomic
-
Block until it completes, even if run remotely
- invokeAll(Collection<? extends Callable<T>>) - Method in class jsr166y.ForkJoinPool
-
- invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class jsr166y.ForkJoinTask
-
Forks the given tasks, returning when isDone
holds for
each task or an (unchecked) exception is encountered, in which
case the exception is rethrown.
- invokeAll(ForkJoinTask<?>...) - Static method in class jsr166y.ForkJoinTask
-
Forks the given tasks, returning when isDone
holds for
each task or an (unchecked) exception is encountered, in which
case the exception is rethrown.
- invokeAll(Collection<T>) - Static method in class jsr166y.ForkJoinTask
-
Forks all tasks in the specified collection, returning when
isDone
holds for each task or an (unchecked) exception
is encountered, in which case the exception is rethrown.
- invokeTask() - Method in class water.DTask.DKeyTask
-
Convenience blocking submit to work queues
- ioflavor() - Method in class water.init.TimelineSnapshot.Event
-
- ioType() - Method in class water.api.TimelineV2.EventV2
-
- ioType() - Method in class water.api.TimelineV2.NetworkEvent
-
- ip - Variable in class water.H2O.OptArgs
-
-port=ip4_or_ip6; Named IP4/IP6 address instead of the default
- ip4() - Method in class water.H2ONode
-
- ip_port - Variable in class water.api.CloudV1.NodeV1
-
- is_io() - Method in class water.init.TimelineSnapshot.Event
-
- is_member_of_frames - Variable in class water.api.FrameV2.ColSpecifierV2
-
- is_member_of_frames - Variable in class water.api.ModelParameterSchemaV2
-
- is_mutually_exclusive_with - Variable in class water.api.ModelParameterSchemaV2
-
- is_schema - Variable in class water.api.SchemaMetadata.FieldMetadata
-
Type for this field is itself a Schema.
- is_schema - Variable in class water.api.SchemaMetadataBase.FieldMetadataBase
-
- isAry() - Method in class water.rapids.Env
-
- isBad() - Method in class water.fvec.Vec
-
True if the column contains only NAs
- isBinary() - Method in class hex.ConfusionMatrix
-
- isBuiltinOp(String) - Static method in class water.rapids.ASTOp
-
- isCancelled() - Method in class jsr166y.ForkJoinTask
-
- isCancelled() - Method in class water.RPC
-
- isCancelledOrCrashed() - Method in class water.Job
-
Returns true if the job was cancelled by the user or crashed.
- isChunkKey() - Method in class water.Key
-
True is this is a
Chunk
Key.
- isClassifier() - Method in class hex.Model.Output
-
Is this model a classification model? (v.
- isClassifier() - Method in class hex.SupervisedModel.SupervisedOutput
-
- isClassifier() - Method in class hex.SupervisedModelBuilder
-
- isClosed() - Method in class water.AutoBuffer
-
- isCompatible(ParseSetup) - Method in class water.parser.ParseSetup
-
- isCompletedAbnormally() - Method in class jsr166y.ForkJoinTask
-
Returns true
if this task threw an exception or was cancelled.
- isCompletedNormally() - Method in class jsr166y.ForkJoinTask
-
Returns true
if this task completed without throwing an
exception and was not cancelled.
- isConst() - Method in class water.fvec.Vec
-
True if the column contains only a constant value and it is not full of NAs
- isDone() - Method in class jsr166y.ForkJoinTask
-
- isDone() - Method in class water.Job
-
Returns true if this job is done
- isDone() - Method in class water.RPC
-
- isDropped() - Method in class water.init.TimelineSnapshot.Event
-
- isEmpty() - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns true
if this collection contains no elements.
- isEmpty() - Method in class jsr166y.LinkedTransferQueue
-
Returns true
if this queue contains no elements.
- isEmpty() - Method in class water.init.TimelineSnapshot.Event
-
- isEmpty() - Method in class water.rapids.Env
-
- isEmpty(long[], int) - Static method in class water.TimeLine
-
- isEmpty() - Method in class water.util.IcedHashMap
-
- isEmpty(double) - Static method in class water.util.TwoDimTable
-
Check whether a double value is considered an "empty field".
- isEnum(int) - Method in class water.fvec.NewChunk
-
- isEnum() - Method in class water.fvec.Vec
-
True if this is an Categorical column.
- isEnum2(int) - Method in class water.fvec.NewChunk
-
- isEOL(byte) - Static method in class water.parser.Parser
-
- isForFrame(Frame) - Method in class hex.ModelMetrics
-
- isForModel(Model) - Method in class hex.ModelMetrics
-
- isFrame() - Method in class water.KeySnapshot.KeyInfo
-
- isFrame() - Method in class water.Value
-
Check if the Value's POJO is a
Frame
subtype.
- isFun() - Method in class water.rapids.Env
-
- isGlobal() - Method in class water.rapids.Env
-
- isId() - Method in class water.rapids.Env
-
- isInfixOp(String) - Static method in class water.rapids.ASTOp
-
- isInt() - Method in class water.fvec.ByteVec
-
Is all integers? Yes, it's all bytes
- isInt() - Method in class water.fvec.Vec
-
isInt is a property of numeric Vecs and not a type; this
property can be changed by assigning non-integer values into the Vec (or
restored by overwriting non-integer values with integers).
- isInt(String) - Static method in class water.util.ArrayUtils
-
- isJob() - Method in class water.Value
-
Check if the Value's POJO is a
Job
subtype.
- isKey() - Method in class water.Value
-
Check if the Value's POJO is a
Key
subtype.
- isLockable() - Method in class water.KeySnapshot.KeyInfo
-
- isLockable() - Method in class water.Value
-
Check if the Value's POJO is a
Lockable
subtype.
- isModel() - Method in class water.Value
-
Check if the Value's POJO is a
Model
subtype.
- isNA(int) - Method in class water.fvec.Chunk
-
Missing value status using chunk-relative row numbers.
- isNA(long) - Method in class water.fvec.Vec
-
Fetch the missing-status the slow way.
- isNA2(int) - Method in class water.fvec.NewChunk
-
- isNA_impl(int) - Method in class water.fvec.NewChunk
-
- isNul() - Method in class water.rapids.Env
-
- isNum() - Method in class water.rapids.Env
-
- isNumeric() - Method in class water.fvec.Vec
-
True if this is a numeric column, excluding enum and time types.
- isOp(String) - Static method in class water.rapids.ASTOp
-
- isPersisted() - Method in class water.Value
-
Check if the backing byte[] has been saved-to-disk
- isQuiescent() - Method in class jsr166y.ForkJoinPool
-
Returns true
if all worker threads are currently idle.
- isRecv() - Method in class water.init.TimelineSnapshot.Event
-
- isReleasable() - Method in interface jsr166y.ForkJoinPool.ManagedBlocker
-
Returns true
if blocking is unnecessary.
- isReleasable() - Method in class water.MRTask
-
- isReleasable() - Method in class water.RPC
-
- isReleasable() - Method in class water.Value
-
Return true if blocking is unnecessary.
- isRunning() - Method in class water.Job
-
Returns true if this job is running
- isRunning(Key<Job>) - Static method in class water.Job
-
Check if given job is running.
- isSend - Variable in class water.api.TimelineV2.NetworkEvent
-
- isSend() - Method in class water.init.TimelineSnapshot.Event
-
- isSeries() - Method in class water.rapids.Env
-
- isShutdown() - Method in class jsr166y.ForkJoinPool
-
Returns true
if this pool has been shut down.
- isSpan() - Method in class water.rapids.Env
-
- isSparse() - Method in class water.fvec.Chunk
-
Sparse Chunks have a significant number of zeros, and support for
skipping over large runs of zeros in a row.
- isSparse() - Method in class water.fvec.NewChunk
-
- isStopped() - Method in class water.Job
-
Returns true if this job was started and is now stopped
- isStr() - Method in class water.rapids.Env
-
- isString() - Method in class water.fvec.NewChunk
-
- isString() - Method in class water.fvec.Vec
-
True if this is a String column.
- isString(int) - Method in class water.parser.Parser.InspectDataOut
-
- isSubclassOf(Class) - Method in class water.KeySnapshot.KeyInfo
-
- isSubclassOf(int, Class) - Static method in class water.Value
-
Check if the Value's POJO is a subtype of given type integer.
- issue(int, InitIDV1) - Method in class water.api.InitIDHandler
-
- isSupervised() - Method in class hex.Model
-
- isSupervised() - Method in class hex.SupervisedModel
-
- isTCP() - Method in class water.init.TimelineSnapshot.Event
-
- isTerminated() - Method in class jsr166y.ForkJoinPool
-
Returns true
if all tasks have completed following shut down.
- isTerminated() - Method in class jsr166y.Phaser
-
Returns true
if this phaser has been terminated.
- isTerminating() - Method in class jsr166y.ForkJoinPool
-
Returns true
if the process of termination has
commenced but not yet completed.
- isText - Variable in class water.api.FrameV2
-
- isTime() - Method in class water.fvec.Vec
-
True if this is a time column.
- isUDF(String) - Static method in class water.rapids.ASTOp
-
- isUDF(ASTOp) - Static method in class water.rapids.ASTOp
-
- isUUID() - Method in class water.fvec.NewChunk
-
- isUUID() - Method in class water.fvec.Vec
-
True if this is a UUID column.
- isVec() - Method in class water.Key
-
True is this is a
Vec
Key.
- isVec() - Method in class water.Value
-
Check if the Value's POJO is a
Vec
subtype.
- isVecGroup() - Method in class water.Value
-
- iterator() - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns an iterator over the elements in this deque in proper sequence.
- iterator() - Method in class jsr166y.LinkedTransferQueue
-
Returns an iterator over the elements in this queue in proper sequence.
- iterator() - Method in class water.init.TimelineSnapshot
-
- main(String[]) - Static method in class water.H2O
-
- main(String[]) - Static method in class water.H2OClient
-
Entry point which ensure launching H2O in client mode
- main(String[]) - Static method in class water.init.Linpack
-
- main(String[]) - Static method in class water.init.MemoryBandwidth
-
- main(String[]) - Static method in class water.NanoHTTPD
-
Starts as a standalone file server and waits for Enter.
- main(String[]) - Static method in class water.util.LinuxProcFileReader
-
Main is purely for command-line testing.
- make(Class<? extends KeySchema>, Key) - Static method in class water.api.KeySchema
-
- make(Key) - Static method in class water.api.KeySchema
-
TODO: figure out the right KeySchema class from the Key, so the type is set properly.
- make(FileStatus) - Static method in class water.fvec.HDFSFileVec
-
- make(FileStatus, Futures) - Static method in class water.fvec.HDFSFileVec
-
- make(File) - Static method in class water.fvec.NFSFileVec
-
Make a new NFSFileVec key which holds the filename implicitly.
- make(File, Futures) - Static method in class water.fvec.NFSFileVec
-
Make a new NFSFileVec key which holds the filename implicitly.
- make(byte[]) - Static method in class water.Key
-
Factory making a Key from a byte[]
- make(String) - Static method in class water.Key
-
Factory making a Key from a String
- make() - Static method in class water.Key
-
Factory making a random Key
- make(String, byte, byte, boolean, H2ONode...) - Static method in class water.Key
-
Factory making a homed system Key.
- make(byte, byte, boolean, H2ONode...) - Static method in class water.Key
-
Factory making a homed system Key.
- makeCompatible(Frame) - Method in class water.fvec.Frame
-
Return Frame 'f' if 'f' is compatible with 'this', else return a new
Frame compatible with 'this' and a copy of 'f's data otherwise.
- makeCon(double, long) - Static method in class water.fvec.Vec
-
Make a new constant vector with the given row count.
- makeCon(double, long, int) - Static method in class water.fvec.Vec
-
Make a new constant vector with the given row count.
- makeCon(double) - Method in class water.fvec.Vec
-
Make a new vector with the same size and data layout as the current one,
and initialized to the given constant value.
- makeCons(int, long, String[][], byte[]) - Method in class water.fvec.Vec
-
- makeCopy() - Method in class water.fvec.Vec
-
A new vector which is a copy of this
one.
- makeModelMetrics(Model, Frame, double) - Method in class hex.ModelMetrics.MetricBuilder
-
- makeRepSeq(long, long) - Static method in class water.fvec.Vec
-
Make a new vector initialized to increasing integers mod repeat
, starting with 1.
- makeSeq(long) - Static method in class water.fvec.Vec
-
Make a new vector initialized to increasing integers, starting with 1.
- makeSeq(long, long) - Static method in class water.fvec.Vec
-
Make a new vector initialized to increasing integers, starting with `min`.
- makeSystem(String) - Static method in class water.Key
-
- makeUserHidden(Key) - Static method in class water.Key
-
- makeVec(double[], Key) - Static method in class water.fvec.Vec
-
- makeZero(long) - Static method in class water.fvec.Vec
-
Make a new zero-filled vector with the given row count.
- makeZero() - Method in class water.fvec.Vec
-
Make a new vector with the same size and data layout as the current one,
and initialized to zero.
- makeZero(String[]) - Method in class water.fvec.Vec
-
A new vector with the same size and data layout as the current one, and
initialized to zero, with the given enum domain.
- makeZeros(int) - Method in class water.fvec.Vec
-
- makeZeros(int, String[][], byte[]) - Method in class water.fvec.Vec
-
- malloc1(int) - Static method in class water.MemoryManager
-
- malloc1(int, boolean) - Static method in class water.MemoryManager
-
- malloc2(int) - Static method in class water.MemoryManager
-
- malloc4(int) - Static method in class water.MemoryManager
-
- malloc4f(int) - Static method in class water.MemoryManager
-
- malloc8(int) - Static method in class water.MemoryManager
-
- malloc8d(int) - Static method in class water.MemoryManager
-
- mallocObj(int) - Static method in class water.MemoryManager
-
- mallocZ(int) - Static method in class water.MemoryManager
-
- managedBlock(ForkJoinPool.ManagedBlocker) - Static method in class jsr166y.ForkJoinPool
-
Blocks in accord with the given blocker.
- mantissa() - Method in class water.fvec.NewChunk
-
- map(Chunk[]) - Method in class hex.DMatrix.TransposeTsk
-
- map(V) - Method in class water.DTask.DKeyTask
-
Override map(); will be run on Key's home node
- map(Keyed) - Method in class water.DTask.RemoveCall
-
- map(Chunk[]) - Method in class water.fvec.FrameCreator.MissingInserter
-
- map(Chunk[]) - Method in class water.fvec.RebalanceDataSet.RebalanceTask
-
- map(Chunk) - Method in class water.fvec.Vec.CollectDomain
-
- map(Chunk) - Method in class water.MRTask
-
Override with your map implementation.
- map(Chunk, NewChunk) - Method in class water.MRTask
-
- map(Chunk, Chunk) - Method in class water.MRTask
-
Override with your map implementation.
- map(Chunk, Chunk, NewChunk) - Method in class water.MRTask
-
- map(Chunk, Chunk, NewChunk, NewChunk) - Method in class water.MRTask
-
- map(Chunk, Chunk, Chunk) - Method in class water.MRTask
-
Override with your map implementation.
- map(Chunk, Chunk, Chunk, NewChunk) - Method in class water.MRTask
-
- map(Chunk, Chunk, Chunk, NewChunk, NewChunk) - Method in class water.MRTask
-
- map(Chunk[]) - Method in class water.MRTask
-
Override with your map implementation.
- map(Chunk[], NewChunk) - Method in class water.MRTask
-
- map(Chunk[], NewChunk, NewChunk) - Method in class water.MRTask
-
- map(Chunk[], NewChunk[]) - Method in class water.MRTask
-
- map(Key) - Method in class water.MRTask
-
Override with your map implementation.
- map(Key) - Method in class water.parser.ParseSetup.GuessSetupTsk
-
- map(Chunk[]) - Method in class water.Quantiles.BinningTask
-
- map(Chunk[]) - Method in class water.rapids.ASTddply.ddplyPass1
-
- map(Chunk[]) - Method in class water.util.ChunkSummary
-
- map(Chunk[]) - Method in class water.util.FrameUtils.MissingInserter
-
- mapValidationMessageFieldNames(String[], String[]) - Method in class hex.schemas.ModelBuilderSchema
-
Map impl field names in the validation messages to schema field names,
called after behavior of stripping leading _ characters.
- markdown - Variable in class water.api.DocsBase
-
- markdown(Handler, int, StringBuffer, String) - Method in class water.api.Handler
-
- markdown - Variable in class water.api.RouteBase
-
- markdown(StringBuffer) - Method in class water.api.Schema
-
Generate Markdown documentation for this Schema.
- markdown(StringBuffer, boolean, boolean) - Method in class water.api.Schema
-
Generate Markdown documentation for this Schema possibly including only the input or output fields.
- markdown(SchemaMetadata, StringBuffer) - Method in class water.api.Schema
-
- markdown(SchemaMetadata, StringBuffer, boolean, boolean) - Method in class water.api.Schema
-
Generate Markdown documentation for this Schema, given we already have the metadata constructed.
- markdown - Variable in class water.api.SchemaMetadata
-
- MarkdownBuilder - Class in water.util
-
Small helper class for creating Markdown in a StringBuffer.
- MarkdownBuilder() - Constructor for class water.util.MarkdownBuilder
-
- MathUtils - Class in water.util
-
- MathUtils() - Constructor for class water.util.MathUtils
-
- max() - Method in class water.fvec.Vec
-
Vec's maximum value
- max_after_balance_size - Variable in class water.api.SupervisedModelParametersSchema
-
When classes are balanced, limit the resulting dataset size to the
specified multiple of the original dataset size.
- max_disk - Variable in class water.api.CloudV1.NodeV1
-
- MAX_ENUM_SIZE - Static variable in class water.parser.Categorical
-
- MAX_ENUM_SIZE - Static variable in class water.Quantiles
-
- MAX_ERRORS - Static variable in class water.parser.ParseSetup.GuessSetupTsk
-
- MAX_EVENTS - Static variable in class water.TimeLine
-
- max_mem - Variable in class water.api.CloudV1.NodeV1
-
- max_ncols - Variable in class water.api.QuantilesV1
-
- max_per_class_error - Variable in class hex.AUCData
-
- max_per_class_error(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- max_per_class_error() - Method in class hex.AUCData
-
- max_per_class_error() - Method in class hex.ConfusionMatrix
-
The maximum per-class error
- max_per_class_error - Variable in class water.api.AUCBase
-
- max_per_class_error_for_criteria - Variable in class water.api.AUCBase
-
- MAX_PREVIEW_COLS - Static variable in class water.parser.Parser.InspectDataOut
-
- MAX_PREVIEW_LINES - Static variable in class water.parser.Parser.InspectDataOut
-
- MAX_PRIORITY - Static variable in class water.H2O
-
- max_qbins - Variable in class water.api.QuantilesV1
-
- max_var - Variable in class hex.VarImp
-
- maxIndex(int[], Random) - Static method in class water.util.ArrayUtils
-
Returns the index of the largest value in the array.
- maxIndex(float[], Random) - Static method in class water.util.ArrayUtils
-
- maxIndex(int[]) - Static method in class water.util.ArrayUtils
-
- maxIndex(long[]) - Static method in class water.util.ArrayUtils
-
- maxIndex(float[]) - Static method in class water.util.ArrayUtils
-
- maxs - Variable in class water.api.FrameV2.ColV2
-
- maxs() - Method in class water.fvec.Vec
-
Vec's 5 largest values
- maxValue(double[]) - Static method in class water.util.ArrayUtils
-
- maxValue(float[]) - Static method in class water.util.ArrayUtils
-
- maxValue(float[], int, int) - Static method in class water.util.ArrayUtils
-
- maxValue(long[]) - Static method in class water.util.ArrayUtils
-
- mcc - Variable in class hex.AUCData
-
- mcc(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- mcc() - Method in class hex.AUCData
-
- mcc() - Method in class hex.ConfusionMatrix
-
The Matthews Correlation Coefficient, takes true negatives into account in contrast to F-Score
See
MCC
MCC = Correlation between observed and predicted binary classification
- mcc - Variable in class water.api.AUCBase
-
- mcc_for_criteria - Variable in class water.api.AUCBase
-
- md5skip - Variable in class water.H2O.OptArgs
-
-md5skip, -md5skip=true; test-only; Skip the MD5 Jar checksum; allows jars from different builds to mingle in the same cloud
- mean - Variable in class water.api.FrameV2.ColV2
-
- mean() - Method in class water.fvec.Vec
-
Vecs's mean
- mem_bw - Variable in class water.api.CloudV1.NodeV1
-
- mem_value_size - Variable in class water.api.CloudV1.NodeV1
-
- members() - Method in class water.H2O
-
- memOrLoad() - Method in class water.Value
-
The FAST path get-byte-array - final method for speed.
- MemoryBandwidth - Class in water.init
-
- MemoryBandwidth() - Constructor for class water.init.MemoryBandwidth
-
- MemoryManager - Class in water
-
Manages memory assigned to key/value pairs.
- MemoryManager() - Constructor for class water.MemoryManager
-
- memsz() - Method in class water.H2O
-
- merge(Parser.ColTypeInfo) - Method in class water.parser.Parser.ColTypeInfo
-
- message - Variable in class water.api.ModelParametersSchema.ValidationMessageBase
-
- message_type - Variable in class water.api.ModelParametersSchema.ValidationMessageBase
-
- method - Variable in class hex.VarImp
-
- microseconds - Variable in class water.init.NetworkTest
-
- microseconds_collective - Variable in class water.init.NetworkTest
-
- MIME_DEFAULT_BINARY - Static variable in class water.NanoHTTPD
-
Common mime types for dynamic content
- MIME_HTML - Static variable in class water.NanoHTTPD
-
Common mime types for dynamic content
- MIME_JSON - Static variable in class water.NanoHTTPD
-
Common mime types for dynamic content
- MIME_PLAINTEXT - Static variable in class water.NanoHTTPD
-
Common mime types for dynamic content
- MIME_XML - Static variable in class water.NanoHTTPD
-
Common mime types for dynamic content
- mimeType - Variable in class water.NanoHTTPD.Response
-
MIME type of content, e.g.
- min() - Method in class water.fvec.Vec
-
Vec's minimum value
- MIN_HI_PRIORITY - Static variable in class water.H2O
-
- MIN_PRIORITY - Static variable in class water.H2O
-
- MIN_SPARSE_RATIO - Static variable in class water.fvec.NewChunk
-
- minIndex(int[]) - Static method in class water.util.ArrayUtils
-
- minIndex(float[]) - Static method in class water.util.ArrayUtils
-
- mins - Variable in class water.api.FrameV2.ColV2
-
- mins() - Method in class water.fvec.Vec
-
Vec's 5 smallest values
- minValue(float[]) - Static method in class water.util.ArrayUtils
-
- minValue(long[]) - Static method in class water.util.ArrayUtils
-
- missing - Variable in class water.api.FrameV2.ColV2
-
- missing_fraction - Variable in class hex.CreateFrame
-
- missingColumnsType() - Method in class hex.Model.Parameters
-
Type of missing columns during adaptation between train/test datasets
Overload this method for models that have sparse data handling - a zero
will preserve the sparseness.
- mmul(Frame, Frame) - Static method in class hex.DMatrix
-
- Model<M extends Model<M,P,O>,P extends Model.Parameters,O extends Model.Output> - Class in hex
-
A Model models reality (hopefully).
- Model(Key, P, O) - Constructor for class hex.Model
-
Full constructor
- model() - Method in class hex.ModelMetrics
-
- model - Variable in class water.api.ModelMetricsBase
-
- Model.ModelCategory - Enum in hex
-
Different prediction categories for models.
- Model.Output - Class in hex
-
Model-specific output class.
- Model.Output(ModelBuilder) - Constructor for class hex.Model.Output
-
Any final prep-work just before model-building starts, but after the
user has clicked "go".
- Model.Parameters - Class in hex
-
Model-specific parameter class.
- Model.Parameters() - Constructor for class hex.Model.Parameters
-
- model_category - Variable in class water.api.ModelMetricsBase
-
- model_category - Variable in class water.api.ModelOutputSchema
-
- model_checksum - Variable in class water.api.ModelMetricsBase
-
- ModelBuilder<M extends Model<M,P,O>,P extends Model.Parameters,O extends Model.Output> - Class in hex
-
Model builder parent class.
- ModelBuilder(P) - Constructor for class hex.ModelBuilder
-
Constructor called from an http request; MUST override in subclasses.
- ModelBuilder(String, P) - Constructor for class hex.ModelBuilder
-
Constructor making a default destination key
- ModelBuilder(Key, String, P) - Constructor for class hex.ModelBuilder
-
Default constructor, given all arguments
- ModelBuilder.ValidationMessage - Class in hex
-
The result of an abnormal Model.Parameter check.
- ModelBuilder.ValidationMessage(ModelBuilder.ValidationMessage.MessageType, String, String) - Constructor for class hex.ModelBuilder.ValidationMessage
-
- ModelBuilder.ValidationMessage.MessageType - Enum in hex
-
- ModelBuilderHandler<B extends ModelBuilder,S extends ModelBuilderSchema<B,S,P>,P extends ModelParametersSchema> - Class in water.api
-
- ModelBuilderHandler() - Constructor for class water.api.ModelBuilderHandler
-
- ModelBuilderSchema<B extends ModelBuilder,S extends ModelBuilderSchema<B,S,P>,P extends ModelParametersSchema> - Class in hex.schemas
-
- ModelBuilderSchema() - Constructor for class hex.schemas.ModelBuilderSchema
-
- ModelBuildersV2 - Class in water.api
-
- ModelBuildersV2() - Constructor for class water.api.ModelBuildersV2
-
- ModelMetrics - Class in hex
-
Container to hold the metric for a model as scored on a specific frame.
- ModelMetrics(Model, Frame) - Constructor for class hex.ModelMetrics
-
- ModelMetrics.MetricBuilder - Class in hex
-
Class used to compute AUCs, CMs & HRs "on the fly" during other passes
over Big Data.
- ModelMetrics.MetricBuilder(String[]) - Constructor for class hex.ModelMetrics.MetricBuilder
-
- ModelMetrics.MetricBuilder(String[], float[]) - Constructor for class hex.ModelMetrics.MetricBuilder
-
- ModelMetricsBase<I extends ModelMetrics,S extends ModelMetricsBase<I,S>> - Class in water.api
-
Base Schema for individual instances of ModelMetrics objects.
- ModelMetricsBase() - Constructor for class water.api.ModelMetricsBase
-
- ModelMetricsV3 - Class in water.api
-
- ModelMetricsV3() - Constructor for class water.api.ModelMetricsV3
-
- ModelOutputSchema<O extends Model.Output,S extends ModelOutputSchema<O,S>> - Class in water.api
-
An instance of a ModelOutput schema contains the Model build output (e.g., the cluster centers for KMeans).
- ModelOutputSchema() - Constructor for class water.api.ModelOutputSchema
-
- ModelParameterSchemaV2 - Class in water.api
-
An instance of a ModelParameters schema contains the metadata for a single Model build parameter (e.g., K for KMeans).
- ModelParameterSchemaV2() - Constructor for class water.api.ModelParameterSchemaV2
-
- ModelParameterSchemaV2(ModelParametersSchema, ModelParametersSchema, Field) - Constructor for class water.api.ModelParameterSchemaV2
-
TODO: refactor using SchemaMetadata.
- ModelParametersSchema<P extends Model.Parameters,S extends ModelParametersSchema<P,S>> - Class in water.api
-
An instance of a ModelParameters schema contains the Model build parameters (e.g., K and max_iterations for KMeans).
- ModelParametersSchema() - Constructor for class water.api.ModelParametersSchema
-
- ModelParametersSchema.ValidationMessageBase<I extends ModelBuilder.ValidationMessage,S extends ModelParametersSchema.ValidationMessageBase<I,S>> - Class in water.api
-
- ModelParametersSchema.ValidationMessageBase() - Constructor for class water.api.ModelParametersSchema.ValidationMessageBase
-
- ModelParametersSchema.ValidationMessageV2 - Class in water.api
-
- ModelParametersSchema.ValidationMessageV2() - Constructor for class water.api.ModelParametersSchema.ValidationMessageV2
-
- ModelSchema<M extends Model,S extends ModelSchema<M,S,P,O>,P extends Model.Parameters,O extends Model.Output> - Class in water.api
-
A Model schema contains all the pieces associated with a Model:
- ModelSchema() - Constructor for class water.api.ModelSchema
-
- ModelSchema(M) - Constructor for class water.api.ModelSchema
-
- ModelUtils - Class in water.util
-
Shared static code to support modeling, prediction, and scoring.
- ModelUtils() - Constructor for class water.util.ModelUtils
-
- MRTask<T extends MRTask<T>> - Class in water
-
Map/Reduce style distributed computation.
- MRTask() - Constructor for class water.MRTask
-
- MRTask(H2O.H2OCountedCompleter) - Constructor for class water.MRTask
-
- MRUtils - Class in water.util
-
- MRUtils() - Constructor for class water.util.MRUtils
-
- MRUtils.ClassDist - Class in water.util
-
Compute the class distribution from a class label vector
(not counting missing values)
Usage 1: Label vector is categorical
------------------------------------
Vec label = ...;
assert(label.isEnum());
long[] dist = new ClassDist(label).doAll(label).dist();
Usage 2: Label vector is numerical
----------------------------------
Vec label = ...;
int num_classes = ...;
assert(label.isInt());
long[] dist = new ClassDist(num_classes).doAll(label).dist();
- MRUtils.ClassDist(Vec) - Constructor for class water.util.MRUtils.ClassDist
-
- MRUtils.ClassDist(int) - Constructor for class water.util.MRUtils.ClassDist
-
- MRUtils.ParallelTasks<T extends DTask<T>> - Class in water.util
-
- MRUtils.ParallelTasks(H2O.H2OCountedCompleter, T[]) - Constructor for class water.util.MRUtils.ParallelTasks
-
- MRUtils.ParallelTasks(H2O.H2OCountedCompleter, T[], int) - Constructor for class water.util.MRUtils.ParallelTasks
-
- ms() - Method in class water.init.TimelineSnapshot.Event
-
- ms(long[], int) - Static method in class water.TimeLine
-
- ms_io() - Method in class water.init.TimelineSnapshot.Event
-
- msec - Variable in class water.api.JobV2
-
- msec() - Method in class water.Job
-
Current runtime; zero if not started
- msecs(long, boolean) - Static method in class water.util.PrettyPrint
-
- msg - Variable in class water.api.H2OErrorV1
-
- msg_sizes - Variable in class water.init.NetworkTest
-
- mult(float[], float) - Static method in class water.util.ArrayUtils
-
- mult(double[], double) - Static method in class water.util.ArrayUtils
-
- multicast(ByteBuffer) - Static method in class water.init.NetworkInit
-
- multiple_pass - Variable in class water.api.QuantilesV1
-
- myOut - Static variable in class water.NanoHTTPD
-
- NA - Static variable in class water.fvec.AppendableVec
-
- naCnt() - Method in class water.fvec.ByteVec
-
Return column missing-element-count - ByteVecs do not allow any "missing elements"
- naCnt() - Method in class water.fvec.NewChunk
-
- naCnt() - Method in class water.fvec.Vec
-
Count of missing elements
- name - Variable in class water.api.AboutHandler.AboutEntryV3
-
- name - Variable in class water.api.KeySchema
-
- name - Variable in class water.api.ModelParameterSchemaV2
-
- name - Variable in class water.api.SchemaMetadata
-
- name - Variable in class water.api.SchemaMetadataBase
-
The simple schema (class) name, e.g.
- name(int) - Method in class water.fvec.Frame
-
A single column name.
- name - Variable in class water.H2O.OptArgs
-
-name=name; Set cloud name
- name - Variable in class water.util.JProfile.ProfileSummary
-
- nameOfPersist(int) - Static method in class water.Value
-
One of ICE, HDFS, S3, NFS or TCP, according to where this Value is persisted.
- names - Variable in class water.api.ModelOutputSchema
-
- names() - Method in class water.fvec.Frame
-
The array of column names.
- NanoHTTPD - Class in water
-
A simple, tiny, nicely embeddable HTTP 1.0 (partially 1.1) server in Java
- NanoHTTPD(ServerSocket, File) - Constructor for class water.NanoHTTPD
-
Starts a HTTP server to given port.
- NanoHTTPD.Response - Class in water
-
HTTP response.
- NanoHTTPD.Response() - Constructor for class water.NanoHTTPD.Response
-
Default constructor: response = HTTP_OK, data = mime = 'null'
- NanoHTTPD.Response(String, String, InputStream) - Constructor for class water.NanoHTTPD.Response
-
Basic constructor.
- NanoHTTPD.Response(String, String, String) - Constructor for class water.NanoHTTPD.Response
-
Convenience method that makes an InputStream out of
given text.
- nanos() - Method in class water.util.Timer
-
- nChunks() - Method in class water.fvec.AppendableVec
-
- nChunks() - Method in class water.fvec.FileVec
-
- nChunks() - Method in class water.fvec.FrameCreator
-
- nChunks() - Method in class water.fvec.Vec
-
Number of chunks, returned as an int
- Chunk count is limited by
the max size of a Java long[]
.
- nclasses() - Method in class hex.ConfusionMatrix
-
- nclasses() - Method in class hex.Model.Output
-
- nclasses() - Method in class hex.SupervisedModel.SupervisedOutput
-
- ncols - Variable in class water.parser.ParseSetupV2
-
- network - Variable in class water.H2O.OptArgs
-
-network=network; Network specification for acceptable interfaces to bind to
- NetworkInit - Class in water.init
-
Data structure for holding network info specified by the user on the command line.
- NetworkTest - Class in water.init
-
- NetworkTest() - Constructor for class water.init.NetworkTest
-
- NetworkTest.NetworkTester - Class in water.init
-
- NetworkTest.NetworkTester(int[], double[][], double[], int, boolean, boolean) - Constructor for class water.init.NetworkTest.NetworkTester
-
- new_close() - Method in class water.fvec.NewChunk
-
- new_func(String) - Static method in class water.rapids.Exec
-
- NewChunk - Class in water.fvec
-
- NewChunk(Vec, int) - Constructor for class water.fvec.NewChunk
-
- NewChunk(Vec, int, boolean) - Constructor for class water.fvec.NewChunk
-
- NewChunk(double[]) - Constructor for class water.fvec.NewChunk
-
- NewChunk(Vec, int, long[], int[], int[], double[]) - Constructor for class water.fvec.NewChunk
-
- NewChunk(Chunk) - Constructor for class water.fvec.NewChunk
-
- NewChunk(Vec, int, int) - Constructor for class water.fvec.NewChunk
-
- NewChunk.Value - Class in water.fvec
-
- NewChunk.Value(int, int) - Constructor for class water.fvec.NewChunk.Value
-
- newInstance(Class<? extends Schema>) - Static method in class water.api.Schema
-
- newKey() - Static method in class water.fvec.Vec
-
Make a new random Key that fits the requirements for a Vec key.
- newLine() - Method in class water.parser.Parser.InspectDataOut
-
- newTaskFor(Runnable, T) - Method in class jsr166y.ForkJoinPool
-
- newTaskFor(Callable<T>) - Method in class jsr166y.ForkJoinPool
-
- newThread(ForkJoinPool) - Method in interface jsr166y.ForkJoinPool.ForkJoinWorkerThreadFactory
-
Returns a new worker thread operating in the given pool.
- next(int) - Method in class jsr166y.ThreadLocalRandom
-
- next() - Method in class water.init.TimelineSnapshot
-
Get the next event of the timeline according to the ordering.
- next(int) - Method in class water.util.RandomUtils.MersenneTwisterRNG
-
- next(int) - Method in class water.util.RandomUtils.XorShiftRNG
-
- nextChunk() - Method in class water.fvec.Chunk
-
Return the next Chunk, or null if at end.
- nextClearBit(int) - Method in class water.util.IcedBitSet
-
- nextDouble(double) - Method in class jsr166y.ThreadLocalRandom
-
Returns a pseudorandom, uniformly distributed double
value
between 0 (inclusive) and the specified value (exclusive).
- nextDouble(double, double) - Method in class jsr166y.ThreadLocalRandom
-
Returns a pseudorandom, uniformly distributed value between the
given least value (inclusive) and bound (exclusive).
- nextInt(int, int) - Method in class jsr166y.ThreadLocalRandom
-
Returns a pseudorandom, uniformly distributed value between the
given least value (inclusive) and bound (exclusive).
- nextInt() - Method in class water.util.RandomUtils.XorShiftRNG
-
- nextInt(int) - Method in class water.util.RandomUtils.XorShiftRNG
-
- nextLong(long) - Method in class jsr166y.ThreadLocalRandom
-
Returns a pseudorandom, uniformly distributed value
between 0 (inclusive) and the specified value (exclusive).
- nextLong(long, long) - Method in class jsr166y.ThreadLocalRandom
-
Returns a pseudorandom, uniformly distributed value between the
given least value (inclusive) and bound (exclusive).
- nextLong() - Method in class water.util.RandomUtils.XorShiftRNG
-
- nextNZ(int) - Method in class water.fvec.Chunk
-
- nextSetBit(int) - Method in class water.util.IcedBitSet
-
- nextThrPriority() - Method in class water.H2O.H2OCountedCompleter
-
If this is a F/J thread, return it's priority+1 - used to lift the
priority of a blocking remote call, so the remote node runs it at a
higher priority - so we don't deadlock when we burn the local
thread.
- nfeatures() - Method in class hex.Model.Output
-
Returns number of input features (OK for most unsupervised methods, need to override for supervised!)
- nfeatures() - Method in class hex.SupervisedModel.SupervisedOutput
-
- NFS - Static variable in class water.persist.Persist.Schemes
-
- NFS - Static variable in class water.Value
-
- NFSFileVec - Class in water.fvec
-
A NFS distributed file-backed Vector
- ninfs - Variable in class water.api.FrameV2.ColV2
-
- ninfs() - Method in class water.fvec.Vec
-
Count of negative infinities
- nl() - Method in class water.util.SB
-
- node_name - Variable in class water.api.ProfilerNodeV2
-
- node_name - Variable in class water.util.JProfile
-
- node_name - Variable in class water.util.ProfileCollectorTask.NodeProfile
-
- nodeidx - Variable in class water.api.LogsV3
-
- nodeidx - Variable in class water.api.WaterMeterCpuTicksV1
-
- nodeidx - Variable in class water.util.GetLogsFromNode
-
Node number to get logs from (starting at 0).
- nodeidx - Variable in class water.util.WaterMeterCpuTicks
-
- NodePersistentStorage - Class in water.init
-
- NodePersistentStorage(URI) - Constructor for class water.init.NodePersistentStorage
-
- NodePersistentStorage.NodePersistentStorageEntry - Class in water.init
-
- NodePersistentStorage.NodePersistentStorageEntry() - Constructor for class water.init.NodePersistentStorage.NodePersistentStorageEntry
-
- NodePersistentStorageHandler - Class in water.api
-
- NodePersistentStorageHandler() - Constructor for class water.api.NodePersistentStorageHandler
-
- NodePersistentStorageV1 - Class in water.api
-
Created by rpeck on 11/30/14.
- NodePersistentStorageV1() - Constructor for class water.api.NodePersistentStorageV1
-
- NodePersistentStorageV1.NodePersistentStorageEntryV1 - Class in water.api
-
- NodePersistentStorageV1.NodePersistentStorageEntryV1() - Constructor for class water.api.NodePersistentStorageV1.NodePersistentStorageEntryV1
-
- nodes - Variable in class water.api.CloudV1
-
- nodes - Variable in class water.api.ProfilerV2
-
- nodes - Variable in class water.init.NetworkTest
-
- nodes - Variable in class water.util.JProfile
-
- nonzeros(int[]) - Method in class water.fvec.Chunk
-
Get chunk-relative indices of values (nonzeros for sparse, all for dense)
stored in this chunk.
- notifyAboutCloudSize(InetAddress, int, int) - Static method in class water.H2O
-
Tell the embedding software that this H2O instance belongs to
a cloud of a certain size.
- notifyAboutCloudSize(InetAddress, int, int) - Method in class water.init.AbstractEmbeddedH2OConfig
-
Tell the embedding software that this H2O instance belongs to
a cloud of a certain size.
- notifyAboutEmbeddedWebServerIpPort(InetAddress, int) - Method in class water.init.AbstractEmbeddedH2OConfig
-
Tell the embedding software that H2O has started an embedded
web server on an IP and port.
- ns() - Method in class water.init.TimelineSnapshot.Event
-
- ns(long[], int) - Static method in class water.TimeLine
-
- nthreads - Variable in class water.api.CloudV1.NodeV1
-
- nthreads - Variable in class water.H2O.OptArgs
-
-nthreads=nthreads; Max number of F/J threads in the low-priority batch queue
- NULL - Static variable in class water.TypeMap
-
- num - Variable in class water.api.DocsBase
-
- num_cpus - Variable in class water.api.CloudV1.NodeV1
-
- num_keys - Variable in class water.api.CloudV1.NodeV1
-
- NUMBER - Static variable in class water.fvec.AppendableVec
-
- NUMBER - Static variable in class water.parser.Parser
-
- NUMBER_END - Static variable in class water.parser.Parser
-
- NUMBER_EXP - Static variable in class water.parser.Parser
-
- NUMBER_EXP_START - Static variable in class water.parser.Parser
-
- NUMBER_FRACTION - Static variable in class water.parser.Parser
-
- NUMBER_SKIP - Static variable in class water.parser.Parser
-
- NUMBER_SKIP_NO_DOT - Static variable in class water.parser.Parser
-
- numBytes() - Method in class water.util.IcedBitSet
-
- numChildren() - Method in class water.rapids.AST
-
- numCols() - Method in class water.fvec.Frame
-
Number of columns
- NUMCPUS - Static variable in class water.H2O
-
- numInts(String...) - Static method in class water.util.ArrayUtils
-
Returns number of strings which represents a number.
- numRoutes() - Static method in class water.api.RequestServer
-
- numRows() - Method in class water.fvec.Frame
-
Number of rows
- numSetBitsHex(String) - Static method in class water.util.LinuxProcFileReader
-
- nzCnt() - Method in class water.fvec.Vec
-
Count of non-zero elements
- p(String) - Method in class water.util.DocGen.HTML
-
- p(Enum) - Method in class water.util.DocGen.HTML
-
- p(String) - Method in class water.util.DocGen
-
- p(String) - Method in class water.util.SB
-
- p(float) - Method in class water.util.SB
-
- p(double) - Method in class water.util.SB
-
- p(char) - Method in class water.util.SB
-
- p(int) - Method in class water.util.SB
-
- p(long) - Method in class water.util.SB
-
- p(IcedBitSet) - Method in class water.util.SB
-
- p(SB) - Method in class water.util.SB
-
- packH2O() - Method in class water.init.TimelineSnapshot.Event
-
- Pair<K,V> - Class in water.util
-
Pair class with a clearer name than AbstractMap.SimpleEntry.
- Pair(K, V) - Constructor for class water.util.Pair
-
- paragraph(String) - Method in class water.util.DocGen
-
- paragraph(String) - Method in class water.util.MarkdownBuilder
-
- paraHead() - Method in class water.util.DocGen.HTML
-
- paraHead() - Method in class water.util.DocGen
-
- parameters - Variable in class hex.schemas.ModelBuilderSchema
-
- parameters - Variable in class water.api.ModelSchema
-
- paraTail() - Method in class water.util.DocGen.HTML
-
- paraTail() - Method in class water.util.DocGen
-
- parse(Key, Key...) - Static method in class water.parser.ParseDataset
-
- parse(Key, Key[], boolean, boolean, int) - Static method in class water.parser.ParseDataset
-
- parse(Key, Key[], boolean, ParseSetup) - Static method in class water.parser.ParseDataset
-
- parse(Key, Key[], boolean, ParseSetup, boolean) - Static method in class water.parser.ParseDataset
-
- parse() - Method in class water.rapids.Exec
-
- parse_fun() - Method in class water.rapids.Exec
-
- ParseDataset - Class in water.parser
-
- ParseDataset.ParserFJTask - Class in water.parser
-
- ParseDataset.ParserFJTask(ParseDataset, Key[], ParseSetup, boolean) - Constructor for class water.parser.ParseDataset.ParserFJTask
-
- parseFrame(Key, File) - Static method in class water.util.FrameUtils
-
Parse given file into the form of frame represented by the given key.
- parseFrame(Key, URI) - Static method in class water.util.FrameUtils
-
- Parser - Class in water.parser
-
A collection of utility classes for parsing.
- parser() - Method in class water.parser.ParseSetup
-
- Parser.ColType - Enum in water.parser
-
- Parser.ColTypeInfo - Class in water.parser
-
- Parser.ColTypeInfo() - Constructor for class water.parser.Parser.ColTypeInfo
-
- Parser.InspectDataOut - Class in water.parser
-
Class implementing DataOut, on behalf of the GUI, for parsing &
previewing the first few lines & columns of a file.
- Parser.InspectDataOut() - Constructor for class water.parser.Parser.InspectDataOut
-
- ParserType - Enum in water.parser
-
Which parse flavor is being used, and does it support parallel parsing.
- ParseSetup - Class in water.parser
-
Configuration and base guesser for a parse;
- ParseSetup(boolean, long, long, String[], ParserType, byte, int, boolean, String[], String[][], String[][], int, Parser.ColTypeInfo[]) - Constructor for class water.parser.ParseSetup
-
- ParseSetup(boolean, int) - Constructor for class water.parser.ParseSetup
-
- ParseSetup() - Constructor for class water.parser.ParseSetup
-
- ParseSetup.GuessSetupTsk - Class in water.parser
-
- ParseSetup.GuessSetupTsk(ParseSetup) - Constructor for class water.parser.ParseSetup.GuessSetupTsk
-
- ParseSetupHandler - Class in water.parser
-
A class holding parser-setup flags: kind of parser, field separator, column
header labels, whether or not to allow single-quotes to quote, number of
columns discovered.
- ParseSetupHandler() - Constructor for class water.parser.ParseSetupHandler
-
- ParseSetupV2 - Class in water.parser
-
- ParseSetupV2() - Constructor for class water.parser.ParseSetupV2
-
- ParseTime - Class in water.parser
-
- ParseTime() - Constructor for class water.parser.ParseTime
-
- ParseV2 - Class in water.api
-
- ParseV2() - Constructor for class water.api.ParseV2
-
- path - Variable in class water.api.DocsBase
-
- path_params - Variable in class water.api.RouteBase
-
- Paxos - Class in water
-
(Not The) Paxos
Used to define Cloud membership.
- Paxos() - Constructor for class water.Paxos
-
- pctiles - Variable in class water.api.FrameV2.ColV2
-
- pctiles() - Method in class water.fvec.Vec
-
A simple and cheap percentiles of the Vec, useful for getting a broad
overview of the data.
- peek() - Method in class jsr166y.ConcurrentLinkedDeque
-
- peek() - Method in class jsr166y.LinkedTransferQueue
-
- peek() - Method in class water.rapids.Env
-
- peekAry() - Method in class water.rapids.Env
-
- peekAryAt(int) - Method in class water.rapids.Env
-
- peekAt(int) - Method in class water.rapids.Env
-
- peekDbl() - Method in class water.rapids.Env
-
- peekFirst() - Method in class jsr166y.ConcurrentLinkedDeque
-
- peekLast() - Method in class jsr166y.ConcurrentLinkedDeque
-
- peekNextLocalTask() - Static method in class jsr166y.ForkJoinTask
-
Returns, but does not unschedule or execute, a task queued by
the current thread but not yet executed, if one is immediately
available.
- peekType() - Method in class water.rapids.Env
-
- peekTypeAt(int) - Method in class water.rapids.Env
-
- PERCENTILES - Static variable in class water.fvec.Vec
-
Default Histogram bins.
- perRow(float[], float) - Method in class hex.ModelMetrics.MetricBuilder
-
- Persist - Class in water.persist
-
Abstract class describing various persistence targets.
- Persist() - Constructor for class water.persist.Persist
-
- Persist.Schemes - Class in water.persist
-
Persistence schemes; used as file prefixes eg "hdfs://some_hdfs_path/some_file"
- Persist.Schemes() - Constructor for class water.persist.Persist.Schemes
-
- PersistHdfs - Class in water.persist
-
HDFS persistence layer.
- PersistNFS - Class in water.persist
-
- PersistNFS() - Constructor for class water.persist.PersistNFS
-
- PersistS3 - Class in water.persist
-
Persistence backend for S3
- PersistS3() - Constructor for class water.persist.PersistS3
-
- Phaser - Class in jsr166y
-
A reusable synchronization barrier, similar in functionality to
CyclicBarrier
and
CountDownLatch
but supporting more flexible usage.
- Phaser() - Constructor for class jsr166y.Phaser
-
Creates a new phaser with no initially registered parties, no
parent, and initial phase number 0.
- Phaser(int) - Constructor for class jsr166y.Phaser
-
Creates a new phaser with the given number of registered
unarrived parties, no parent, and initial phase number 0.
- Phaser(Phaser) - Constructor for class jsr166y.Phaser
-
- Phaser(Phaser, int) - Constructor for class jsr166y.Phaser
-
Creates a new phaser with the given parent and number of
registered unarrived parties.
- pid - Variable in class water.api.CloudV1.NodeV1
-
- PID - Static variable in class water.H2O
-
- pinfs - Variable in class water.api.FrameV2.ColV2
-
- pinfs() - Method in class water.fvec.Vec
-
Count of positive infinities
- pj(double) - Method in class water.util.SB
-
- pj(float) - Method in class water.util.SB
-
- pj(String) - Method in class water.util.SB
-
- pobj(Object) - Method in class water.util.SB
-
- PojoUtils - Class in water.util
-
POJO utilities which cover cases similar to but not the same as Aapche Commons PojoUtils.
- PojoUtils() - Constructor for class water.util.PojoUtils
-
- PojoUtils.FieldNaming - Enum in water.util
-
- poll() - Method in class jsr166y.ConcurrentLinkedDeque
-
- poll(long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
-
- poll() - Method in class jsr166y.LinkedTransferQueue
-
- pollFirst() - Method in class jsr166y.ConcurrentLinkedDeque
-
- pollLast() - Method in class jsr166y.ConcurrentLinkedDeque
-
- pollNextLocalTask() - Static method in class jsr166y.ForkJoinTask
-
Unschedules and returns, without executing, the next task
queued by the current thread but not yet executed.
- pollSubmission() - Method in class jsr166y.ForkJoinPool
-
Removes and returns the next unexecuted submission if one is
available.
- pollTask() - Static method in class jsr166y.ForkJoinTask
-
Unschedules and returns, without executing, the next task
queued by the current thread but not yet executed, if one is
available, or if not available, a task that was forked by some
other thread, if available.
- pop() - Method in class jsr166y.ConcurrentLinkedDeque
-
- pop() - Method in class water.rapids.Env
-
- pop(int) - Method in class water.rapids.Env
-
- pop2AST() - Method in class water.rapids.Env
-
- popAry() - Method in class water.rapids.Env
-
- popDbl() - Method in class water.rapids.Env
-
- poppush(int, Val) - Method in class water.rapids.Env
-
- popSeries() - Method in class water.rapids.Env
-
- popSpan() - Method in class water.rapids.Env
-
- popStr() - Method in class water.rapids.Env
-
- port - Variable in class water.H2O.OptArgs
-
-port=####; Specific Browser/API/HTML port
- portPack() - Method in class water.init.TimelineSnapshot.Event
-
- position() - Method in class water.AutoBuffer
-
- positive_response - Variable in class hex.CreateFrame
-
- POSSIBLE_CURRENCY - Static variable in class water.parser.Parser
-
- POSSIBLE_EMPTY_LINE - Static variable in class water.parser.Parser
-
- POST(int, String) - Static method in class water.util.Log
-
POST stands for "Power on self test".
- POST(int, Exception) - Static method in class water.util.Log
-
- postGlobal() - Method in class water.MRTask
-
- postGlobal() - Method in class water.util.ChunkSummary
-
- postWrite(Futures) - Method in class water.fvec.Frame
-
Allow rollups for all written-into vecs; used by
MRTask
once
writing is complete.
- postWrite(Futures) - Method in class water.fvec.Vec
-
Stop writing into this Vec.
- postWrite() - Method in class water.rapids.Env
-
- pow10(int) - Static method in class water.util.PrettyPrint
-
- pow10i(int) - Static method in class water.util.PrettyPrint
-
- powers10i - Static variable in class water.util.PrettyPrint
-
- pprint(double[][]) - Static method in class water.util.ArrayUtils
-
- pprint(double[][], DecimalFormat) - Static method in class water.util.ArrayUtils
-
- precision - Variable in class hex.AUCData
-
- precision(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- precision() - Method in class hex.AUCData
-
- precision() - Method in class hex.ConfusionMatrix
-
The percentage of positive predictions that are correct.
- precision - Variable in class water.api.AUCBase
-
- precision - Variable in class water.api.FrameV2.ColV2
-
- precision() - Method in class water.fvec.Chunk
-
Fixed-width format printing support.
- precision_for_criteria - Variable in class water.api.AUCBase
-
- predict - Variable in class hex.AUC
-
- predict - Variable in class hex.HitRatio
-
- prediction_error - Variable in class water.api.ConfusionMatrixBase
-
- prediction_error_by_class - Variable in class water.api.ConfusionMatrixBase
-
- predictions - Variable in class water.api.ModelMetricsBase
-
- prefetch(Key) - Static method in class water.DKV
-
Prefetch and cache the Value for Key key.
- prefetch(String) - Static method in class water.DKV
-
Prefetch and cache the Value for Key formed by key_name.
- PREFIX_OPS - Static variable in class water.rapids.ASTOp
-
- prepend(String[], String) - Static method in class water.util.ArrayUtils
-
- PrettyPrint - Class in water.util
-
- PrettyPrint() - Constructor for class water.util.PrettyPrint
-
- preWriting() - Method in class water.fvec.Vec
-
Begin writing into this Vec.
- PRIM_B - Static variable in class water.TypeMap
-
- PRIMES - Static variable in class water.util.MathUtils
-
- print() - Method in class water.init.AbstractEmbeddedH2OConfig
-
Print debug information.
- printx16(long, long) - Static method in class water.UDP
-
- priority() - Method in class water.api.RemoveAllHandler.RemoveAllTask
-
- priority() - Method in class water.api.UnlockTask
-
- priority() - Method in class water.Atomic
-
- priority() - Method in class water.H2O.H2OCountedCompleter
-
- priority() - Method in class water.MRTask
-
- priority() - Method in class water.TaskGetKey
-
- priority() - Method in class water.TaskPutKey
-
- priority() - Method in class water.util.FileIntegrityChecker
-
- priority() - Method in class water.util.JStackCollectorTask
-
- priority() - Method in class water.util.ProfileCollectorTask
-
- profile - Variable in class water.util.JProfile.ProfileSummary
-
- ProfileCollectorTask - Class in water.util
-
- ProfileCollectorTask(int) - Constructor for class water.util.ProfileCollectorTask
-
- ProfileCollectorTask.NodeProfile - Class in water.util
-
- ProfilerHandler - Class in water.api
-
- ProfilerHandler() - Constructor for class water.api.ProfilerHandler
-
- ProfilerNodeV2 - Class in water.api
-
- ProfilerNodeV2() - Constructor for class water.api.ProfilerNodeV2
-
- ProfilerNodeV2.ProfilerNodeEntryV2 - Class in water.api
-
- ProfilerNodeV2.ProfilerNodeEntryV2() - Constructor for class water.api.ProfilerNodeV2.ProfilerNodeEntryV2
-
- ProfilerV2 - Class in water.api
-
- ProfilerV2() - Constructor for class water.api.ProfilerV2
-
- profString() - Method in class water.MRTask
-
- progress() - Method in class hex.DMatrix.MatrixMulStats
-
- progress - Variable in class water.api.JobV2
-
- progress() - Method in class water.Job
-
Returns a float from 0 to 1 representing progress.
- progress() - Method in class water.Job.Progress
-
Report Job progress from 0 to 1.
- projectVersion() - Method in class water.init.AbstractBuildVersion
-
- projectVersion() - Method in class water.init.BuildVersion
-
- PROPOSED - Static variable in class water.Paxos
-
- providesFlatfile() - Method in class water.init.AbstractEmbeddedH2OConfig
-
Whether H2O gets a flatfile config from this config object.
- ps(String) - Method in class water.util.SB
-
- pType - Variable in class water.parser.ParseSetupV2
-
- push(E) - Method in class jsr166y.ConcurrentLinkedDeque
-
- push(Val) - Method in class water.rapids.Env
-
- pushAry(Frame) - Method in class water.rapids.Env
-
- pushHelper(Val, Env.SymbolTable) - Method in class water.rapids.Env
-
- put(E) - Method in class jsr166y.LinkedTransferQueue
-
Inserts the specified element at the tail of this queue.
- put(int, NodePersistentStorageV1) - Method in class water.api.NodePersistentStorageHandler
-
- put(Freezable) - Method in class water.AutoBuffer
-
- put(Key, Iced) - Static method in class water.DKV
-
Make the mapping key -> v.
- put(Key, Iced, Futures) - Static method in class water.DKV
-
Make the mapping key -> v.
- put(Key, Iced, Futures, boolean) - Static method in class water.DKV
-
Make the mapping key -> v.
- put(Keyed) - Static method in class water.DKV
-
Make the mapping keyed._key -> keyed.
- put(Keyed, Futures) - Static method in class water.DKV
-
Make the mapping keyed._key -> keyed.
- put(Key, Value) - Static method in class water.DKV
-
Make the mapping key -> val.
- put(Key, Value, Futures) - Static method in class water.DKV
-
Make the mapping key -> val.
- put(Key, Value, Futures, boolean) - Static method in class water.DKV
-
Make the mapping key -> val.
- put(String, String, InputStream) - Method in class water.init.NodePersistentStorage
-
- put(String, String, String) - Method in class water.init.NodePersistentStorage
-
- put(String, Freezable) - Method in class water.util.DocGen.HTML
-
- put(K, V) - Method in class water.util.IcedHashMap
-
- put1(int) - Method in class water.AutoBuffer
-
- put1(String, byte) - Method in class water.util.DocGen.HTML
-
- put2(char) - Method in class water.AutoBuffer
-
- put2(short) - Method in class water.AutoBuffer
-
- put2(String, char) - Method in class water.util.DocGen.HTML
-
- put2(String, short) - Method in class water.util.DocGen.HTML
-
- put3(int) - Method in class water.AutoBuffer
-
- put4(int) - Method in class water.AutoBuffer
-
- put4(String, int) - Method in class water.util.DocGen.HTML
-
- put4f(float) - Method in class water.AutoBuffer
-
- put4f(String, float) - Method in class water.util.DocGen.HTML
-
- put8(long) - Method in class water.AutoBuffer
-
- put8(String, long) - Method in class water.util.DocGen.HTML
-
- put8d(double) - Method in class water.AutoBuffer
-
- put8d(String, double) - Method in class water.util.DocGen.HTML
-
- PUT_KEY_PRIORITY - Static variable in class water.H2O
-
- put_with_name(int, NodePersistentStorageV1) - Method in class water.api.NodePersistentStorageHandler
-
- putA(Freezable[]) - Method in class water.AutoBuffer
-
- putA(String, Freezable[]) - Method in class water.util.DocGen.HTML
-
- putA1(byte[]) - Method in class water.AutoBuffer
-
- putA1(byte[], int) - Method in class water.AutoBuffer
-
- putA1(byte[], int, int) - Method in class water.AutoBuffer
-
- putA1(String, byte[]) - Method in class water.util.DocGen.HTML
-
- putA2(String, short[]) - Method in class water.util.DocGen.HTML
-
- putA4(int[]) - Method in class water.AutoBuffer
-
- putA4(String, int[]) - Method in class water.util.DocGen.HTML
-
- putA4f(float[]) - Method in class water.AutoBuffer
-
- putA4f(String, float[]) - Method in class water.util.DocGen.HTML
-
- putA8(long[]) - Method in class water.AutoBuffer
-
- putA8(String, long[]) - Method in class water.util.DocGen.HTML
-
- putA8d(double[]) - Method in class water.AutoBuffer
-
- putA8d(String, double[]) - Method in class water.util.DocGen.HTML
-
- putAA(Freezable[][]) - Method in class water.AutoBuffer
-
- putAA(String, Freezable[][]) - Method in class water.util.DocGen.HTML
-
- putAA4(int[][]) - Method in class water.AutoBuffer
-
- putAA4(String, int[][]) - Method in class water.util.DocGen.HTML
-
- putAA4f(float[][]) - Method in class water.AutoBuffer
-
- putAA4f(String, float[][]) - Method in class water.util.DocGen.HTML
-
- putAA8(long[][]) - Method in class water.AutoBuffer
-
- putAA8(String, long[][]) - Method in class water.util.DocGen.HTML
-
- putAA8d(double[][]) - Method in class water.AutoBuffer
-
- putAA8d(String, double[][]) - Method in class water.util.DocGen.HTML
-
- putAAA8(long[][][]) - Method in class water.AutoBuffer
-
- putAAA8(String, long[][][]) - Method in class water.util.DocGen.HTML
-
- putAAASer(Object[][][]) - Method in class water.AutoBuffer
-
- putAASer(Object[][]) - Method in class water.AutoBuffer
-
- putAAStr(String[][]) - Method in class water.AutoBuffer
-
- putAAStr(String, String[][]) - Method in class water.util.DocGen.HTML
-
- putAEnum(String, Enum[]) - Method in class water.AutoBuffer
-
- putAEnum(Enum[]) - Method in class water.AutoBuffer
-
- putAEnum(String, Enum[]) - Method in class water.util.DocGen.HTML
-
- putAll(Map<? extends K, ? extends V>) - Method in class water.util.IcedHashMap
-
- putASer(Object[]) - Method in class water.AutoBuffer
-
- putAStr(String[]) - Method in class water.AutoBuffer
-
- putAStr(String, String[]) - Method in class water.util.DocGen.HTML
-
- putEnum(Enum) - Method in class water.AutoBuffer
-
- putEnum(String, Enum) - Method in class water.util.DocGen.HTML
-
- putIfAbsent(K, V) - Method in class water.util.IcedHashMap
-
- putIfMatch(Key, Value, Value) - Static method in class water.H2O
-
- putJNULL() - Method in class water.AutoBuffer
-
- putJSON(Freezable) - Method in class water.AutoBuffer
-
- putJSON(String, Freezable) - Method in class water.AutoBuffer
-
- putJSON1(byte) - Method in class water.AutoBuffer
-
- putJSON1(String, byte) - Method in class water.AutoBuffer
-
- putJSON4(String, int) - Method in class water.AutoBuffer
-
- putJSON4f(String, float) - Method in class water.AutoBuffer
-
- putJSON8(String, long) - Method in class water.AutoBuffer
-
- putJSON8d(String, double) - Method in class water.AutoBuffer
-
- putJSONA(Freezable[]) - Method in class water.AutoBuffer
-
- putJSONA(String, Freezable[]) - Method in class water.AutoBuffer
-
- putJSONA1(byte[]) - Method in class water.AutoBuffer
-
- putJSONA1(String, byte[]) - Method in class water.AutoBuffer
-
- putJSONA2(String, short[]) - Method in class water.AutoBuffer
-
- putJSONA4(String, int[]) - Method in class water.AutoBuffer
-
- putJSONA4f(String, float[]) - Method in class water.AutoBuffer
-
- putJSONA8(String, long[]) - Method in class water.AutoBuffer
-
- putJSONA8d(double[]) - Method in class water.AutoBuffer
-
- putJSONA8d(String, double[]) - Method in class water.AutoBuffer
-
- putJSONAA(String, Freezable[][]) - Method in class water.AutoBuffer
-
- putJSONAA1(String, byte[][]) - Method in class water.AutoBuffer
-
- putJSONAA4(String, int[][]) - Method in class water.AutoBuffer
-
- putJSONAA8(String, long[][]) - Method in class water.AutoBuffer
-
- putJSONAA8d(String, double[][]) - Method in class water.AutoBuffer
-
- putJSONAAA8(String, long[][][]) - Method in class water.AutoBuffer
-
- putJSONAAASer(String, Object[][][]) - Method in class water.AutoBuffer
-
- putJSONAASer(String, Object[][]) - Method in class water.AutoBuffer
-
- putJSONAAStr(String, String[][]) - Method in class water.AutoBuffer
-
- putJSONAEnum(String, Enum[]) - Method in class water.AutoBuffer
-
- putJSONAEnum(Enum[]) - Method in class water.AutoBuffer
-
- putJSONASer(String, Object[]) - Method in class water.AutoBuffer
-
- putJSONAStr(String[]) - Method in class water.AutoBuffer
-
- putJSONAStr(String, String[]) - Method in class water.AutoBuffer
-
- putJSONEnum(String, Enum) - Method in class water.AutoBuffer
-
- putJSONName(String) - Method in class water.AutoBuffer
-
- putJSONSer(String, Object) - Method in class water.AutoBuffer
-
- putJSONStr(String) - Method in class water.AutoBuffer
-
- putJSONStr(String, String) - Method in class water.AutoBuffer
-
- putJSONStrUnquoted(String) - Method in class water.AutoBuffer
-
- putJSONStrUnquoted(String, String) - Method in class water.AutoBuffer
-
- putJSONZ(String, boolean) - Method in class water.AutoBuffer
-
- putSer(Object) - Method in class water.AutoBuffer
-
- putSer(String, Serializable) - Method in class water.util.DocGen.HTML
-
- putStr(String) - Method in class water.AutoBuffer
-
- putStr(String, String) - Method in class water.util.DocGen.HTML
-
- putZ(boolean) - Method in class water.AutoBuffer
-
- putZ(String, boolean) - Method in class water.util.DocGen.HTML
-
- r2() - Method in class hex.ModelMetrics
-
- Raft - Class in water.rapids
-
- Raft() - Constructor for class water.rapids.Raft
-
- rand() - Static method in class water.Key
-
A random string, useful as a Key name or partial Key suffix.
- random_udp_drop - Variable in class water.H2O.OptArgs
-
-random_udp_drop, -random_udp_drop=true; test only, randomly drop udp incoming
- randomize - Variable in class hex.CreateFrame
-
- RandomUtils - Class in water.util
-
- RandomUtils() - Constructor for class water.util.RandomUtils
-
- RandomUtils.H2ORandomRNG - Class in water.util
-
- RandomUtils.H2ORandomRNG(long) - Constructor for class water.util.RandomUtils.H2ORandomRNG
-
- RandomUtils.H2ORandomRNG.RNGKind - Enum in water.util
-
- RandomUtils.H2ORandomRNG.RNGType - Enum in water.util
-
- RandomUtils.MersenneTwisterRNG - Class in water.util
-
Random number generator based on the
Mersenne Twister algorithm developed by Makoto Matsumoto
and Takuji Nishimura.
- RandomUtils.MersenneTwisterRNG(int...) - Constructor for class water.util.RandomUtils.MersenneTwisterRNG
-
Creates an RNG and seeds it with the specified seed data.
- RandomUtils.XorShiftRNG - Class in water.util
-
Simple XorShiftRNG.
- RandomUtils.XorShiftRNG(long) - Constructor for class water.util.RandomUtils.XorShiftRNG
-
- RapidsV1 - Class in water.api
-
- RapidsV1() - Constructor for class water.api.RapidsV1
-
- read(AutoBuffer) - Method in interface water.Freezable
-
Standard "read thyself from the AutoBuffer" call, using the fast Iced protocol.
- read(AutoBuffer) - Method in class water.H2O.H2OCountedCompleter
-
- read(AutoBuffer) - Method in class water.Iced
-
Standard "read thyself from the AutoBuffer" call, using the fast Iced protocol.
- read(AutoBuffer, T) - Method in class water.Icer
-
- read(AutoBuffer) - Method in class water.util.IcedArrayList
-
- read() - Method in class water.util.LinuxProcFileReader
-
Read and parse data from /proc/stat and /proc/<pid>/stat.
- read2(AutoBuffer, T) - Method in class water.Icer
-
- read3(AutoBuffer, T) - Method in class water.Icer
-
- read_impl(AutoBuffer) - Method in interface water.Freezable
-
Implementation of the
Iced
serialization protocol, only called by
auto-genned code.
- read_impl(AutoBuffer) - Method in class water.fvec.Chunk
-
Custom deserializers, implemented by Chunk subclasses: the _mem field
contains ALL the fields already.
- read_impl(AutoBuffer) - Method in class water.fvec.NewChunk
-
- read_impl(AutoBuffer) - Method in class water.fvec.Vec.CollectDomain
-
- read_impl(AutoBuffer) - Method in class water.H2O.H2OCountedCompleter
-
- read_impl(AutoBuffer) - Method in class water.H2ONode
-
- read_impl(AutoBuffer) - Method in class water.Iced
-
Implementation of the
Iced
serialization protocol, only called by
auto-genned code.
- read_impl(AutoBuffer) - Method in class water.Key
-
Implementation of the
Iced
serialization protocol, only called by
auto-genned code.
- read_impl(AutoBuffer) - Method in class water.parser.Categorical
-
- read_impl(AutoBuffer) - Method in class water.rapids.ASTddply.ddplyPass1
-
- read_impl(AutoBuffer) - Method in class water.util.IcedArrayList
-
- read_impl(AutoBuffer) - Method in class water.util.IcedHashMap
-
- read_impl(AutoBuffer) - Method in class water.Value
-
- read_lock(Key, Key) - Static method in class water.Lockable
-
Atomically get a read-lock on Key k, preventing future deletes or updates
- read_lock(Key) - Method in class water.Lockable
-
Atomically get a read-lock on this, preventing future deletes or updates
- read_lock_frames(Job) - Method in class hex.Model.Parameters
-
Read-Lock both training and validation User frames.
- read_unlock_frames(Job) - Method in class hex.Model.Parameters
-
Read-UnLock both training and validation User frames.
- readable() - Method in class water.fvec.AppendableVec
-
- readExternal(ObjectInput) - Method in class water.Iced
-
- readJSON(AutoBuffer) - Method in interface water.Freezable
-
Standard "read thyself from the AutoBuffer" call, using JSON.
- readJSON(AutoBuffer) - Method in class water.H2O.H2OCountedCompleter
-
- readJSON(AutoBuffer) - Method in class water.Iced
-
Standard "read thyself from the AutoBuffer" call, using JSON.
- readJSON(AutoBuffer, T) - Method in class water.Icer
-
- readJSON(AutoBuffer) - Method in class water.util.IcedArrayList
-
- readJSON2(AutoBuffer, T) - Method in class water.Icer
-
- readJSON3(AutoBuffer, T) - Method in class water.Icer
-
- readJSON_impl(AutoBuffer) - Method in interface water.Freezable
-
Implementation of the
Iced
serialization protocol, only called by
auto-genned code.
- readJSON_impl(AutoBuffer) - Method in class water.H2O.H2OCountedCompleter
-
- readJSON_impl(AutoBuffer) - Method in class water.H2ONode
-
- readJSON_impl(AutoBuffer) - Method in class water.Iced
-
Implementation of the
Iced
serialization protocol, only called by
auto-genned code.
- readJSON_impl(AutoBuffer) - Method in class water.parser.Categorical
-
- readJSON_impl(AutoBuffer) - Method in class water.util.IcedArrayList
-
- readJSON_impl(AutoBuffer) - Method in class water.util.IcedHashMap
-
- readPut(String, InputStream, UploadFileVec.ReadPutStats) - Static method in class water.fvec.UploadFileVec
-
- readPut(Key, InputStream, UploadFileVec.ReadPutStats) - Static method in class water.fvec.UploadFileVec
-
- real_range - Variable in class hex.CreateFrame
-
- RebalanceDataSet - Class in water.fvec
-
Created by tomasnykodym on 3/28/14.
- RebalanceDataSet(Frame, Frame, Key) - Constructor for class water.fvec.RebalanceDataSet
-
Constructor for make-compatible task.
- RebalanceDataSet(Frame, Frame, Key, H2O.H2OCountedCompleter, Key) - Constructor for class water.fvec.RebalanceDataSet
-
- RebalanceDataSet(Frame, Key, int) - Constructor for class water.fvec.RebalanceDataSet
-
- RebalanceDataSet(Frame, Key, int, H2O.H2OCountedCompleter, Key) - Constructor for class water.fvec.RebalanceDataSet
-
- RebalanceDataSet.RebalanceTask - Class in water.fvec
-
- RebalanceDataSet.RebalanceTask(H2O.H2OCountedCompleter, Vec...) - Constructor for class water.fvec.RebalanceDataSet.RebalanceTask
-
- recall - Variable in class hex.AUCData
-
- recall(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- recall() - Method in class hex.AUCData
-
- recall() - Method in class hex.ConfusionMatrix
-
The percentage of positive labeled instances that were predicted as positive.
- recall - Variable in class water.api.AUCBase
-
- recall_for_criteria - Variable in class water.api.AUCBase
-
- recoH2O() - Method in class water.init.TimelineSnapshot.Event
-
- reComputeErrors() - Method in class hex.ConfusionMatrix
-
- record_IOclose(long, long, int, long, int) - Static method in class water.TimeLine
-
- RecursiveAction - Class in jsr166y
-
- RecursiveAction() - Constructor for class jsr166y.RecursiveAction
-
- RecursiveTask<V> - Class in jsr166y
-
- RecursiveTask() - Constructor for class jsr166y.RecursiveTask
-
- reduce(ModelMetrics.MetricBuilder) - Method in class hex.ModelMetrics.MetricBuilder
-
- reduce(AppendableVec) - Method in class water.fvec.AppendableVec
-
- reduce(Vec.CollectDomain) - Method in class water.fvec.Vec.CollectDomain
-
- reduce(T) - Method in class water.MRTask
-
Override to combine results from 'mrt' into 'this' MRTask.
- reduce(ParseSetup.GuessSetupTsk) - Method in class water.parser.ParseSetup.GuessSetupTsk
-
- reduce(Quantiles.BinningTask) - Method in class water.Quantiles.BinningTask
-
- reduce(ASTddply.ddplyPass1) - Method in class water.rapids.ASTddply.ddplyPass1
-
- reduce(ChunkSummary) - Method in class water.util.ChunkSummary
-
- reduce(FileIntegrityChecker) - Method in class water.util.FileIntegrityChecker
-
- reduce(JStackCollectorTask) - Method in class water.util.JStackCollectorTask
-
- reduce(ProfileCollectorTask) - Method in class water.util.ProfileCollectorTask
-
- reduce4(T) - Method in class water.MRTask
-
Call user's reduction.
- ReflectionUtils - Class in water.util
-
- ReflectionUtils() - Constructor for class water.util.ReflectionUtils
-
- register() - Method in class jsr166y.Phaser
-
Adds a new unarrived party to this phaser.
- register(String, String, Class<? extends Handler>, String, String) - Static method in class water.api.RequestServer
-
Deprecated.
- register(String, String, Class<? extends Handler>, String, String[], String) - Static method in class water.api.RequestServer
-
Deprecated.
- register(String, String, Class<? extends Handler>, String, String, String) - Static method in class water.api.RequestServer
-
Register an HTTP request handler for a given URI pattern, with no path parameters.
- register(String, String, Class<? extends Handler>, String, String, String[], String) - Static method in class water.api.RequestServer
-
Register an HTTP request handler method for a given URL pattern, with parameters extracted from the URI.
- register(Class<? extends Schema>) - Static method in class water.api.Schema
-
Register the given schema class.
- registerAllSchemasIfNecessary() - Static method in class water.api.Schema
-
Find all schemas using reflection and register them.
- registerGET(String, Class, String, String, String, String, String) - Static method in class water.H2O
-
- registerModelBuilder(String, Class<? extends ModelBuilder>) - Static method in class hex.ModelBuilder
-
Register a ModelBuilder, assigning it an algo name.
- registerPOST(String, Class, String, String) - Static method in class water.H2O
-
- registerResourceRoot(File) - Static method in class water.H2O
-
- registerResourceRoot(File) - Static method in class water.init.JarHash
-
- reinitialize() - Method in class jsr166y.ForkJoinTask
-
Resets the internal bookkeeping state of this task, allowing a
subsequent fork
.
- rel_dist() - Method in class water.util.MRUtils.ClassDist
-
- reloadVecs() - Method in class water.fvec.Frame
-
Force a cache-flush and reload, assuming vec mappings were altered
remotely, or that the _vecs array was shared and now needs to be a
defensive copy.
- remainingCapacity() - Method in class jsr166y.LinkedTransferQueue
-
Always returns Integer.MAX_VALUE
because a
LinkedTransferQueue
is not capacity constrained.
- remove() - Method in class jsr166y.ConcurrentLinkedDeque
-
- remove(Object) - Method in class jsr166y.ConcurrentLinkedDeque
-
Removes the first element e
such that
o.equals(e)
, if such an element exists in this deque.
- remove(Object) - Method in class jsr166y.LinkedTransferQueue
-
Removes a single instance of the specified element from this queue,
if it is present.
- remove(int, RemoveAllV1) - Method in class water.api.RemoveAllHandler
-
- remove(int, RemoveV1) - Method in class water.api.RemoveHandler
-
- remove(Key) - Static method in class water.DKV
-
Remove any mapping for key.
- remove(Key, Futures) - Static method in class water.DKV
-
Remove any mapping for key.
- remove(String) - Method in class water.fvec.Frame
-
Removes the column with a matching name.
- remove(String[]) - Method in class water.fvec.Frame
-
- remove(int[]) - Method in class water.fvec.Frame
-
Removes a list of columns by index; the index list must be sorted
- remove(int) - Method in class water.fvec.Frame
-
Removes a numbered column.
- remove() - Method in class water.init.TimelineSnapshot
-
- remove() - Method in class water.Key
-
Remove a Key from the DKV, including any embedded Keys.
- remove(Futures) - Method in class water.Key
-
- remove() - Method in class water.Keyed
-
Remove this Keyed object, and all subparts; blocking.
- remove(Futures) - Method in class water.Keyed
-
Remove this Keyed object, and all subparts.
- remove(Key) - Static method in class water.Keyed
-
Remove this Keyed object, and all subparts; blocking.
- remove(Key, Futures) - Static method in class water.Keyed
-
Remove this Keyed object, and all subparts.
- remove(Object, Object) - Method in class water.util.IcedHashMap
-
- remove(Object) - Method in class water.util.IcedHashMap
-
- remove_and_unlock() - Method in class water.rapids.Env
-
- remove_impl(Futures) - Method in class hex.Model
-
- remove_impl(Futures) - Method in class water.fvec.Frame
-
Actually remove/delete all Vecs from memory, not just from the Frame.
- remove_impl(Futures) - Method in class water.fvec.SubsetVec
-
- remove_impl(Futures) - Method in class water.fvec.Vec
-
Remove associated Keys when this guy removes.
- remove_impl(Futures) - Method in class water.Job
-
- remove_impl(Futures) - Method in class water.Keyed
-
Override to remove subparts, but not self, of composite Keyed objects.
- RemoveAllHandler - Class in water.api
-
- RemoveAllHandler() - Constructor for class water.api.RemoveAllHandler
-
- RemoveAllHandler.RemoveAllTask - Class in water.api
-
- RemoveAllHandler.RemoveAllTask() - Constructor for class water.api.RemoveAllHandler.RemoveAllTask
-
- RemoveAllV1 - Class in water.api
-
- RemoveAllV1() - Constructor for class water.api.RemoveAllV1
-
- removeFirst() - Method in class jsr166y.ConcurrentLinkedDeque
-
- removeFirstOccurrence(Object) - Method in class jsr166y.ConcurrentLinkedDeque
-
Removes the first element e
such that
o.equals(e)
, if such an element exists in this deque.
- RemoveHandler - Class in water.api
-
- RemoveHandler() - Constructor for class water.api.RemoveHandler
-
- removeLast() - Method in class jsr166y.ConcurrentLinkedDeque
-
- removeLastOccurrence(Object) - Method in class jsr166y.ConcurrentLinkedDeque
-
Removes the last element e
such that
o.equals(e)
, if such an element exists in this deque.
- RemoveV1 - Class in water.api
-
- RemoveV1() - Constructor for class water.api.RemoveV1
-
- repeats - Variable in class water.init.NetworkTest.NetworkTester
-
- repeats - Variable in class water.init.NetworkTest
-
- replace(int, Vec) - Method in class water.fvec.Frame
-
Replace one column with another.
- replace(K, V, V) - Method in class water.util.IcedHashMap
-
- replace(K, V) - Method in class water.util.IcedHashMap
-
- replace(String, Key) - Method in class water.util.RString
-
- replace(String, Object) - Method in class water.util.RString
-
- REPLACEMENTS - Static variable in class water.util.SB
-
- reportBrokenEnum(int, int, long, int[][], int) - Method in class water.fvec.Chunk
-
Used by the parser to help report various internal bugs.
- RequestServer - Class in water.api
-
This is a simple web server which accepts HTTP requests and routes them
to methods in Handler classes for processing.
- requestShutdown() - Static method in class water.H2O
-
- required - Variable in class water.api.ModelParameterSchemaV2
-
- reserveKeys(int) - Method in class water.fvec.Vec.VectorGroup
-
Reserve a range of keys and return index of first new available key
- response() - Method in class hex.SupervisedModelBuilder
-
- response(AutoBuffer) - Method in class water.RPC
-
- response_column - Variable in class water.api.SupervisedModelParametersSchema
-
- response_factors - Variable in class hex.CreateFrame
-
- responseName() - Method in class hex.Model.Output
-
The name of the response column (which is always the last column).
- restructure(String[], Vec[]) - Method in class water.fvec.Frame
-
Restructure a Frame completely
- result - Variable in class water.api.QuantilesV1
-
- rollbackLine() - Method in class water.parser.Parser.InspectDataOut
-
- RouteBase<I extends water.api.Route,S extends RouteBase<I,S>> - Class in water.api
-
- RouteBase() - Constructor for class water.api.RouteBase
-
- routes - Variable in class water.api.DocsBase
-
- routes() - Static method in class water.api.RequestServer
-
- RouteV1 - Class in water.api
-
- RouteV1() - Constructor for class water.api.RouteV1
-
- rowHeaders - Variable in class water.api.TwoDimTableV1
-
- rowId0() - Method in class water.fvec.NewChunk.Value
-
- rows - Variable in class hex.CreateFrame
-
- rows - Variable in class water.api.FrameV2
-
- rows() - Method in class water.fvec.SubsetVec
-
- RPC<V extends DTask> - Class in water
-
A remotely executed FutureTask.
- RPC(H2ONode, V) - Constructor for class water.RPC
-
- rpcs_active - Variable in class water.api.CloudV1.NodeV1
-
- RString - Class in water.util
-
A replaceable string that allows very easy and simple replacements.
- RString(String) - Constructor for class water.util.RString
-
- run() - Method in class jsr166y.ForkJoinWorkerThread
-
This method is required to be public, but should never be
called explicitly.
- run(int, CreateFrameV2) - Method in class water.api.CreateFrameHandler
-
- run() - Method in class water.HeartBeatThread
-
- run(int) - Static method in class water.init.Linpack
-
Compute system CPU speed in Gflops
- run(int) - Static method in class water.init.MemoryBandwidth
-
Compute memory bandwidth in bytes / second
- run() - Method in class water.TCPReceiverThread
-
- run() - Method in class water.UDPReceiverThread
-
- run() - Method in class water.UDPTimeOutThread
-
- run_benchmark() - Method in class water.init.Linpack
-
- s() - Method in class water.util.SB
-
- S3 - Static variable in class water.persist.Persist.Schemes
-
- S3 - Static variable in class water.Value
-
- sameGroup(Vec, Vec) - Static method in class water.fvec.Vec.VectorGroup
-
- sampleFrame(Frame, long, long) - Static method in class water.util.MRUtils
-
Sample rows from a frame.
- sampleFrameStratified(Frame, Vec, float[], long, long, boolean, boolean) - Static method in class water.util.MRUtils
-
Stratified sampling for classifiers
- sampleFrameStratified(Frame, Vec, float[], long, boolean) - Static method in class water.util.MRUtils
-
Stratified sampling
- sampleOOBRows(int, float, Random) - Static method in class water.util.ModelUtils
-
Sample out-of-bag rows with given rate with help of given sampler.
- sampleOOBRows(int, float, Random, int[]) - Static method in class water.util.ModelUtils
-
- sanityCheck() - Method in class water.api.QuantilesV1
-
- SB - Class in water.util
-
Tight/tiny StringBuilder wrapper.
- SB() - Constructor for class water.util.SB
-
- SB(String) - Constructor for class water.util.SB
-
- scaled() - Method in class hex.VarImp
-
- scaled_values() - Method in class hex.VarImp.VarImpRI
-
- schema() - Method in class hex.Model
-
Externally visible default schema
TODO: this is in the wrong layer: the internals should not know anything about the schemas!!!
This puts a reverse edge into the dependency graph.
- schema() - Method in class hex.ModelBuilder
-
Externally visible default schema
TODO: this is in the wrong layer: the internals should not know anything about the schemas!!!
This puts a reverse edge into the dependency graph.
- schema() - Method in class hex.ModelMetrics
-
Externally visible default schema
TODO: this is in the wrong layer: the internals should not know anything about the schemas!!!
This puts a reverse edge into the dependency graph.
- Schema<I extends Iced,S extends Schema<I,S>> - Class in water.api
-
Base Schema Class.
- Schema() - Constructor for class water.api.Schema
-
- schema(int, Iced) - Static method in class water.api.Schema
-
For a given version and Iced object return an appropriate Schema instance, if any.
- schema(int, Class<? extends Iced>) - Static method in class water.api.Schema
-
For a given version and Iced class return an appropriate Schema instance, if any.
- schema(int, String) - Static method in class water.api.Schema
-
For a given version and type (Iced class simpleName) return an appropriate new Schema
object, if any.
- schema(String) - Static method in class water.api.Schema
-
For a given schema_name (e.g., "FrameV2") return an appropriate new schema object (e.g., a water.api.Framev2).
- schema(Class<? extends Schema>) - Static method in class water.api.Schema
-
For a given schema class (e.g., water.api.FrameV2) return a new instance (e.g., a water.api.Framev2).
- Schema.Meta - Class in water.api
-
- Schema.Meta() - Constructor for class water.api.Schema.Meta
-
- Schema.Meta(int, String, String) - Constructor for class water.api.Schema.Meta
-
- schema_name - Variable in class water.api.Schema.Meta
-
The simple schema (class) name, e.g.
- schema_name - Variable in class water.api.SchemaMetadata.FieldMetadata
-
Schema name for this field, if it is_schema.
- schema_type - Variable in class water.api.Schema.Meta
-
- schema_version - Variable in class water.api.Schema.Meta
-
- schemaClass(int, Iced) - Static method in class water.api.Schema
-
For a given version and Iced object return the appropriate Schema class, if any.
- schemaClass(int, Class<? extends Iced>) - Static method in class water.api.Schema
-
For a given version and Iced class return the appropriate Schema class, if any.
- schemaClass(int, String) - Static method in class water.api.Schema
-
For a given version and type (Iced class simpleName) return the appropriate Schema
class, if any.
- schemaClass(String) - Static method in class water.api.Schema
-
For a given schema_name (e.g., "FrameV2") return the schema class (e.g., water.api.Framev2).
- SchemaMetadata - Class in water.api
-
The metadata info on all the fields in a Schema.
- SchemaMetadata() - Constructor for class water.api.SchemaMetadata
-
- SchemaMetadata(Schema) - Constructor for class water.api.SchemaMetadata
-
- SchemaMetadata.FieldMetadata - Class in water.api
-
- SchemaMetadata.FieldMetadata() - Constructor for class water.api.SchemaMetadata.FieldMetadata
-
- SchemaMetadata.FieldMetadata(String, String, boolean, String, Iced, String, String, boolean, API.Level, API.Direction, String[], boolean, String[], String[]) - Constructor for class water.api.SchemaMetadata.FieldMetadata
-
- SchemaMetadata.FieldMetadata(Schema, Field) - Constructor for class water.api.SchemaMetadata.FieldMetadata
-
Create a new FieldMetadata object for the given Field of the given Schema.
- SchemaMetadataBase<I extends SchemaMetadata,S extends SchemaMetadataBase<I,S>> - Class in water.api
-
Schema for the metadata for a Schema.
- SchemaMetadataBase() - Constructor for class water.api.SchemaMetadataBase
-
- SchemaMetadataBase.FieldMetadataBase<I extends SchemaMetadata.FieldMetadata,S extends SchemaMetadataBase.FieldMetadataBase<I,S>> - Class in water.api
-
Schema for the metadata for the field of a Schema.
- SchemaMetadataBase.FieldMetadataBase() - Constructor for class water.api.SchemaMetadataBase.FieldMetadataBase
-
- SchemaMetadataV1 - Class in water.api
-
- SchemaMetadataV1() - Constructor for class water.api.SchemaMetadataV1
-
- schemaname - Variable in class water.api.DocsBase
-
- schemas - Variable in class water.api.DocsBase
-
- schemas() - Static method in class water.api.Schema
-
Return an immutable Map of all the schemas: schema_name -> schema Class.
- Scope - Class in water
-
A "scope" for tracking Key lifetimes; an experimental API.
- Scope() - Constructor for class water.Scope
-
- score(Frame) - Method in class hex.Model
-
Bulk score the frame fr
, producing a Frame result; the 1st
Vec is the predicted class, the remaining Vecs are the probability
distributions.
- score(double[]) - Method in class hex.Model
-
- score0(Chunk[], int, double[], float[]) - Method in class hex.Model
-
Bulk scoring API for one row.
- score0(double[], float[]) - Method in class hex.Model
-
Subclasses implement the scoring logic.
- score0(Chunk[], int, double[], float[]) - Method in class hex.SupervisedModel
-
Bulk scoring API for one row.
- score_each_iteration - Variable in class water.api.ModelParametersSchema
-
- scoreImpl(Frame, Frame) - Method in class hex.Model
-
Score an already adapted frame.
- scoring_time - Variable in class water.api.ModelMetricsBase
-
- section(String) - Method in class water.util.DocGen.HTML
-
- section(String) - Method in class water.util.DocGen
-
- seed - Variable in class hex.CreateFrame
-
- SEEDS - Static variable in class water.util.RandomUtils.MersenneTwisterRNG
-
- SELF - Static variable in class water.H2O
-
- self(InetAddress) - Static method in class water.H2ONode
-
- SELF_ADDRESS - Static variable in class water.H2O
-
- send_recv() - Method in class water.init.TimelineSnapshot.Event
-
- send_recv(long[], int) - Static method in class water.TimeLine
-
- sep - Variable in class water.parser.ParseSetupV2
-
- SEPARATOR_OR_EOL - Static variable in class water.parser.Parser
-
- seq(int, int) - Static method in class water.util.ArrayUtils
-
Generates sequence (start, stop) of integers: (start, start+1, ...., stop-1)
- serial - Variable in class water.init.NetworkTest
-
- serve(String, String, Properties, Properties) - Method in class water.api.RequestServer
-
- serve(String, String, Properties, Properties) - Method in class water.NanoHTTPD
-
Override this to customize the server.
- serveFile(String, Properties, File, boolean) - Method in class water.NanoHTTPD
-
Serves file from homeDir and its' subdirectories (only).
- SERVER - Static variable in class water.api.RequestServer
-
- set(int, long) - Method in class water.fvec.Chunk
-
Write a long
with check-relative indexing.
- set(int, double) - Method in class water.fvec.Chunk
-
Write a double
with check-relative indexing.
- set(int, float) - Method in class water.fvec.Chunk
-
Write a float
with check-relative indexing.
- set(int, String) - Method in class water.fvec.Chunk
-
Write a String
with check-relative indexing.
- set(long, long) - Method in class water.fvec.Vec
-
Write element the slow way, as a long.
- set(long, double) - Method in class water.fvec.Vec
-
Write element the slow way, as a double.
- set(long, float) - Method in class water.fvec.Vec
-
Write element the slow way, as a float.
- set(long, String) - Method in class water.fvec.Vec
-
Write element the slow way, as a String.
- set(long, long) - Method in class water.fvec.Vec.Writer
-
- set(long, double) - Method in class water.fvec.Vec.Writer
-
- set(long, float) - Method in class water.fvec.Vec.Writer
-
- set(long, String) - Method in class water.fvec.Vec.Writer
-
- set(byte[], int, int) - Method in class water.parser.ValueString
-
- set(int) - Method in class water.util.IcedBitSet
-
- set(int, int, String) - Method in class water.util.TwoDimTable
-
Setter for table cells
- set(int, int, double) - Method in class water.util.TwoDimTable
-
Setter for table cells
- set(int, int, float) - Method in class water.util.TwoDimTable
-
Setter for table cells
- set(int, int, int) - Method in class water.util.TwoDimTable
-
Setter for table cells
- set(int, int, long) - Method in class water.util.TwoDimTable
-
Setter for table cells
- set2(byte[], int, short) - Static method in class water.util.UnsafeUtils
-
- set4(byte[], int, int) - Static method in class water.util.UnsafeUtils
-
- set4f(byte[], int, float) - Static method in class water.util.UnsafeUtils
-
- set8(byte[], int, long) - Static method in class water.util.UnsafeUtils
-
- set8d(byte[], int, double) - Static method in class water.util.UnsafeUtils
-
- set_abs(long, String) - Method in class water.fvec.Chunk
-
Set a String
, using absolute row numbers.
- set_ast(AST) - Method in class water.rapids.Raft
-
- set_impl(int, double) - Method in class water.fvec.NewChunk
-
- set_key(Key) - Method in class water.rapids.Raft
-
- set_sparse(int) - Method in class water.fvec.NewChunk
-
- set_vec(Vec) - Method in class water.fvec.NewChunk
-
- setAllFields(Vec, Frame, double, int, int, int, int, String, double, int, boolean, int, double, double) - Method in class water.Quantiles
-
- setBytes(byte[]) - Method in class water.fvec.Chunk
-
- setColumnNames(String[]) - Method in class water.parser.Parser.InspectDataOut
-
- setCompleter(CountedCompleter) - Method in class jsr166y.CountedCompleter
-
- setDomain(String[]) - Method in class water.fvec.Vec
-
Set the Categorical/factor/categorical names.
- setdsk() - Method in class water.Value
-
Used by the persistance subclass to mark this Value as saved-on-disk.
- setEmbeddedH2OConfig(AbstractEmbeddedH2OConfig) - Static method in class water.H2O
-
Register embedded H2O configuration object with H2O instance.
- setException(Throwable) - Method in class water.DTask
-
Capture the first exception in _ex.
- setForkJoinTaskTag(short) - Method in class jsr166y.ForkJoinTask
-
Atomically sets the tag value for this task.
- setHttpStatus(int) - Method in class hex.schemas.ModelBuilderSchema
-
- setMax(float[], int, float) - Static method in class water.util.AtomicUtils.FloatArray
-
- setMin(float[], int, float) - Static method in class water.util.AtomicUtils.FloatArray
-
- setNA(int) - Method in class water.fvec.Chunk
-
Set a value as missing.
- setNA(long) - Method in class water.fvec.Vec.Writer
-
- setNA_impl2(int) - Method in class water.fvec.NewChunk
-
- setOff(int) - Method in class water.parser.ValueString
-
- setPendingCount(int) - Method in class jsr166y.CountedCompleter
-
Sets the pending count to the given value.
- setRawResult(Void) - Method in class jsr166y.CountedCompleter
-
Requires null completion value.
- setRawResult(V) - Method in class jsr166y.ForkJoinTask
-
Forces the given value to be returned as a result.
- setRawResult(Void) - Method in class jsr166y.RecursiveAction
-
Requires null completion value.
- setRawResult(V) - Method in class jsr166y.RecursiveTask
-
- setSeed(long) - Method in class jsr166y.ThreadLocalRandom
-
Throws UnsupportedOperationException
.
- setSparseRatio(int) - Method in class water.fvec.NewChunk
-
- setStart(long) - Method in class water.fvec.Chunk
-
Set the start
- setSubRange(AppendableVec) - Method in class water.fvec.AppendableVec
-
Add AV build over sub-range of this vec (used e.g.
- setTimezone(String) - Static method in class water.parser.ParseTime
-
- setTo(String) - Method in class water.parser.ValueString
-
- setTypes(byte[]) - Method in class water.fvec.AppendableVec
-
- setup(Key, boolean, int) - Static method in class water.parser.ParseDataset
-
- setupLocal() - Method in class water.api.RemoveAllHandler.RemoveAllTask
-
- setupLocal() - Method in class water.api.UnlockTask
-
- setupLocal() - Method in class water.fvec.Vec.CollectDomain
-
- setupLocal() - Method in class water.MRTask
-
Override to do any remote initialization on the 1st remote instance of
this object, for initializing node-local shared data structures.
- setupLocal() - Method in class water.util.FileIntegrityChecker
-
- setupLocal() - Method in class water.util.JStackCollectorTask
-
- setupLocal() - Method in class water.util.ProfileCollectorTask
-
This runs on each node in the cluster.
- setUsedRNGKind(RandomUtils.H2ORandomRNG.RNGKind) - Static method in class water.util.RandomUtils
-
- setUsedRNGType(RandomUtils.H2ORandomRNG.RNGType) - Static method in class water.util.RandomUtils
-
- setVariables(String[]) - Method in class hex.VarImp
-
- setVec(Vec) - Method in class water.fvec.Chunk
-
Set the owning Vec
- setVecFields(Vec, int, double, double) - Method in class water.Quantiles
-
- shouldBeEnum() - Method in class water.fvec.AppendableVec
-
- shuffleArray(int[], int, int[], long, int) - Static method in class water.util.ArrayUtils
-
Extract a shuffled array of integers
- shuffleArray(long[], long) - Static method in class water.util.ArrayUtils
-
- shuffleFramePerChunk(Frame, long) - Static method in class water.util.MRUtils
-
Row-wise shuffle of a frame (only shuffles rows inside of each chunk)
- shutdown() - Method in class jsr166y.ForkJoinPool
-
Initiates an orderly shutdown in which previously submitted
tasks are executed, but no new tasks will be accepted.
- shutdown(int, ShutdownV2) - Method in class water.api.ShutdownHandler
-
- shutdown() - Static method in class water.H2O
-
Shutdown itself by sending a shutdown UDP packet.
- ShutdownHandler - Class in water.api
-
- ShutdownHandler() - Constructor for class water.api.ShutdownHandler
-
- ShutdownHandler.Shutdown - Class in water.api
-
- ShutdownHandler.Shutdown() - Constructor for class water.api.ShutdownHandler.Shutdown
-
- shutdownNow() - Method in class jsr166y.ForkJoinPool
-
Attempts to cancel and/or stop all tasks, and reject all
subsequently submitted tasks.
- ShutdownV2 - Class in water.api
-
- ShutdownV2() - Constructor for class water.api.ShutdownV2
-
- sigma - Variable in class water.api.FrameV2.ColV2
-
- sigma() - Method in class water.fvec.Vec
-
Vecs's standard deviation
- singleQuotes - Variable in class water.parser.ParseSetupV2
-
- size() - Method in class hex.ConfusionMatrix
-
- size - Variable in class hex.DMatrix.MatrixMulStats
-
- size() - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns the number of elements in this deque.
- size() - Method in class jsr166y.LinkedTransferQueue
-
Returns the number of elements in this queue.
- size() - Method in class water.H2O
-
- size() - Method in class water.util.FileIntegrityChecker
-
- size() - Method in class water.util.IcedBitSet
-
- size() - Method in class water.util.IcedHashMap
-
- size_io() - Method in class water.init.TimelineSnapshot.Event
-
- skip(int) - Method in class water.AutoBuffer
-
Skip over some bytes in the byte buffer.
- SKIP_LINE - Static variable in class water.parser.Parser
-
- SOCK - Static variable in class water.TCPReceiverThread
-
- sortedMerge(int[], double[], int[], double[], int[], double[]) - Static method in class water.util.ArrayUtils
-
- source_key - Variable in class water.api.QuantilesV1
-
- sp() - Method in class water.rapids.Env
-
The stack API
- sparse() - Method in class water.fvec.NewChunk
-
- sparseLen() - Method in class water.fvec.Chunk
-
Sparse Chunks have a significant number of zeros, and support for
skipping over large runs of zeros in a row.
- sparseLen() - Method in class water.fvec.NewChunk
-
- specificity - Variable in class hex.AUCData
-
- specificity(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- specificity() - Method in class hex.AUCData
-
- specificity() - Method in class hex.ConfusionMatrix
-
The percentage of negative labeled instances that were predicted as negative.
- specificity - Variable in class water.api.AUCBase
-
- specificity_for_criteria - Variable in class water.api.AUCBase
-
- SpecifiesHttpResponseCode - Interface in water.api
-
Interface which allows a Schema, if returned by a handler method, to specify the HTTP response code.
- srcs - Variable in class water.parser.ParseSetupV2
-
- sslen() - Method in class water.fvec.NewChunk
-
- stacktrace - Variable in class water.api.H2OErrorV1
-
- stacktrace - Variable in class water.api.ProfilerNodeV2.ProfilerNodeEntryV2
-
- stacktraces - Variable in class water.util.ProfileCollectorTask.NodeProfile
-
- start() - Static method in class water.api.RequestServer
-
- start() - Method in class water.fvec.Chunk
-
Global starting row for this local Chunk
- start(H2O.H2OCountedCompleter, long) - Method in class water.Job
-
Start this task based on given top-level fork-join task representing job computation.
- START_TIME_MILLIS - Static variable in class water.H2O
-
- startRollupStats(Futures) - Method in class water.fvec.Vec
-
- startRollupStats(Futures, boolean) - Method in class water.fvec.Vec
-
Check if we have local cached copy of basic Vec stats (including histogram if requested) and if not start task to compute and fetch them;
useful when launching a bunch of them in parallel to avoid single threaded execution later (e.g.
- STATIC_H2OS - Static variable in class water.H2O
-
- status - Variable in class water.api.JobV2
-
- status - Variable in class water.NanoHTTPD.Response
-
HTTP status code after processing, e.g.
- stop() - Method in class water.NanoHTTPD
-
Stops the server.
- store(Value) - Method in class water.persist.Persist
-
Store a Value into persistent storage, consuming some storage space.
- store(Value) - Method in class water.persist.PersistHdfs
-
- store(Path, byte[]) - Static method in class water.persist.PersistHdfs
-
- store(Value) - Method in class water.persist.PersistNFS
-
- store(Value) - Method in class water.persist.PersistS3
-
- store_size() - Static method in class water.H2O
-
- STOREtoString() - Static method in class water.H2O
-
- str_data - Variable in class water.api.FrameV2.ColV2
-
- strCnt() - Method in class water.fvec.NewChunk
-
- stride - Variable in class water.api.FrameV2.ColV2
-
- stride() - Method in class water.fvec.Vec
-
The stride
for a a simple and cheap histogram of the Vec, useful
for getting a broad overview of the data.
- STRING - Static variable in class water.fvec.AppendableVec
-
- STRING - Static variable in class water.parser.Parser
-
- STRING_END - Static variable in class water.parser.Parser
-
- stringBuffer() - Method in class water.util.MarkdownBuilder
-
- StrWrappedVec - Class in water.fvec
-
A vector transforming values of given vector according to given domain
mapping - currently only used to transform Enum columns but in theory would
work for any dense-packed Int column.
- StrWrappedVec(Key, long[], Key) - Constructor for class water.fvec.StrWrappedVec
-
Main constructor: convert from enum to string
- subarray(T[], int, int) - Static method in class water.util.ArrayUtils
-
- subframe(String[]) - Method in class water.fvec.Frame
-
Returns a subframe of this frame containing only vectors with desired names.
- subframe(String[], double) - Method in class water.fvec.Frame
-
Returns a new frame composed of vectors of this frame selected by given names.
- submit(ForkJoinTask<T>) - Method in class jsr166y.ForkJoinPool
-
Submits a ForkJoinTask for execution.
- submit(Callable<T>) - Method in class jsr166y.ForkJoinPool
-
- submit(Runnable, T) - Method in class jsr166y.ForkJoinPool
-
- submit(Runnable) - Method in class jsr166y.ForkJoinPool
-
- submitTask() - Method in class water.DTask.DKeyTask
-
Convenience non-blocking submit to work queues
- submitTask(H2O.H2OCountedCompleter) - Static method in class water.H2O
-
- subRef(Frame) - Method in class water.rapids.Env
-
- subRef(Vec) - Method in class water.rapids.Env
-
- SubsetVec - Class in water.fvec
-
A simple wrapper for looking at only a subset of rows
- SubsetVec(Key, long[], Key, Key) - Constructor for class water.fvec.SubsetVec
-
- sum(long[]) - Static method in class water.util.ArrayUtils
-
- sum(int[]) - Static method in class water.util.ArrayUtils
-
- sum(float[]) - Static method in class water.util.ArrayUtils
-
- sum(double[]) - Static method in class water.util.ArrayUtils
-
- summary() - Method in class hex.VarImp.VarImpRI
-
- summary - Variable in class water.api.RouteBase
-
- sumSquares(float[]) - Static method in class water.util.MathUtils
-
- sumSquares(float[], int, int) - Static method in class water.util.MathUtils
-
- SupervisedModel<M extends Model<M,P,O>,P extends SupervisedModel.SupervisedParameters,O extends SupervisedModel.SupervisedOutput> - Class in hex
-
Supervised Model
There is a response column used in training.
- SupervisedModel(Key, P, O) - Constructor for class hex.SupervisedModel
-
- SupervisedModel.SupervisedOutput - Class in hex
-
Output from all Supervised Models, includes class distribtion
- SupervisedModel.SupervisedOutput() - Constructor for class hex.SupervisedModel.SupervisedOutput
-
- SupervisedModel.SupervisedOutput(SupervisedModelBuilder) - Constructor for class hex.SupervisedModel.SupervisedOutput
-
Any final prep-work just before model-building starts, but after the
user has clicked "go".
- SupervisedModel.SupervisedParameters - Class in hex
-
Supervised Model Parameters includes a response column, and whether or
not rebalancing classes is desirable.
- SupervisedModel.SupervisedParameters() - Constructor for class hex.SupervisedModel.SupervisedParameters
-
- SupervisedModelBuilder<M extends SupervisedModel<M,P,O>,P extends SupervisedModel.SupervisedParameters,O extends SupervisedModel.SupervisedOutput> - Class in hex
-
- SupervisedModelBuilder(P) - Constructor for class hex.SupervisedModelBuilder
-
Constructor called from an http request; MUST override in subclasses.
- SupervisedModelBuilder(String, P) - Constructor for class hex.SupervisedModelBuilder
-
- SupervisedModelBuilder(Key, String, P) - Constructor for class hex.SupervisedModelBuilder
-
- SupervisedModelBuilderSchema<B extends SupervisedModelBuilder,S extends SupervisedModelBuilderSchema<B,S,P>,P extends SupervisedModelParametersSchema> - Class in hex.schemas
-
- SupervisedModelBuilderSchema() - Constructor for class hex.schemas.SupervisedModelBuilderSchema
-
- SupervisedModelParametersSchema<P extends SupervisedModel.SupervisedParameters,S extends SupervisedModelParametersSchema<P,S>> - Class in water.api
-
An instance of a SupervisedModelParameters schema contains the common SupervisedModel build parameters (e.g., response_column).
- SupervisedModelParametersSchema() - Constructor for class water.api.SupervisedModelParametersSchema
-
- swap(int, int) - Method in class water.fvec.Frame
-
Swap two Vecs in-place; useful for sorting columns by some criteria
- switch_to_doubles() - Method in class water.fvec.NewChunk
-
- SYMBOLS - Static variable in class water.rapids.ASTOp
-
- syncDirectory(ArrayList<String>, ArrayList<String>, ArrayList<String>, ArrayList<String>) - Method in class water.util.FileIntegrityChecker
-
- sys_load - Variable in class water.api.CloudV1.NodeV1
-
- system_snapshot() - Static method in class water.TimeLine
-
- T_BAD - Static variable in class water.fvec.Vec
-
- T_ENUM - Static variable in class water.fvec.Vec
-
- T_NUM - Static variable in class water.fvec.Vec
-
- T_STR - Static variable in class water.fvec.Vec
-
- T_TIME - Static variable in class water.fvec.Vec
-
- T_TIMELAST - Static variable in class water.fvec.Vec
-
- T_UUID - Static variable in class water.fvec.Vec
-
- table - Variable in class water.api.ConfusionMatrixBase
-
- tableHeader - Variable in class water.api.TwoDimTableV1
-
- tableHeader(String...) - Method in class water.util.MarkdownBuilder
-
- tableRow(String...) - Method in class water.util.MarkdownBuilder
-
- take() - Method in class jsr166y.LinkedTransferQueue
-
- TaskGetKey - Class in water
-
Get the given key from the remote node
- TaskPutKey - Class in water
-
Push the given key to the remote node
- TaskPutKey(Key, Value) - Constructor for class water.TaskPutKey
-
- TaskPutKey(Key, Value, boolean) - Constructor for class water.TaskPutKey
-
- TAtomic<T extends Freezable> - Class in water
-
A typed atomic update.
- TAtomic() - Constructor for class water.TAtomic
-
- TAtomic(H2O.H2OCountedCompleter) - Constructor for class water.TAtomic
-
- TCP - Static variable in class water.Value
-
- TCPReceiverThread - Class in water
-
The Thread that looks for TCP Cloud requests.
- TCPReceiverThread() - Constructor for class water.TCPReceiverThread
-
- tcps_active - Variable in class water.api.CloudV1.NodeV1
-
- ThreadLocalRandom - Class in jsr166y
-
A random number generator isolated to the current thread.
- threshold(AUC.ThresholdCriterion) - Method in class hex.AUCData
-
- threshold() - Method in class hex.AUCData
-
- threshold_criteria - Variable in class water.api.AUCBase
-
- threshold_criterion - Variable in class hex.AUC
-
- threshold_criterion - Variable in class hex.AUCData
-
- threshold_criterion - Variable in class water.api.AUCBase
-
- threshold_for_criteria - Variable in class water.api.AUCBase
-
- thresholds - Variable in class hex.AUCData
-
- thresholds - Variable in class water.api.AUCBase
-
- throwErr(Throwable) - Static method in class water.util.Log
-
- TIME - Static variable in class water.fvec.AppendableVec
-
- time() - Method in class water.util.Timer
-
Return the difference between when the timer was created and the current time.
- TIME_PARSE - Static variable in class water.parser.ParseTime
-
- TimeLine - Class in water
-
Maintain a VERY efficient list of events in the system.
- TimeLine() - Constructor for class water.TimeLine
-
- TimelineHandler - Class in water.api
-
UDP Timeline
Created by tomasnykodym on 6/5/14.
- TimelineHandler() - Constructor for class water.api.TimelineHandler
-
- TimelineHandler.Timeline - Class in water.api
-
- TimelineHandler.Timeline() - Constructor for class water.api.TimelineHandler.Timeline
-
- TimelineSnapshot - Class in water.init
-
Wrapper around timeline snapshot.
- TimelineSnapshot(H2O, long[][]) - Constructor for class water.init.TimelineSnapshot
-
- TimelineSnapshot.Event - Class in water.init
-
- TimelineSnapshot.Event(int, int) - Constructor for class water.init.TimelineSnapshot.Event
-
- TimelineV2 - Class in water.api
-
Display of a Timeline
Created by tomasnykodym on 6/5/14.
- TimelineV2() - Constructor for class water.api.TimelineV2
-
- TimelineV2.EventV2<I,S extends TimelineV2.EventV2<I,S>> - Class in water.api
-
- TimelineV2.NetworkEvent - Class in water.api
-
- TIMEOUT - Static variable in class water.HeartBeatThread
-
- Timer - Class in water.util
-
Simple Timer class.
- Timer() - Constructor for class water.util.Timer
-
- timestamp - Variable in class water.api.H2OErrorV1
-
- timestamp - Variable in class water.api.ProfilerNodeV2
-
- timestamp - Variable in exception water.exceptions.H2OAbstractRuntimeException
-
- timestamp - Variable in class water.KeySnapshot
-
(local) Time of creation.
- timestamp - Variable in class water.util.JProfile
-
- timestamp - Variable in class water.util.ProfileCollectorTask.NodeProfile
-
- title(String) - Method in class water.util.DocGen.HTML
-
- title(String) - Method in class water.util.DocGen
-
- to - Variable in class water.api.TimelineV2.NetworkEvent
-
- toArray() - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns an array containing all of the elements in this deque, in
proper sequence (from first to last element).
- toArray(T[]) - Method in class jsr166y.ConcurrentLinkedDeque
-
Returns an array containing all of the elements in this deque,
in proper sequence (from first to last element); the runtime
type of the returned array is that of the specified array.
- toASCII() - Method in class hex.ConfusionMatrix
-
- toASCII(StringBuilder) - Method in class hex.HitRatio
-
- toASCII(StringBuilder) - Method in class water.init.NetworkTest
-
- toCSV(boolean, boolean) - Method in class water.fvec.Frame
-
Convert this Frame to a CSV (in an InputStream
), that optionally
is compatible with R 3.1's recent change to read.csv()'s behavior.
- toEnum() - Method in class water.fvec.Vec
-
Transform this vector to enum.
- toH2OError() - Method in exception water.exceptions.H2OAbstractRuntimeException
-
- toH2OError(String) - Method in exception water.exceptions.H2OAbstractRuntimeException
-
- toHTML(StringBuilder) - Method in class water.init.NetworkTest
-
- toHTML(StringBuilder) - Method in class water.util.JProfile
-
- toHTML(StringBuilder) - Method in class water.util.JStack
-
- toInt(String[], int, int) - Static method in class water.util.ArrayUtils
-
- toJavaStringInit(String[]) - Method in class water.util.SB
-
- toJavaStringInit(float[]) - Method in class water.util.SB
-
- toJSArray(float[]) - Method in class water.util.SB
-
- toJSArray(String[]) - Method in class water.util.SB
-
- toJsonString() - Method in class water.Iced
-
Helper for folks that want a JSON String for this object.
- TOKEN - Static variable in class water.parser.Parser
-
- toss(ValFrame) - Method in class water.rapids.Env
-
- toStrArray() - Method in class water.util.IcedBitSet
-
- toString() - Method in class hex.ConfusionMatrix
-
- toString() - Method in class hex.ModelBuilder.ValidationMessage
-
- toString() - Method in class jsr166y.ForkJoinPool
-
Returns a string identifying this pool, as well as its state,
including indications of run state, parallelism level, and
worker and task counts.
- toString() - Method in class jsr166y.Phaser
-
Returns a string identifying this phaser, as well as its
state.
- toString() - Method in class water.api.KeySchema
-
- toString() - Method in class water.api.TimelineV2.NetworkEvent
-
- toString() - Method in class water.AutoBuffer
-
- toString() - Method in class water.fvec.AppendableVec
-
- toString() - Method in class water.fvec.Chunk
-
- toString() - Method in class water.fvec.NewChunk
-
- toString() - Method in class water.fvec.Vec
-
Pretty print the Vec: [#elems, min/mean/max]{chunks,...}
- toString() - Method in class water.fvec.Vec.VectorGroup
-
Pretty print the VectorGroup
- toString() - Method in class water.H2O
-
- toString() - Method in class water.H2OError
-
- toString() - Method in class water.H2ONode
-
- toString() - Method in class water.IcedWrapper
-
- toString() - Method in class water.init.AbstractBuildVersion
-
- toString() - Method in class water.init.TimelineSnapshot.Event
-
- toString() - Method in class water.Key
-
Converts the key to HTML displayable string.
- toString() - Method in class water.parser.Categorical
-
- toString() - Method in class water.parser.Parser.ColTypeInfo
-
- toString() - Method in class water.parser.ParseSetup
-
- toString() - Method in class water.parser.ValueString
-
- toString(ValueString[]) - Static method in class water.parser.ValueString
-
- toString() - Method in class water.rapids.ASTddply.ddplyPass1
-
- toString() - Method in class water.rapids.ASTddply.Group
-
- toString(StringBuilder, int) - Method in class water.rapids.ASTFunc
-
- toString(int) - Method in class water.rapids.Env
-
- toString() - Method in class water.rapids.Env
-
- toString(long[]) - Static method in class water.util.ArrayUtils
-
- toString(int[]) - Static method in class water.util.ArrayUtils
-
- toString(float[]) - Static method in class water.util.AtomicUtils.FloatArray
-
- toString() - Method in class water.util.ChunkSummary
-
- toString() - Method in class water.util.DocGen.HTML
-
- toString() - Method in class water.util.IcedBitSet
-
- toString() - Method in class water.util.IcedInt
-
- toString() - Method in class water.util.MarkdownBuilder
-
- toString() - Method in class water.util.RString
-
- toString() - Method in class water.util.SB
-
- toString() - Method in class water.util.Timer
-
Return the difference between when the timer was created and the current
time as a string along with the time of creation in date format.
- toString() - Method in class water.util.TwoDimTable
-
Print table to String, using 2 spaces for padding between columns
- toString(int) - Method in class water.util.TwoDimTable
-
Print table to String, using user-given padding
- toStringVec() - Method in class water.fvec.Vec
-
Transform this vector to strings.
- tot_mem - Variable in class water.api.CloudV1.NodeV1
-
- total_bytes - Variable in class water.fvec.UploadFileVec.ReadPutStats
-
- total_chunks - Variable in class water.fvec.UploadFileVec.ReadPutStats
-
- total_frames - Variable in class water.fvec.UploadFileVec.ReadPutStats
-
- total_value_size - Variable in class water.api.CloudV1.NodeV1
-
- total_vecs - Variable in class water.fvec.UploadFileVec.ReadPutStats
-
- totalRows() - Method in class hex.ConfusionMatrix
-
- trace(Object...) - Static method in class water.util.Log
-
- traces - Variable in class water.api.JStackV2
-
- track(Key) - Static method in class water.Scope
-
- train() - Method in class hex.Model.Parameters
-
- train() - Method in class hex.ModelBuilder
-
Training frame: derived from the parameter's training frame, excluding
all ignored columns, all constant and bad columns, perhaps flipping the
response column to an Categorical, etc.
- training_frame - Variable in class water.api.ModelParametersSchema
-
- trainModel() - Method in class hex.ModelBuilder
-
Method to launch training of a Model, based on its parameters.
- transfer(E) - Method in class jsr166y.LinkedTransferQueue
-
Transfers the element to a consumer, waiting if necessary to do so.
- transfer(E) - Method in interface jsr166y.TransferQueue
-
Transfers the element to a consumer, waiting if necessary to do so.
- TransferQueue<E> - Interface in jsr166y
-
A BlockingQueue
in which producers may wait for consumers
to receive elements.
- transpose(Frame) - Static method in class hex.DMatrix
-
Transpose the Frame as if it was a matrix (i.e.
- transpose(Frame, Frame) - Static method in class hex.DMatrix
-
Transpose the Frame as if it was a matrix (rows <-> columns).
- tryComplete() - Method in class jsr166y.CountedCompleter
-
- tryReturnKeys(int, int) - Method in class water.fvec.Vec.VectorGroup
-
- tryTransfer(E) - Method in class jsr166y.LinkedTransferQueue
-
Transfers the element to a waiting consumer immediately, if possible.
- tryTransfer(E, long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
-
Transfers the element to a consumer if it is possible to do so
before the timeout elapses.
- tryTransfer(E) - Method in interface jsr166y.TransferQueue
-
Transfers the element to a waiting consumer immediately, if possible.
- tryTransfer(E, long, TimeUnit) - Method in interface jsr166y.TransferQueue
-
Transfers the element to a consumer if it is possible to do so
before the timeout elapses.
- tryUnfork() - Method in class jsr166y.ForkJoinTask
-
Tries to unschedule this task for execution.
- TutorialsV1 - Class in water.api
-
- TutorialsV1() - Constructor for class water.api.TutorialsV1
-
- TwoDimTable - Class in water.util
-
Serializable 2D Table containing Strings or doubles
Table can be named
Columns and Rows can be named
Fields can be empty
- TwoDimTable(String, String[], String[], String[], String[]) - Constructor for class water.util.TwoDimTable
-
Constructor for TwoDimTable (R rows, C columns)
- TwoDimTable(String, String[], String[], String[], String[], String[][], double[][]) - Constructor for class water.util.TwoDimTable
-
Constructor for TwoDimTable (R rows, C columns)
- TwoDimTableV1 - Class in water.api
-
- TwoDimTableV1() - Constructor for class water.api.TwoDimTableV1
-
- type - Variable in class water.api.FrameV2.ColV2
-
- type - Variable in class water.api.KeySchema
-
- type - Variable in class water.api.ModelParameterSchemaV2
-
- type - Variable in class water.api.SchemaMetadata.FieldMetadata
-
Type for this field.
- type - Variable in class water.api.SchemaMetadata
-
- type - Variable in class water.api.SchemaMetadataBase.FieldMetadataBase
-
- type - Variable in class water.api.SchemaMetadataBase
-
- type() - Method in class water.fvec.NewChunk
-
- type() - Method in class water.Key
-
- TypeaheadV2 - Class in water.api
-
- TypeaheadV2() - Constructor for class water.api.TypeaheadV2
-
- TypeMap - Class in water
-
Internal H2O class used to build and maintain the cloud-wide type mapping.
- TypeMap() - Constructor for class water.TypeMap
-
- vactual - Variable in class hex.AUC
-
- vactual - Variable in class hex.HitRatio
-
- valid() - Method in class hex.Model.Parameters
-
- valid() - Method in class hex.ModelBuilder
-
Validation frame: derived from the parameter's validation frame, excluding
all ignored columns, all constant and bad columns, perhaps flipping the
response column to a Categorical, etc.
- valid() - Method in class water.util.LinuxProcFileReader
-
- validation_error_count - Variable in class hex.schemas.ModelBuilderSchema
-
- validation_frame - Variable in class water.api.ModelParametersSchema
-
- validation_messages - Variable in class hex.schemas.ModelBuilderSchema
-
- ValidationAdapter - Class in water.api
-
- ValidationAdapter() - Constructor for class water.api.ValidationAdapter
-
- validationErrors() - Method in class hex.ModelBuilder
-
Get a string representation of only the ERROR ValidationMessages (e.g., to use in an exception throw).
- value - Variable in class hex.CreateFrame
-
- value - Variable in class water.api.AboutHandler.AboutEntryV3
-
- value - Variable in class water.api.SchemaMetadata.FieldMetadata
-
Value for this field.
- value - Variable in class water.api.SchemaMetadataBase.FieldMetadataBase
-
- value(String) - Static method in enum water.util.RandomUtils.H2ORandomRNG.RNGKind
-
- Value - Class in water
-
The core Value stored in the distributed K/V store, used to cache Plain Old
Java Objects, and maintain coherency around the cluster.
- Value(Key, int, byte[], short, byte) - Constructor for class water.Value
-
Construct a Value from all parts; not needed for most uses.
- Value(Key, Freezable) - Constructor for class water.Value
-
Standard constructor to build a Value from a POJO and a Key.
- valueClass() - Method in class water.Key
-
Return the classname for the Value that this Key points to, if any (e.g., "water.fvec.Frame").
- valueClassSimple() - Method in class water.Key
-
Return the base classname (not including the package) for the Value that this Key points to, if any (e.g., "Frame").
- valueOf(String) - Static method in enum hex.AUC.ThresholdCriterion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum hex.Model.ModelCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum hex.ModelBuilder.ValidationMessage.MessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.api.API.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.api.API.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.Job.JobState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.parser.Parser.ColType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.parser.ParserType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.UDP.udp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.util.PojoUtils.FieldNaming
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.util.RandomUtils.H2ORandomRNG.RNGKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum water.util.RandomUtils.H2ORandomRNG.RNGType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum hex.AUC.ThresholdCriterion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum hex.Model.ModelCategory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum hex.ModelBuilder.ValidationMessage.MessageType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.api.API.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.api.API.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class water.api.H2OErrorV1
-
- values - Variable in class water.api.ModelParameterSchemaV2
-
- values - Variable in exception water.exceptions.H2OAbstractRuntimeException
-
- values() - Method in class water.fvec.NewChunk
-
- values(int, int) - Method in class water.fvec.NewChunk
-
- values() - Static method in enum water.Job.JobState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.parser.Parser.ColType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.parser.ParserType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.UDP.udp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class water.util.IcedHashMap
-
- values() - Static method in enum water.util.PojoUtils.FieldNaming
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.util.RandomUtils.H2ORandomRNG.RNGKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum water.util.RandomUtils.H2ORandomRNG.RNGType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueString - Class in water.parser
-
- ValueString(String) - Constructor for class water.parser.ValueString
-
- ValueString() - Constructor for class water.parser.ValueString
-
- variables - Variable in class hex.VarImp
-
- VarImp - Class in hex
-
- VarImp(float[]) - Constructor for class hex.VarImp
-
- VarImp(float[], String[]) - Constructor for class hex.VarImp
-
- VarImp(float[], String[], VarImp.VarImpMethod) - Constructor for class hex.VarImp
-
- varimp - Variable in class hex.VarImp
-
- VarImp.VarImpMDA - Class in hex
-
Variable importance measured as mean decrease in accuracy.
- VarImp.VarImpMDA(float[], float[], int) - Constructor for class hex.VarImp.VarImpMDA
-
- VarImp.VarImpRI - Class in hex
-
Variable importance measured as relative influence.
- VarImp.VarImpRI(float[]) - Constructor for class hex.VarImp.VarImpRI
-
- varimpSD - Variable in class hex.VarImp.VarImpMDA
-
- vec() - Method in class water.fvec.Chunk
-
Owning Vec
- vec(int) - Method in class water.fvec.Frame
-
Returns the Vec by given index, implemented by code: vecs()[idx]
.
- vec(String) - Method in class water.fvec.Frame
-
Return a Vec by name, or null if missing
- vec() - Method in class water.fvec.Frame.VecSpecifier
-
- Vec - Class in water.fvec
-
A distributed vector/array/column of uniform data.
- Vec(Key, long[]) - Constructor for class water.fvec.Vec
-
Build a numeric-type Vec; the caller understands Chunk layout (via the
espc
array).
- Vec(Key, long[], String[], byte) - Constructor for class water.fvec.Vec
-
Main default constructor; the caller understands Chunk layout (via the
espc
array), plus enum/factor the domain
(or null for
non-enums), and the Vec type.
- VEC - Static variable in class water.Key
-
- Vec.CollectDomain - Class in water.fvec
-
Collect numeric domain of given vector
A map-reduce task to collect up the unique values of an integer vector
and returned as the domain for the vector.
- Vec.CollectDomain() - Constructor for class water.fvec.Vec.CollectDomain
-
- Vec.VectorGroup - Class in water.fvec
-
Class representing the group of vectors.
- Vec.VectorGroup() - Constructor for class water.fvec.Vec.VectorGroup
-
- Vec.Writer - Class in water.fvec
-
A more efficient way to write randomly to a Vec - still single-threaded,
still slow, but much faster than Vec.set().
- VECGROUP - Static variable in class water.TypeMap
-
- vecKey(int) - Method in class water.fvec.Vec.VectorGroup
-
Returns Vec Key from Vec id#
- vecs() - Method in class water.fvec.Frame
-
The internal array of Vecs.
- vecs(int[]) - Method in class water.fvec.Frame
-
- version - Variable in class water.api.CloudV1
-
- version - Variable in class water.api.SchemaMetadata
-
- version - Variable in class water.api.SchemaMetadataBase
-
- version - Variable in class water.H2O.OptArgs
-
-version, -version=true; print version and exit
- VG_LEN1 - Static variable in class water.fvec.Vec.VectorGroup
-
The common shared vector group for very short vectors
- vpredict - Variable in class hex.AUC
-
- vresponse() - Method in class hex.SupervisedModelBuilder
-
- __meta - Variable in class water.api.Schema
-
- _apiSocket - Static variable in class water.init.NetworkInit
-
- _appendables - Variable in class water.MRTask
-
- _arr - Variable in class hex.ConfusionMatrix
-
- _aucdata - Variable in class hex.ModelMetrics
-
- _backEnd - Variable in class water.KeySnapshot.KeyInfo
-
- _balance_classes - Variable in class hex.SupervisedModel.SupervisedParameters
-
Should all classes be over/under-sampled to balance the class
distribution?
- _category - Variable in class water.init.NodePersistentStorage.NodePersistentStorageEntry
-
- _check_no_locking - Static variable in class water.TypeMap
-
- _chunkOff - Variable in class water.fvec.AppendableVec
-
- _chunkSize - Variable in class water.fvec.FileVec
-
- _cidx - Variable in class water.fvec.NewChunk
-
- _class_sampling_factors - Variable in class hex.SupervisedModel.SupervisedParameters
-
Desired over/under-sampling ratios per class (lexicographic order).
- _classErr - Variable in class hex.ConfusionMatrix
-
- _client - Variable in class water.HeartBeat
-
- _cloudLocked - Static variable in class water.Paxos
-
- _cm - Variable in class hex.ModelMetrics
-
- _cmTable - Variable in class hex.ConfusionMatrix
-
- _cols - Static variable in class water.rapids.ASTddply
-
- _column - Variable in class water.Quantiles
-
- _column_name - Variable in class water.Quantiles
-
- _commonKnowledge - Static variable in class water.Paxos
-
- _convert_to_enum - Variable in class hex.SupervisedModel.SupervisedParameters
-
Convert the response column to an enum (forcing a classification
instead of a regression) as needed.
- _cpus_allowed - Variable in class water.HeartBeat
-
- _data - Variable in class water.parser.Parser.InspectDataOut
-
- _description - Variable in class water.Job
-
User description
- _dest - Variable in class water.Job
-
Jobs produce a single DKV result into Key _dest
- _destination_key - Variable in class hex.Model.Parameters
-
- _dev_msg - Variable in class water.H2OError
-
Potentially more detailed message intended for a developer (e.g.
- _distribution - Variable in class hex.SupervisedModel.SupervisedOutput
-
- _domain - Variable in class hex.ConfusionMatrix
-
- _domain - Variable in class water.Quantiles
-
- _domains - Variable in class hex.Model.Output
-
Categorical/factor/enum mappings, per column.
- _done - Variable in class water.Quantiles
-
- _dropConsCols - Variable in class hex.Model.Parameters
-
- _dropNA20Cols - Variable in class hex.Model.Parameters
-
- _ds - Variable in class water.fvec.NewChunk
-
- _ds - Variable in class water.rapids.ASTddply.Group
-
- _end_time - Variable in class water.Job
-
Job end_time using Sys.CTM, or 0 if not ended
- _error_url - Variable in class water.H2OError
-
- _espc - Variable in class water.fvec.AppendableVec
-
- _espc - Variable in class water.fvec.Vec
-
Element-start per chunk.
- _ex - Variable in class water.DTask
-
- _exception - Variable in class water.Job
-
Any exception thrown by this Job, or null if none
- _exception_msg - Variable in class water.H2OError
-
Raw exception message, if any.
- _exception_type - Variable in class water.H2OError
-
Exception type, if any.
- _fjqueue - Variable in class water.HeartBeat
-
- _fjthrds - Variable in class water.HeartBeat
-
- _fr - Variable in class water.MRTask
-
The Vectors (or Keys) to work on.
- _frame - Variable in class water.fvec.Frame.VecSpecifier
-
- _fs - Variable in class water.MRTask
-
We can add more things to block on - in case we want a bunch of lazy
tasks produced by children to all end before this top-level task ends.
- _fun - Static variable in class water.rapids.ASTApply
-
- _fun - Static variable in class water.rapids.ASTddply
-
- _fun_args - Static variable in class water.rapids.ASTApply
-
- _fun_args - Static variable in class water.rapids.ASTddply
-
- _gflops - Variable in class water.HeartBeat
-
- _groups - Variable in class water.rapids.ASTddply.ddplyPass1
-
- _gSetup - Variable in class water.parser.ParseSetup.GuessSetupTsk
-
- _hash - Variable in class water.rapids.ASTddply.Group
-
- _heartbeat - Variable in class water.H2ONode
-
- _hi - Variable in class water.MRTask
-
Internal field to track a range of local Chunks to work on
- _hr - Variable in class hex.ModelMetrics
-
- _http_status - Variable in class water.H2OError
-
HTTP status code for this error.
- _id - Variable in class water.fvec.NewChunk
-
- _ignored_columns - Variable in class hex.Model.Parameters
-
- _impl_class - Variable in class water.api.Schema
-
- _interpolated - Variable in class water.Quantiles
-
- _interpolation_type - Variable in class water.Quantiles
-
- _interpolation_type_used - Variable in class water.Quantiles
-
- _invalidLines - Variable in class water.parser.Parser.InspectDataOut
-
- _is - Variable in class water.fvec.NewChunk
-
- _isEnum - Variable in class water.Quantiles
-
- _isInt - Variable in class water.Quantiles
-
- _iterations - Variable in class water.Quantiles
-
- _jobs - Variable in class water.api.JobsHandler.Jobs
-
- _kb - Variable in class water.Key
-
- _key - Variable in class water.api.JobsHandler.Jobs
-
- _key - Variable in class water.Atomic
-
- _key - Variable in class water.H2ONode
-
- _key - Variable in class water.Keyed
-
Key mapping a Value which holds this object; may be null
- _key - Variable in class water.KeySnapshot.KeyInfo
-
- _key - Variable in class water.Value
-
The Key part of a Key/Value store.
- _keyInfos - Variable in class water.KeySnapshot
-
- _keys - Variable in class water.HeartBeat
-
- _keys - Variable in class water.MRTask
-
- _last_heard_from - Variable in class water.H2ONode
-
- _left - Variable in class water.MRTask
-
Internal field to track the left & right sub-range of chunks to work on
- _len - Variable in class water.fvec.Chunk
-
Number of rows in this Chunk; publically a read-only field.
- _lo - Variable in class water.MRTask
-
Internal field to track a range of local Chunks to work on
- _lockers - Variable in class water.Lockable
-
List of Job Keys locking this Key.
- _log2ChkSize - Variable in class water.fvec.FileVec
-
- _ls - Variable in class water.fvec.NewChunk
-
- _margin - Static variable in class water.rapids.ASTApply
-
- _max - Variable in class water.Quantiles
-
- _max - Variable in class water.Value
-
Size of the serialized wad of bits.
- _max_after_balance_size - Variable in class hex.SupervisedModel.SupervisedParameters
-
When classes are being balanced, limit the resulting dataset size to
the specified multiple of the original dataset size.
- _max_confusion_matrix_size - Variable in class hex.Model.Parameters
-
For classification models, the maximum size (in terms of classes) of
the confusion matrix for it to be printed.
- _max_hit_ratio_k - Variable in class hex.SupervisedModel.SupervisedParameters
-
The maximum number (top K) of predictions to use for hit ratio
computation (for multi-class only, 0 to disable)
- _max_ncols - Variable in class water.Quantiles
-
- _max_qbins - Variable in class water.Quantiles
-
- _maxP - Variable in class water.util.MRUtils.ParallelTasks
-
- _memary - Variable in class water.H2O
-
- _membw - Variable in class water.HeartBeat
-
- _messages - Variable in class hex.ModelBuilder
-
A list of field validation issues.
- _min - Variable in class water.Quantiles
-
- _model_metrics - Variable in class hex.Model.Output
-
List of all the associated ModelMetrics objects, so we can delete them
when we delete this model.
- _modelClassDist - Variable in class hex.SupervisedModel.SupervisedOutput
-
- _modifiesInputs - Variable in class water.DTask
-
- _mse - Variable in class hex.ModelMetrics
-
- _msg - Variable in class water.H2OError
-
Message intended for the end user (a data scientist).
- _multiple_pass - Variable in class water.Quantiles
-
- _name - Variable in class water.init.NodePersistentStorage.NodePersistentStorageEntry
-
- _names - Variable in class hex.Model.Output
-
Columns used in the model and are used to match up with scoring data
columns.
- _names - Variable in class water.fvec.Frame
-
Vec names
- _nclass - Variable in class hex.SupervisedModelBuilder
-
- _ncols - Variable in class water.parser.Parser.InspectDataOut
-
- _newValEnd - Variable in class water.Quantiles
-
- _newValStart - Variable in class water.Quantiles
-
- _nhi - Variable in class water.MRTask
-
Internal field to track a range of remote nodes/JVMs to work on
- _nleft - Variable in class water.MRTask
-
Internal field to track the left & right remote nodes/JVMs to work on
- _nlines - Variable in class water.parser.Parser.InspectDataOut
-
- _nodeId - Variable in class water.init.TimelineSnapshot.Event
-
- _nrite - Variable in class water.MRTask
-
Internal field to track the left & right remote nodes/JVMs to work on
- _nthreads - Variable in class water.HeartBeat
-
- _num_cpus - Variable in class water.HeartBeat
-
- _nxx - Variable in class water.MRTask
-
Internal field to track a range of remote nodes/JVMs to work on
- _output - Variable in class hex.Model
-
- _parms - Variable in class hex.Model
-
- _parms - Variable in class hex.ModelBuilder
-
All the parameters required to build the model.
- _pctile - Variable in class water.Quantiles
-
- _pid - Variable in class water.HeartBeat
-
- _predErr - Variable in class hex.ConfusionMatrix
-
- _priorClassDist - Variable in class hex.SupervisedModel.SupervisedOutput
-
- _priority - Variable in class water.H2O.FJWThr
-
- _process_num_open_fds - Variable in class water.HeartBeat
-
- _progressKey - Variable in class water.Job
-
- _qbins - Variable in class water.Quantiles.BinningTask
-
- _quantile - Variable in class water.Quantiles
-
- _quantile_requested - Variable in class water.Quantiles
-
- _rawData - Variable in class water.KeySnapshot.KeyInfo
-
- _response - Variable in class hex.SupervisedModelBuilder
-
- _response_column - Variable in class hex.SupervisedModel.SupervisedParameters
-
Supervised models have an expected response they get to train with!
- _response_key - Variable in class hex.SupervisedModelBuilder
-
- _result - Variable in class water.Quantiles
-
- _result - Variable in class water.util.ProfileCollectorTask
-
- _result_single - Variable in class water.Quantiles
-
- _rite - Variable in class water.MRTask
-
Internal field to track the left & right sub-range of chunks to work on
- _rpcs - Variable in class water.HeartBeat
-
- _sb - Variable in class water.rapids.Env
-
- _sb - Variable in class water.util.SB
-
- _score_each_iteration - Variable in class hex.Model.Parameters
-
- _sends - Variable in class water.init.TimelineSnapshot
-
- _setup - Variable in class water.parser.Parser
-
- _sigma - Variable in class hex.ModelMetrics
-
- _size - Variable in class water.init.NodePersistentStorage.NodePersistentStorageEntry
-
- _source_key - Variable in class water.Quantiles
-
- _sparseLen - Variable in class water.fvec.NewChunk
-
- _ss - Variable in class water.fvec.NewChunk
-
- _sslen - Variable in class water.fvec.NewChunk
-
- _stack_depth - Variable in class water.util.ProfileCollectorTask
-
- _stacktrace - Variable in class water.H2OError
-
Stacktrace, if any.
- _start_time - Variable in class water.Job
-
Job start_time using Sys.CTM
- _startTime - Variable in class hex.DMatrix.MatrixMulStats
-
- _state - Variable in class hex.Model.Output
-
Job state (CANCELLED, FAILED, DONE).
- _state - Variable in class water.Job
-
- _sumsqe - Variable in class hex.ModelMetrics.MetricBuilder
-
- _system_load_average - Variable in class water.HeartBeat
-
- _sz - Variable in class water.KeySnapshot.KeyInfo
-
- _tasks - Variable in class water.util.MRUtils.ParallelTasks
-
- _tcp_readers - Variable in class water.H2ONode
-
- _tcps_active - Variable in class water.HeartBeat
-
- _timCnt - Variable in class water.fvec.NewChunk
-
- _timestamp - Variable in class water.H2OError
-
Milliseconds since the epoch for the time that this H2OError instance was created.
- _timestamp_millis - Variable in class water.init.NodePersistentStorage.NodePersistentStorageEntry
-
- _topLocal - Variable in class water.MRTask
-
Internal field to track if this is a top-level local call
- _totalRows - Variable in class water.Quantiles
-
- _traces - Variable in class water.util.JStack
-
- _traces - Variable in class water.util.JStackCollectorTask
-
- _train - Variable in class hex.Model.Parameters
-
- _train - Variable in class hex.ModelBuilder
-
- _training_duration_in_ms - Variable in class hex.Model.Output
-
The duration in mS for model training, again this comes from the Job
which needs to split from ModelBuilder.
- _training_start_time - Variable in class hex.Model.Output
-
The start time in mS since the epoch for model training, again this
comes from the Job which needs to split from ModelBuilder.
- _type - Variable in class water.KeySnapshot.KeyInfo
-
- _udpSocket - Static variable in class water.init.NetworkInit
-
- _unsafe - Static variable in class water.Icer
-
- _val - Variable in class water.util.IcedInt
-
- _valBinSize - Variable in class water.Quantiles
-
- _valEnd - Variable in class water.Quantiles
-
- _valid - Variable in class hex.Model.Parameters
-
- _valid - Variable in class hex.ModelBuilder
-
- _valMaxBinCnt - Variable in class water.Quantiles
-
- _valRange - Variable in class water.Quantiles
-
- _valStart - Variable in class water.Quantiles
-
- _values - Variable in class water.H2OError
-
Any values that are relevant to reporting or handling this error.
- _version_pattern - Static variable in class water.api.Schema
-
- _vresponse - Variable in class hex.SupervisedModelBuilder
-
- _vresponse_key - Variable in class hex.SupervisedModelBuilder
-
- _warnings - Variable in class hex.Model
-
- _work - Variable in class hex.ModelMetrics.MetricBuilder
-
- _xs - Variable in class water.fvec.NewChunk
-